You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ds...@apache.org on 2016/01/29 02:16:18 UTC

[01/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-831 3dd04f2f4 -> 4c951aff4


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/VM.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/VM.java b/gemfire-core/src/test/java/dunit/VM.java
deleted file mode 100644
index f4cde93..0000000
--- a/gemfire-core/src/test/java/dunit/VM.java
+++ /dev/null
@@ -1,1347 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.io.File;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.rmi.RemoteException;
-import java.util.concurrent.Callable;
-//import java.util.Iterator;
-//import java.util.Vector;
-
-import hydra.MethExecutorResult;
-
-import com.gemstone.gemfire.test.dunit.standalone.BounceResult;
-import com.gemstone.gemfire.test.dunit.standalone.RemoteDUnitVMIF;
-
-/**
- * This class represents a Java Virtual Machine that runs on a host.
- *
- * @author David Whitlock
- *
- */
-public class VM implements java.io.Serializable {
-
-  /** The host on which this VM runs */
-  private Host host;
-
-  /** The process id of this VM */
-  private int pid;
-
-  /** The hydra client for this VM */
-  private RemoteDUnitVMIF client;
-
-  /** The state of this VM */
-  private volatile boolean available;
-
-  ////////////////////  Constructors  ////////////////////
-
-  /**
-   * Creates a new <code>VM</code> that runs on a given host with a
-   * given process id.
-   */
-  public VM(Host host, int pid, RemoteDUnitVMIF client) {
-    this.host = host;
-    this.pid = pid;
-    this.client = client;
-    this.available = true;
-  }
-
-  //////////////////////  Accessors  //////////////////////
-
-  /**
-   * Returns the host on which this <code>VM</code> runs
-   */
-  public Host getHost() {
-    return this.host;
-  }
-
-  /**
-   * Returns the process id of this <code>VM</code>
-   */
-  public int getPid() {
-    return this.pid;
-  }
-
-  /////////////////  Remote Method Invocation  ///////////////
-
-  /**
-   * Invokes a static zero-arg method  with an {@link Object} or
-   * <code>void</code> return type in this VM.  If the return type of
-   * the method is <code>void</code>, <code>null</code> is returned.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public Object invoke(Class c, String methodName) {
-    return invoke(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Asynchronously invokes a static zero-arg method with an {@link
-   * Object} or <code>void</code> return type in this VM.  If the
-   * return type of the method is <code>void</code>, <code>null</code>
-   * is returned.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   */
-  public AsyncInvocation invokeAsync(Class c, String methodName) {
-    return invokeAsync(c, methodName, null);
-  }
-
-  /**
-   * Invokes a static method with an {@link Object} or
-   * <code>void</code> return type in this VM.  If the return type of
-   * the method is <code>void</code>, <code>null</code> is returned.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public Object invoke(Class c, String methodName, Object[] args) {
-    if (!this.available) {
-      String s = "VM not available: " + this;
-      throw new RMIException(this, c.getName(), methodName,
-            new IllegalStateException(s));
-    }
-    MethExecutorResult result = null;
-    int retryCount = 120;
-    do {
-    try {
-      result = this.client.executeMethodOnClass(c.getName(), methodName, args);
-      break; // out of while loop
-    } catch( RemoteException e ) {
-      boolean isWindows = false;
-      String os = System.getProperty("os.name");
-      if (os != null) {
-        if (os.indexOf("Windows") != -1) {
-          isWindows = true;
-        }
-      }
-      if (isWindows && retryCount-- > 0) {
-        boolean interrupted = Thread.interrupted();
-        try { Thread.sleep(1000); } catch (InterruptedException ignore) {interrupted = true;}
-        finally {
-          if (interrupted) {
-            Thread.currentThread().interrupt();
-          }
-        }
-      } else {
-        throw new RMIException(this, c.getName(), methodName, e );
-      }
-    }
-    } while (true);
-
-    if (!result.exceptionOccurred()) {
-      return result.getResult();
-
-    } else {
-      Throwable thr = result.getException();
-      throw new RMIException(this, c.getName(), methodName, thr,
-                             result.getStackTrace()); 
-    }
-  }
-
-  /**
-   * Asynchronously invokes a static method with an {@link Object} or
-   * <code>void</code> return type in this VM.  If the return type of
-   * the method is <code>void</code>, <code>null</code> is returned.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   */
-  public AsyncInvocation invokeAsync(final Class c, 
-                                     final String methodName,
-                                     final Object[] args) {
-    AsyncInvocation ai =
-      new AsyncInvocation(c, methodName, new Runnable() {
-        public void run() {
-          final Object o = invoke(c, methodName, args);
-          AsyncInvocation.setReturnValue(o);
-        }
-      });
-    ai.start();
-    return ai;
-  }
-
-  /**
-   * Asynchronously invokes an instance method with an {@link Object} or
-   * <code>void</code> return type in this VM.  If the return type of
-   * the method is <code>void</code>, <code>null</code> is returned.
-   *
-   * @param o
-   *        The object on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   */
-  public AsyncInvocation invokeAsync(final Object o, 
-                                     final String methodName,
-                                     final Object[] args) {
-    AsyncInvocation ai =
-      new AsyncInvocation(o, methodName, new Runnable() {
-        public void run() {
-          final Object ret = invoke(o, methodName, args);
-          AsyncInvocation.setReturnValue(ret);
-        }
-      });
-    ai.start();
-    return ai;
-  }
-
-  /**
-   * Invokes the <code>run</code> method of a {@link Runnable} in this
-   * VM.  Recall that <code>run</code> takes no arguments and has no
-   * return value.
-   *
-   * @param r
-   *        The <code>Runnable</code> to be run
-   *
-   * @see SerializableRunnable
-   */
-  public AsyncInvocation invokeAsync(Runnable r) {
-    return invokeAsync(r, "run", new Object[0]);
-  }
-  
-  /**
-   * Invokes the <code>call</code> method of a {@link Runnable} in this
-   * VM.  
-   *
-   * @param c
-   *        The <code>Callable</code> to be run
-   *
-   * @see SerializableCallable
-   */
-  public AsyncInvocation invokeAsync(Callable c) {
-    return invokeAsync(c, "call", new Object[0]);
-  }
-
-  /**
-   * Invokes the <code>run</code> method of a {@link Runnable} in this
-   * VM.  Recall that <code>run</code> takes no arguments and has no
-   * return value.
-   *
-   * @param r
-   *        The <code>Runnable</code> to be run
-   *
-   * @see SerializableRunnable
-   */
-  public void invoke(Runnable r) {
-    invoke(r, "run");
-  }
-  
-  /**
-   * Invokes the <code>run</code> method of a {@link Runnable} in this
-   * VM.  Recall that <code>run</code> takes no arguments and has no
-   * return value.
-   *
-   * @param c
-   *        The <code>Callable</code> to be run
-   *
-   * @see SerializableCallable
-   */
-  public Object invoke(Callable c) {
-    return invoke(c, "call");
-  }
-  
-  /**
-   * Invokes the <code>run</code method of a {@link Runnable} in this
-   * VM.  If the invocation throws AssertionFailedError, and repeatTimeoutMs
-   * is >0, the <code>run</code> method is invoked repeatedly until it
-   * either succeeds, or repeatTimeoutMs has passed.  The AssertionFailedError
-   * is thrown back to the sender of this method if <code>run</code> has not
-   * completed successfully before repeatTimeoutMs has passed.
-   */
-  public void invokeRepeatingIfNecessary(RepeatableRunnable o, long repeatTimeoutMs) {
-    invoke(o, "runRepeatingIfNecessary", new Object[] {new Long(repeatTimeoutMs)});
-  }
-
-  /**
-   * Invokes an instance method with no arguments on an object that is
-   * serialized into this VM.  The return type of the method can be
-   * either {@link Object} or <code>void</code>.  If the return type
-   * of the method is <code>void</code>, <code>null</code> is
-   * returned.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public Object invoke(Object o, String methodName) {
-    return invoke(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method can be either {@link
-   * Object} or <code>void</code>.  If the return type of the method
-   * is <code>void</code>, <code>null</code> is returned.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public Object invoke(Object o, String methodName, Object[] args) {
-    if (!this.available) {
-      String s = "VM not available: " + this;
-      throw new RMIException(this, o.getClass().getName(), methodName,
-            new IllegalStateException(s));
-    }
-    MethExecutorResult result = null;
-    int retryCount = 120;
-    do {
-    try {
-      if ( args == null )
-        result = this.client.executeMethodOnObject(o, methodName);
-      else
-        result = this.client.executeMethodOnObject(o, methodName, args);
-      break; // out of while loop
-    } catch( RemoteException e ) {
-      if (retryCount-- > 0) {
-        boolean interrupted = Thread.interrupted();
-        try { Thread.sleep(1000); } catch (InterruptedException ignore) {interrupted = true;}
-        finally {
-          if (interrupted) {
-            Thread.currentThread().interrupt();
-          }
-        }
-      } else {
-        throw new RMIException(this, o.getClass().getName(), methodName, e );
-      }
-    }
-    } while (true);
-
-    if (!result.exceptionOccurred()) {
-      return result.getResult();
-
-    } else {
-      Throwable thr = result.getException();
-      throw new RMIException(this, o.getClass().getName(), methodName, thr,
-                             result.getStackTrace()); 
-    }
-  }
-
-  /**
-   * Invokes the <code>main</code> method of a given class
-   *
-   * @param c
-   *        The class on which to invoke the <code>main</code> method
-   * @param args
-   *        The "command line" arguments to pass to the
-   *        <code>main</code> method
-   */
-  public void invokeMain(Class c, String[] args) {
-    Object[] stupid = new Object[] { args };
-    invoke(c, "main", stupid);
-  }
-
-  /**
-   * Asynchronously invokes the <code>main</code> method of a given
-   * class
-   *
-   * @param c
-   *        The class on which to invoke the <code>main</code> method
-   * @param args
-   *        The "command line" arguments to pass to the
-   *        <code>main</code> method
-   */
-  public AsyncInvocation invokeMainAsync(Class c, String[] args) {
-    Object[] stupid = new Object[] { args };
-    return invokeAsync(c, "main", stupid);
-  }
-
-  /**
-   * Invokes a static method with a <code>boolean</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>boolean</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public boolean invokeBoolean(Class c, String methodName) {
-    return invokeBoolean(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>boolean</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>boolean</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public boolean invokeBoolean(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a boolean";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Boolean) {
-      return ((Boolean) result).booleanValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a boolean";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>boolean</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>boolean</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public boolean invokeBoolean(Object o, String methodName) {
-    return invokeBoolean(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>boolean</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>boolean</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public boolean invokeBoolean(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a boolean";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Boolean) {
-      return ((Boolean) result).booleanValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a boolean";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>char</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>char</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public char invokeChar(Class c, String methodName) {
-    return invokeChar(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>char</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>char</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public char invokeChar(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a char";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Character) {
-      return ((Character) result).charValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a char";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>char</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>char</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public char invokeChar(Object o, String methodName) {
-    return invokeChar(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>char</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>char</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public char invokeChar(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a char";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Character) {
-      return ((Character) result).charValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a char";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>byte</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>byte</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public byte invokeByte(Class c, String methodName) {
-    return invokeByte(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>byte</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>byte</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public byte invokeByte(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a byte";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Byte) {
-      return ((Byte) result).byteValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a byte";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>byte</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>byte</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public byte invokeByte(Object o, String methodName) {
-    return invokeByte(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>byte</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>byte</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public byte invokeByte(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a byte";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Byte) {
-      return ((Byte) result).byteValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a byte";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>short</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>short</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public short invokeShort(Class c, String methodName) {
-    return invokeShort(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>short</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>short</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public short invokeShort(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a short";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Short) {
-      return ((Short) result).shortValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a short";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>short</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>short</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public short invokeShort(Object o, String methodName) {
-    return invokeShort(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>short</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>short</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public short invokeShort(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a short";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Short) {
-      return ((Short) result).shortValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a short";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>int</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>int</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public int invokeInt(Class c, String methodName) {
-    return invokeInt(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>int</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>int</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public int invokeInt(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a int";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Integer) {
-      return ((Integer) result).intValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a int";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>int</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>int</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public int invokeInt(Object o, String methodName) {
-    return invokeInt(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>int</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>int</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public int invokeInt(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a int";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Integer) {
-      return ((Integer) result).intValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a int";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>long</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>long</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public long invokeLong(Class c, String methodName) {
-    return invokeLong(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>long</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>long</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public long invokeLong(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a long";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Long) {
-      return ((Long) result).longValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a long";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>long</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>long</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public long invokeLong(Object o, String methodName) {
-    return invokeLong(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>long</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>long</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public long invokeLong(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a long";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Long) {
-      return ((Long) result).longValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a long";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>float</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>float</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public float invokeFloat(Class c, String methodName) {
-    return invokeFloat(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>float</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>float</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public float invokeFloat(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a float";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Float) {
-      return ((Float) result).floatValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a float";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>float</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>float</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public float invokeFloat(Object o, String methodName) {
-    return invokeFloat(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>float</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>float</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public float invokeFloat(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a float";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Float) {
-      return ((Float) result).floatValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a float";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes a static method with a <code>double</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>double</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public double invokeDouble(Class c, String methodName) {
-    return invokeDouble(c, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes a static method with a <code>double</code> return type
-   * in this VM.
-   *
-   * @param c
-   *        The class on which to invoke the method
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>double</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public double invokeDouble(Class c, String methodName, Object[] args) {
-    Object result = invoke(c, methodName, args);
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a double";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Double) {
-      return ((Double) result).doubleValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a double";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>double</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>double</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public double invokeDouble(Object o, String methodName) {
-    return invokeDouble(o, methodName, new Object[0]);
-  }
-
-  /**
-   * Invokes an instance method on an object that is serialized into
-   * this VM.  The return type of the method is <code>double</code>.
-   *
-   * @param o
-   *        The receiver of the method invocation
-   * @param methodName
-   *        The name of the method to invoke
-   * @param args
-   *        Arguments passed to the method call (must be {@link
-   *        java.io.Serializable}). 
-   *
-   * @throws IllegalArgumentException
-   *         The method does not return a <code>double</code>
-   * @throws RMIException
-   *         An exception occurred on while invoking the method in
-   *         this VM
-   */
-  public double invokeDouble(Object o, String methodName, Object[] args) {
-    Object result = invoke(o, methodName, args);
-    Class c = o.getClass();
-    if (result == null) {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned null, expected a double";
-      throw new IllegalArgumentException(s);
-
-    } else if (result instanceof Double) {
-      return ((Double) result).doubleValue();
-
-    } else {
-      String s = "Method \"" + methodName + "\" in class \"" +
-        c.getName() + "\" returned a \"" + result.getClass().getName()
-        + "\" expected a double";
-      throw new IllegalArgumentException(s);
-    }
-  }
-
-  /**
-   * Synchronously bounces (mean kills and restarts) this <code>VM</code>.
-   * Concurrent bounce attempts are synchronized but attempts to invoke
-   * methods on a bouncing VM will cause test failure.  Tests using bounce
-   * should be placed at the end of the dunit test suite, since an exception
-   * here will cause all tests using the unsuccessfully bounced VM to fail.
-   * 
-   * This method is currently not supported by the standalone dunit
-   * runner.
-   *
-   * @throws RMIException if an exception occurs while bouncing this VM, for
-   *  example a HydraTimeoutException if the VM fails to stop within {@link
-   *  hydra.Prms#maxClientShutdownWaitSec} or restart within {@link
-   *  hydra.Prms#maxClientStartupWaitSec}.
-   */
-  public synchronized void bounce() {
-    if (!this.available) {
-      String s = "VM not available: " + this;
-      throw new RMIException(this, this.getClass().getName(), "bounceVM",
-            new IllegalStateException(s));
-    }
-    this.available = false;
-    try {
-      BounceResult result = DUnitEnv.get().bounce(this.pid);
-      
-      this.pid = result.getNewPid();
-      this.client = result.getNewClient();
-      this.available = true;
-    } catch (UnsupportedOperationException e) {
-      this.available = true;
-      throw e;
-    } catch (RemoteException e) {
-      StringWriter sw = new StringWriter();
-      e.printStackTrace(new PrintWriter(sw, true));
-      RMIException rmie = new RMIException(this, this.getClass().getName(),
-        "bounceVM", e, sw.toString());
-      throw rmie;
-    }
-  }
-
-  /////////////////////  Utility Methods  ////////////////////
-
-  public String toString() {
-    return "VM " + this.getPid() + " running on " + this.getHost();
-  }
-
-  public static int getCurrentVMNum() {
-    return DUnitEnv.get().getVMID();
-  }
-  
-  public File getWorkingDirectory() {
-    return DUnitEnv.get().getWorkingDirectory(this.getPid());
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
index 4ba1fc7..f24b136 100644
--- a/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
+++ b/gemfire-lucene/src/test/java/com/gemstone/gemfire/cache/lucene/internal/distributed/LuceneFunctionReadPathDUnitTest.java
@@ -45,12 +45,11 @@ import com.gemstone.gemfire.cache.lucene.internal.LuceneServiceImpl;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+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.junit.categories.DistributedTest;
 
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
-
 @Category(DistributedTest.class)
 public class LuceneFunctionReadPathDUnitTest extends CacheTestCase {
   private static final String INDEX_NAME = "index";



[21/52] [abbrv] incubator-geode git commit: Update Events section of Geode Community website

Posted by ds...@apache.org.
Update Events section of Geode Community website

this closes #76


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/ed313510
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/ed313510
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/ed313510

Branch: refs/heads/feature/GEODE-831
Commit: ed31351044baa860b5e2722654dd27ae5f5f324a
Parents: 93deadc
Author: Dave Barnes <db...@pivotal.io>
Authored: Sat Jan 23 17:34:04 2016 -0800
Committer: Swapnil Bawaskar <sb...@pivotal.io>
Committed: Mon Jan 25 12:01:07 2016 -0800

----------------------------------------------------------------------
 .../website/content/community/index.html        | 40 +++++++-------------
 1 file changed, 14 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed313510/gemfire-site/website/content/community/index.html
----------------------------------------------------------------------
diff --git a/gemfire-site/website/content/community/index.html b/gemfire-site/website/content/community/index.html
index a2ec4e9..958e211 100644
--- a/gemfire-site/website/content/community/index.html
+++ b/gemfire-site/website/content/community/index.html
@@ -68,52 +68,40 @@ under the License. -->
 		</div>
 		<div class="row">
     	<div class="col-md-3 done">
-    	    	<h3><a target="_blank" href="http://events.linuxfoundation.org/events/archive/2015/apachecon-north-america">ApacheCon </a> <small>Austin, TX <br/> April 13-16, 2015</small></h3>
+    	    	<h3><a target="_blank" href="https://fosdem.org/2016/schedule/event/hpc_bigdata_fastdata1/">FOSDEM</a> <br />
+                <small>Brussels, Belgium <br/> January 31, 2016</small></h3>
     	    	<p>
               <ul>
                 <li>
-                  <a target="_blank" href="http://events.linuxfoundation.org/sites/events/files/slides/GemFire_ApacheCon.pdf">"Unleashing the Silicon Forest Fire - the Open Sourcing of GemFire"</a>
+                  <a target="_blank" href="https://fosdem.org/2016/schedule/event/hpc_bigdata_fastdata1/">"Big Data meets Fast Data: a scalable hybrid real-time transactional and analytics solution"</a>
                 </li>
                 <li>
-                  <a target="_blank" href="http://events.linuxfoundation.org/sites/events/files/slides/apachecon15_markito_melo.pdf">"Implementing a Highly-Scalable Stock Prediction System with R, Geode and Spring XD"</a>
+                  <a target="_blank" href="https://fosdem.org/2016/schedule/event/hpc_bigdata_debs/">"Taxi trip analysis (DEBS grand-challenge) with Apache Geode (incubating)"</a>
                 </li>
               </ul>
             </p>
         </div>
 			<div class="col-md-3 done">
-    	    	<h3><a target="_blank" href="http://conferences.oreilly.com/oscon/open-source-2015">OSCON </a> <small>Portland, OR<br /> July 20-24, 2015</small></h3>
+    	    	<h3><a target="_blank" href="http://www.seajug.org/">SeaJUG </a><br />
+                <small>Seattle, WA<br /> February 16, 2016</small></h3>
             <p>
               <ul>
-                <li><a target="_blank" href="http://conferences.oreilly.com/oscon/open-source-2015/public/schedule/detail/44875">Build your first Internet of Things App today with Open Source Software</a></li>
+                <li><a target="_blank" href="http://www.seajug.org/">Introduction to Apache Geode (incubating)</a><br />Swapnil Bawaskar, William Markito</li>
               <ul/>
             <p>
 			</div>
       <div class="col-md-3 done">
-            <h3><a target="_blank" href="http://www.springone2gx.com/">SpringOne2GX</a> <small>Washington, DC<br /> September 14-17, 2015</small></h3>
-            <p>
-              <ul>
-                <li><a target="_blank" href="http://www.slideshare.net/SpringCentral/building-highly-scalable-spring-applications-using-inmemory-data-grids-53086251">Building highly-scalable Spring applications with in-memory, distributed data grids</a></li>
-
-                <li><a target="_blank" href="http://www.slideshare.net/SpringCentral/implementing-a-highly-scalable-stock-prediction-system-with-r-apache-geode-and-spring-xd">Implementing a highly scalable stock prediction system with R, Geode and Spring XD</a></li>
-              <ul/>
+            <h3><a target="_blank" href="http://geodesummit.com/">Apache Geode Summit</a><br />
+            <small>Palo Alto, CA<br /> March 9, 2016</small></h3>
+<p>
+<ul>
+<li><a target="_blank" href="http://geodesummit.com/">The inaugural Geode Summit is a full day conference to bring together the Apache Geode (incubating) community and GemFire users and developers.</a>
+</li>
+</ul>
             <p>
       </div>
     </div>
     <div class="row">
-      <div class="col-md-3 done">
-        <h3><a target="_blank" href="http://events.linuxfoundation.org/events/apache-big-data-europe">Apache: Big Data </a> <small>Budapest, Hungary <br/> September 28-30, 2015</small></h3>
-        <p>
-        <ul>
-          <li><a target="_blank" href="http://events.linuxfoundation.org/sites/events/files/slides/ApacheConBigData%20-%20Introducing%20Apache%20Geode%20-%20final.pdf">An Introduction to Apache Geode (incubating)</a></li>
-          <li><a target="_blank" href="https://events.linuxfoundation.org/sites/events/files/slides/ApacheCon%20Big%20Data%202015%20-%20Implementing%20a%20Highly%20Scalable%20In-Memory%20Stock%20Prediction%20System%20with%20Apache%20Geode%20(incubating),%20R,%20SparkML%20and%20Spring%20XD.pdf">Implementing a Highly Scalable In-Memory Stock Prediction System with Apache Geode (incubating), R and Spring XD</a></li>
-        <ul/>
-        <p>
-      </div>
-      <div class="col-md-3 done">
-    	    	<h3><a target="_blank" href="http://www.slideshare.net/ApacheGeode/open-sourcing-gemfire-apache-geode">PJUG Meetup </a> <small>Portland, OR <br /> July 20-24, 2015</small></h3>
-            <p>Joint meeting with co-hosted between OSCON, PJUG and PDXScala<p>
-			</div>
-
 			<div class="col-md-3">
 				<h3>&nbsp;</h3>
     	    	<p><i>Want to organize a Geode event? <a href="mailto:gregchase@apache.org">Contact us!</a></i><p>


[18/52] [abbrv] incubator-geode git commit: Deprecating waitForCriterion in DistributedTestCase

Posted by ds...@apache.org.
Deprecating waitForCriterion in DistributedTestCase

Now that Awaitility is part of the test dependencies, we should just use
that.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/3bdaff69
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/3bdaff69
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/3bdaff69

Branch: refs/heads/feature/GEODE-831
Commit: 3bdaff694e2b136638827d8c02891e0caa1cce03
Parents: 20d47eb
Author: Dan Smith <up...@apache.org>
Authored: Fri Jan 22 11:11:21 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Mon Jan 25 11:37:47 2016 -0800

----------------------------------------------------------------------
 .../java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java | 3 +++
 1 file changed, 3 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3bdaff69/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
index 4f59210..80f5a47 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
@@ -79,6 +79,7 @@ import com.gemstone.gemfire.internal.logging.ManagerLogWriter;
 import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
 import com.gemstone.gemfire.internal.util.Callable;
 import com.gemstone.gemfire.management.internal.cli.LogWrapper;
+import com.jayway.awaitility.Awaitility;
 import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
@@ -1097,7 +1098,9 @@ public abstract class DistributedTestCase extends TestCase implements java.io.Se
    * @param ms total time to wait, in milliseconds
    * @param interval pause interval between waits
    * @param throwOnTimeout if false, don't generate an error
+   * @deprecated Use {@link Awaitility} instead.
    */
+  @Deprecated
   static public void waitForCriterion(WaitCriterion ev, long ms, 
       long interval, boolean throwOnTimeout) {
     long waitThisTime;


[04/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
new file mode 100755
index 0000000..4f59210
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DistributedTestCase.java
@@ -0,0 +1,1432 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.File;
+import java.io.PrintWriter;
+import java.io.Serializable;
+import java.io.StringWriter;
+import java.net.UnknownHostException;
+import java.text.DecimalFormat;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.LinkedHashSet;
+import java.util.Map;
+import java.util.Properties;
+import java.util.Random;
+import java.util.concurrent.ConcurrentLinkedQueue;
+
+import org.apache.logging.log4j.LogManager;
+import org.apache.logging.log4j.Logger;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.InternalGemFireError;
+import com.gemstone.gemfire.LogWriter;
+import com.gemstone.gemfire.SystemFailure;
+import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.hdfs.internal.hoplog.HoplogConfig;
+import com.gemstone.gemfire.cache.query.QueryTestUtils;
+import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
+import com.gemstone.gemfire.cache30.ClientServerTestCase;
+import com.gemstone.gemfire.cache30.GlobalLockingDUnitTest;
+import com.gemstone.gemfire.cache30.MultiVMRegionTestCase;
+import com.gemstone.gemfire.cache30.RegionTestCase;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
+import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.CreationStackGenerator;
+import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManagerHelper;
+import com.gemstone.gemfire.internal.InternalDataSerializer;
+import com.gemstone.gemfire.internal.InternalInstantiator;
+import com.gemstone.gemfire.internal.OSProcess;
+import com.gemstone.gemfire.internal.SocketCreator;
+import com.gemstone.gemfire.internal.admin.ClientStatsManager;
+import com.gemstone.gemfire.internal.cache.DiskStoreObserver;
+import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import com.gemstone.gemfire.internal.cache.HARegion;
+import com.gemstone.gemfire.internal.cache.InitialImageOperation;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import com.gemstone.gemfire.internal.cache.tier.InternalClientMembership;
+import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
+import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import com.gemstone.gemfire.internal.cache.tier.sockets.DataSerializerPropogationDUnitTest;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
+import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import com.gemstone.gemfire.internal.logging.LocalLogWriter;
+import com.gemstone.gemfire.internal.logging.LogService;
+import com.gemstone.gemfire.internal.logging.LogWriterFactory;
+import com.gemstone.gemfire.internal.logging.LogWriterImpl;
+import com.gemstone.gemfire.internal.logging.ManagerLogWriter;
+import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
+import com.gemstone.gemfire.internal.util.Callable;
+import com.gemstone.gemfire.management.internal.cli.LogWrapper;
+import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher;
+import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+
+import junit.framework.TestCase;
+
+/**
+ * This class is the superclass of all distributed unit tests.
+ * 
+ * tests/hydra/JUnitTestTask is the main DUnit driver. It supports two 
+ * additional public static methods if they are defined in the test case:
+ * 
+ * public static void caseSetUp() -- comparable to JUnit's BeforeClass annotation
+ * 
+ * public static void caseTearDown() -- comparable to JUnit's AfterClass annotation
+ *
+ * @author David Whitlock
+ */
+@Category(DistributedTest.class)
+@SuppressWarnings("serial")
+public abstract class DistributedTestCase extends TestCase implements java.io.Serializable {
+  private static final Logger logger = LogService.getLogger();
+  private static final LogWriterLogger oldLogger = LogWriterLogger.create(logger);
+  private static final LinkedHashSet<String> testHistory = new LinkedHashSet<String>();
+
+  private static void setUpCreationStackGenerator() {
+    // the following is moved from InternalDistributedSystem to fix #51058
+    InternalDistributedSystem.TEST_CREATION_STACK_GENERATOR.set(
+    new CreationStackGenerator() {
+      @Override
+      public Throwable generateCreationStack(final DistributionConfig config) {
+        final StringBuilder sb = new StringBuilder();
+        final String[] validAttributeNames = config.getAttributeNames();
+        for (int i = 0; i < validAttributeNames.length; i++) {
+          final String attName = validAttributeNames[i];
+          final Object actualAtt = config.getAttributeObject(attName);
+          String actualAttStr = actualAtt.toString();
+          sb.append("  ");
+          sb.append(attName);
+          sb.append("=\"");
+          if (actualAtt.getClass().isArray()) {
+            actualAttStr = InternalDistributedSystem.arrayToString(actualAtt);
+          }
+          sb.append(actualAttStr);
+          sb.append("\"");
+          sb.append("\n");
+        }
+        return new Throwable("Creating distributed system with the following configuration:\n" + sb.toString());
+      }
+    });
+  }
+  
+  private static void tearDownCreationStackGenerator() {
+    InternalDistributedSystem.TEST_CREATION_STACK_GENERATOR.set(InternalDistributedSystem.DEFAULT_CREATION_STACK_GENERATOR);
+  }
+  
+  /** This VM's connection to the distributed system */
+  public static InternalDistributedSystem system;
+  private static Class lastSystemCreatedInTest;
+  private static Properties lastSystemProperties;
+  public static volatile String testName;
+  
+  private static ConcurrentLinkedQueue<ExpectedException> expectedExceptions = new ConcurrentLinkedQueue<ExpectedException>();
+
+  /** For formatting timing info */
+  private static final DecimalFormat format = new DecimalFormat("###.###");
+
+  public static boolean reconnect = false;
+
+  public static final boolean logPerTest = Boolean.getBoolean("dunitLogPerTest");
+
+  ///////////////////////  Utility Methods  ///////////////////////
+  
+  public void attachDebugger(VM vm, final String msg) {
+    vm.invoke(new SerializableRunnable("Attach Debugger") {
+      public void run() {
+        com.gemstone.gemfire.internal.util.DebuggerSupport.
+        waitForJavaDebugger(getSystem().getLogWriter().convertToLogWriterI18n(), msg);
+      } 
+    });
+  }
+
+
+  /**
+   * Invokes a <code>SerializableRunnable</code> in every VM that
+   * DUnit knows about.
+   *
+   * @see VM#invoke(Runnable)
+   */
+  public static void invokeInEveryVM(SerializableRunnable work) {
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+
+      for (int v = 0; v < host.getVMCount(); v++) {
+        VM vm = host.getVM(v);
+        vm.invoke(work);
+      }
+    }
+  }
+
+  public static void invokeInLocator(SerializableRunnable work) {
+    Host.getLocator().invoke(work);
+  }
+  
+  /**
+   * Invokes a <code>SerializableCallable</code> in every VM that
+   * DUnit knows about.
+   *
+   * @return a Map of results, where the key is the VM and the value is the result
+   * @see VM#invoke(Callable)
+   */
+  protected static Map invokeInEveryVM(SerializableCallable work) {
+    HashMap ret = new HashMap();
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+      for (int v = 0; v < host.getVMCount(); v++) {
+        VM vm = host.getVM(v);
+        ret.put(vm, vm.invoke(work));
+      }
+    }
+    return ret;
+  }
+
+  /**
+   * Invokes a method in every remote VM that DUnit knows about.
+   *
+   * @see VM#invoke(Class, String)
+   */
+  protected static void invokeInEveryVM(Class c, String method) {
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+
+      for (int v = 0; v < host.getVMCount(); v++) {
+        VM vm = host.getVM(v);
+        vm.invoke(c, method);
+      }
+    }
+  }
+
+  /**
+   * Invokes a method in every remote VM that DUnit knows about.
+   *
+   * @see VM#invoke(Class, String)
+   */
+  protected static void invokeInEveryVM(Class c, String method, Object[] methodArgs) {
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+
+      for (int v = 0; v < host.getVMCount(); v++) {
+        VM vm = host.getVM(v);
+        vm.invoke(c, method, methodArgs);
+      }
+    }
+  }
+  
+  /**
+   * The number of milliseconds to try repeating validation code in the
+   * event that AssertionFailedError is thrown.  For ACK scopes, no
+   * repeat should be necessary.
+   */
+  protected long getRepeatTimeoutMs() {
+    return 0;
+  }
+  
+  protected void invokeRepeatingIfNecessary(VM vm, RepeatableRunnable task) {
+    vm.invokeRepeatingIfNecessary(task, getRepeatTimeoutMs());
+  }
+  
+  /**
+   * Invokes a <code>SerializableRunnable</code> in every VM that
+   * DUnit knows about.  If work.run() throws an assertion failure, 
+   * its execution is repeated, until no assertion failure occurs or
+   * repeatTimeout milliseconds have passed.
+   *
+   * @see VM#invoke(Runnable)
+   */
+  protected void invokeInEveryVMRepeatingIfNecessary(RepeatableRunnable work) {
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+
+      for (int v = 0; v < host.getVMCount(); v++) {
+        VM vm = host.getVM(v);
+        vm.invokeRepeatingIfNecessary(work, getRepeatTimeoutMs());
+      }
+    }
+  }
+
+  /** Return the total number of VMs on all hosts */
+  protected static int getVMCount() {
+    int count = 0;
+    for (int h = 0; h < Host.getHostCount(); h++) {
+      Host host = Host.getHost(h);
+      count += host.getVMCount();
+    }
+    return count;
+  }
+
+
+  /** print a stack dump for this vm
+      @author bruce
+      @since 5.0
+   */
+  public static void dumpStack() {
+    com.gemstone.gemfire.internal.OSProcess.printStacks(0, false);
+  }
+  
+  /** print a stack dump for the given vm
+      @author bruce
+      @since 5.0
+   */
+  public static void dumpStack(VM vm) {
+    vm.invoke(com.gemstone.gemfire.test.dunit.DistributedTestCase.class, "dumpStack");
+  }
+  
+  /** print stack dumps for all vms on the given host
+      @author bruce
+      @since 5.0
+   */
+  public static void dumpStack(Host host) {
+    for (int v=0; v < host.getVMCount(); v++) {
+      host.getVM(v).invoke(com.gemstone.gemfire.test.dunit.DistributedTestCase.class, "dumpStack");
+    }
+  }
+  
+  /** print stack dumps for all vms
+      @author bruce
+      @since 5.0
+   */
+  public static void dumpAllStacks() {
+    for (int h=0; h < Host.getHostCount(); h++) {
+      dumpStack(Host.getHost(h));
+    }
+  }
+
+
+  public static String noteTiming(long operations, String operationUnit,
+                                  long beginTime, long endTime,
+                                  String timeUnit)
+  {
+    long delta = endTime - beginTime;
+    StringBuffer sb = new StringBuffer();
+    sb.append("  Performed ");
+    sb.append(operations);
+    sb.append(" ");
+    sb.append(operationUnit);
+    sb.append(" in ");
+    sb.append(delta);
+    sb.append(" ");
+    sb.append(timeUnit);
+    sb.append("\n");
+
+    double ratio = ((double) operations) / ((double) delta);
+    sb.append("    ");
+    sb.append(format.format(ratio));
+    sb.append(" ");
+    sb.append(operationUnit);
+    sb.append(" per ");
+    sb.append(timeUnit);
+    sb.append("\n");
+
+    ratio = ((double) delta) / ((double) operations);
+    sb.append("    ");
+    sb.append(format.format(ratio));
+    sb.append(" ");
+    sb.append(timeUnit);
+    sb.append(" per ");
+    sb.append(operationUnit);
+    sb.append("\n");
+
+    return sb.toString();
+  }
+
+  /**
+   * Creates a new LogWriter and adds it to the config properties. The config
+   * can then be used to connect to DistributedSystem, thus providing early
+   * access to the LogWriter before connecting. This call does not connect
+   * to the DistributedSystem. It simply creates and returns the LogWriter
+   * that will eventually be used by the DistributedSystem that connects using
+   * config.
+   * 
+   * @param config the DistributedSystem config properties to add LogWriter to
+   * @return early access to the DistributedSystem LogWriter
+   */
+  protected static LogWriter createLogWriter(Properties config) { // TODO:LOG:CONVERT: this is being used for ExpectedExceptions
+    Properties nonDefault = config;
+    if (nonDefault == null) {
+      nonDefault = new Properties();
+    }
+    addHydraProperties(nonDefault);
+    
+    DistributionConfig dc = new DistributionConfigImpl(nonDefault);
+    LogWriter logger = LogWriterFactory.createLogWriterLogger(
+        false/*isLoner*/, false/*isSecurityLog*/, dc, 
+        false);        
+    
+    // if config was non-null, then these will be added to it...
+    nonDefault.put(DistributionConfig.LOG_WRITER_NAME, logger);
+    
+    return logger;
+  }
+  
+  /**
+   * Fetches the GemFireDescription for this test and adds its 
+   * DistributedSystem properties to the provided props parameter.
+   * 
+   * @param config the properties to add hydra's test properties to
+   */
+  protected static void addHydraProperties(Properties config) {
+    Properties p = DUnitEnv.get().getDistributedSystemProperties();
+    for (Iterator iter = p.entrySet().iterator();
+        iter.hasNext(); ) {
+      Map.Entry entry = (Map.Entry) iter.next();
+      String key = (String) entry.getKey();
+      String value = (String) entry.getValue();
+      if (config.getProperty(key) == null) {
+        config.setProperty(key, value);
+      }
+    }
+  }
+  
+  ////////////////////////  Constructors  ////////////////////////
+
+  /**
+   * Creates a new <code>DistributedTestCase</code> test with the
+   * given name.
+   */
+  public DistributedTestCase(String name) {
+    super(name);
+    DUnitLauncher.launchIfNeeded();
+  }
+
+  ///////////////////////  Instance Methods  ///////////////////////
+
+
+  protected Class getTestClass() {
+    Class clazz = getClass();
+    while (clazz.getDeclaringClass() != null) {
+      clazz = clazz.getDeclaringClass();
+    }
+    return clazz;
+  }
+  
+  
+  /**
+   * This finds the log level configured for the test run.  It should be used
+   * when creating a new distributed system if you want to specify a log level.
+   * @return the dunit log-level setting
+   */
+  public static String getDUnitLogLevel() {
+    Properties p = DUnitEnv.get().getDistributedSystemProperties();
+    String result = p.getProperty(DistributionConfig.LOG_LEVEL_NAME);
+    if (result == null) {
+      result = ManagerLogWriter.levelToString(DistributionConfig.DEFAULT_LOG_LEVEL);
+    }
+    return result;
+  }
+
+  public final static Properties getAllDistributedSystemProperties(Properties props) {
+    Properties p = DUnitEnv.get().getDistributedSystemProperties();
+    
+    // our tests do not expect auto-reconnect to be on by default
+    if (!p.contains(DistributionConfig.DISABLE_AUTO_RECONNECT_NAME)) {
+      p.put(DistributionConfig.DISABLE_AUTO_RECONNECT_NAME, "true");
+    }
+
+    for (Iterator iter = props.entrySet().iterator();
+    iter.hasNext(); ) {
+      Map.Entry entry = (Map.Entry) iter.next();
+      String key = (String) entry.getKey();
+      Object value = entry.getValue();
+      p.put(key, value);
+    }
+    return p;
+  }
+
+  public void setSystem(Properties props, DistributedSystem ds) {
+    system = (InternalDistributedSystem)ds;
+    lastSystemProperties = props;
+    lastSystemCreatedInTest = getTestClass();
+  }
+  /**
+   * Returns this VM's connection to the distributed system.  If
+   * necessary, the connection will be lazily created using the given
+   * <code>Properties</code>.  Note that this method uses hydra's
+   * configuration to determine the location of log files, etc.
+   * Note: "final" was removed so that WANTestBase can override this method.
+   * This was part of the xd offheap merge.
+   *
+   * @see hydra.DistributedConnectionMgr#connect
+   * @since 3.0
+   */
+  public /*final*/ InternalDistributedSystem getSystem(Properties props) {
+    // Setting the default disk store name is now done in setUp
+    if (system == null) {
+      system = InternalDistributedSystem.getAnyInstance();
+    }
+    if (system == null || !system.isConnected()) {
+      // Figure out our distributed system properties
+      Properties p = getAllDistributedSystemProperties(props);
+      lastSystemCreatedInTest = getTestClass();
+      if (logPerTest) {
+        String testMethod = getTestName();
+        String testName = lastSystemCreatedInTest.getName() + '-' + testMethod;
+        String oldLogFile = p.getProperty(DistributionConfig.LOG_FILE_NAME);
+        p.put(DistributionConfig.LOG_FILE_NAME, 
+            oldLogFile.replace("system.log", testName+".log"));
+        String oldStatFile = p.getProperty(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME);
+        p.put(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME, 
+            oldStatFile.replace("statArchive.gfs", testName+".gfs"));
+      }
+      system = (InternalDistributedSystem)DistributedSystem.connect(p);
+      lastSystemProperties = p;
+    } else {
+      boolean needNewSystem = false;
+      if(!getTestClass().equals(lastSystemCreatedInTest)) {
+        Properties newProps = getAllDistributedSystemProperties(props);
+        needNewSystem = !newProps.equals(lastSystemProperties);
+        if(needNewSystem) {
+          getLogWriter().info(
+              "Test class has changed and the new DS properties are not an exact match. "
+                  + "Forcing DS disconnect. Old props = "
+                  + lastSystemProperties + "new props=" + newProps);
+        }
+      } else {
+        Properties activeProps = system.getProperties();
+        for (Iterator iter = props.entrySet().iterator();
+        iter.hasNext(); ) {
+          Map.Entry entry = (Map.Entry) iter.next();
+          String key = (String) entry.getKey();
+          String value = (String) entry.getValue();
+          if (!value.equals(activeProps.getProperty(key))) {
+            needNewSystem = true;
+            getLogWriter().info("Forcing DS disconnect. For property " + key
+                                + " old value = " + activeProps.getProperty(key)
+                                + " new value = " + value);
+            break;
+          }
+        }
+      }
+      if(needNewSystem) {
+        // the current system does not meet our needs to disconnect and
+        // call recursively to get a new system.
+        getLogWriter().info("Disconnecting from current DS in order to make a new one");
+        disconnectFromDS();
+        getSystem(props);
+      }
+    }
+    return system;
+  }
+
+
+  /**
+   * Crash the cache in the given VM in such a way that it immediately stops communicating with
+   * peers.  This forces the VM's membership manager to throw a ForcedDisconnectException by
+   * forcibly terminating the JGroups protocol stack with a fake EXIT event.<p>
+   * 
+   * NOTE: if you use this method be sure that you clean up the VM before the end of your
+   * test with disconnectFromDS() or disconnectAllFromDS().
+   */
+  public boolean crashDistributedSystem(VM vm) {
+    return (Boolean)vm.invoke(new SerializableCallable("crash distributed system") {
+      public Object call() throws Exception {
+        DistributedSystem msys = InternalDistributedSystem.getAnyInstance();
+        crashDistributedSystem(msys);
+        return true;
+      }
+    });
+  }
+  
+  /**
+   * Crash the cache in the given VM in such a way that it immediately stops communicating with
+   * peers.  This forces the VM's membership manager to throw a ForcedDisconnectException by
+   * forcibly terminating the JGroups protocol stack with a fake EXIT event.<p>
+   * 
+   * NOTE: if you use this method be sure that you clean up the VM before the end of your
+   * test with disconnectFromDS() or disconnectAllFromDS().
+   */
+  public void crashDistributedSystem(final DistributedSystem msys) {
+    MembershipManagerHelper.crashDistributedSystem(msys);
+    MembershipManagerHelper.inhibitForcedDisconnectLogging(false);
+    WaitCriterion wc = new WaitCriterion() {
+      public boolean done() {
+        return !msys.isConnected();
+      }
+      public String description() {
+        return "waiting for distributed system to finish disconnecting: " + msys;
+      }
+    };
+//    try {
+      waitForCriterion(wc, 10000, 1000, true);
+//    } finally {
+//      dumpMyThreads(getLogWriter());
+//    }
+  }
+
+  private String getDefaultDiskStoreName() {
+    String vmid = System.getProperty("vmid");
+    return "DiskStore-"  + vmid + "-"+ getTestClass().getCanonicalName() + "." + getTestName();
+  }
+
+  /**
+   * Returns this VM's connection to the distributed system.  If
+   * necessary, the connection will be lazily created using the
+   * <code>Properties</code> returned by {@link
+   * #getDistributedSystemProperties}.
+   *
+   * @see #getSystem(Properties)
+   *
+   * @since 3.0
+   */
+  public final InternalDistributedSystem getSystem() {
+    return getSystem(this.getDistributedSystemProperties());
+  }
+
+  /**
+   * Returns a loner distributed system that isn't connected to other
+   * vms
+   * 
+   * @since 6.5
+   */
+  public final InternalDistributedSystem getLonerSystem() {
+    Properties props = this.getDistributedSystemProperties();
+    props.put(DistributionConfig.MCAST_PORT_NAME, "0");
+    props.put(DistributionConfig.LOCATORS_NAME, "");
+    return getSystem(props);
+  }
+  
+  /**
+   * Returns a loner distributed system in combination with enforceUniqueHost
+   * and redundancyZone properties.
+   * Added specifically to test scenario of defect #47181.
+   */
+  public final InternalDistributedSystem getLonerSystemWithEnforceUniqueHost() {
+    Properties props = this.getDistributedSystemProperties();
+    props.put(DistributionConfig.MCAST_PORT_NAME, "0");
+    props.put(DistributionConfig.LOCATORS_NAME, "");
+    props.put(DistributionConfig.ENFORCE_UNIQUE_HOST_NAME, "true");
+    props.put(DistributionConfig.REDUNDANCY_ZONE_NAME, "zone1");
+    return getSystem(props);
+  }
+
+  /**
+   * Returns whether or this VM is connected to a {@link
+   * DistributedSystem}.
+   */
+  public final boolean isConnectedToDS() {
+    return system != null && system.isConnected();
+  }
+
+  /**
+   * Returns a <code>Properties</code> object used to configure a
+   * connection to a {@link
+   * com.gemstone.gemfire.distributed.DistributedSystem}.
+   * Unless overridden, this method will return an empty
+   * <code>Properties</code> object.
+   *
+   * @since 3.0
+   */
+  public Properties getDistributedSystemProperties() {
+    return new Properties();
+  }
+
+  /**
+   * Sets up the test (noop).
+   */
+  @Override
+  public void setUp() throws Exception {
+    logTestHistory();
+    setUpCreationStackGenerator();
+    testName = getName();
+    System.setProperty(HoplogConfig.ALLOW_LOCAL_HDFS_PROP, "true");
+    
+    if (testName != null) {
+      GemFireCacheImpl.setDefaultDiskStoreName(getDefaultDiskStoreName());
+      String baseDefaultDiskStoreName = getTestClass().getCanonicalName() + "." + getTestName();
+      for (int h = 0; h < Host.getHostCount(); h++) {
+        Host host = Host.getHost(h);
+        for (int v = 0; v < host.getVMCount(); v++) {
+          VM vm = host.getVM(v);
+          String vmDefaultDiskStoreName = "DiskStore-" + h + "-" + v + "-" + baseDefaultDiskStoreName;
+          vm.invoke(DistributedTestCase.class, "perVMSetUp", new Object[] {testName, vmDefaultDiskStoreName});
+        }
+      }
+    }
+    System.out.println("\n\n[setup] START TEST " + getClass().getSimpleName()+"."+testName+"\n\n");
+  }
+
+  /**
+   * Write a message to the log about what tests have ran previously. This
+   * makes it easier to figure out if a previous test may have caused problems
+   */
+  private void logTestHistory() {
+    String classname = getClass().getSimpleName();
+    testHistory.add(classname);
+    System.out.println("Previously run tests: " + testHistory);
+  }
+
+  public static void perVMSetUp(String name, String defaultDiskStoreName) {
+    setTestName(name);
+    GemFireCacheImpl.setDefaultDiskStoreName(defaultDiskStoreName);
+    System.setProperty(HoplogConfig.ALLOW_LOCAL_HDFS_PROP, "true");    
+  }
+  public static void setTestName(String name) {
+    testName = name;
+  }
+  
+  public static String getTestName() {
+    return testName;
+  }
+
+  /**
+   * For logPerTest to work, we have to disconnect from the DS, but all
+   * subclasses do not call super.tearDown(). To prevent this scenario
+   * this method has been declared final. Subclasses must now override
+   * {@link #tearDown2()} instead.
+   * @throws Exception
+   */
+  @Override
+  public final void tearDown() throws Exception {
+    tearDownCreationStackGenerator();
+    tearDown2();
+    realTearDown();
+    tearDownAfter();
+  }
+
+  /**
+   * Tears down the test. This method is called by the final {@link #tearDown()} method and should be overridden to
+   * perform actual test cleanup and release resources used by the test.  The tasks executed by this method are
+   * performed before the DUnit test framework using Hydra cleans up the client VMs.
+   * <p/>
+   * @throws Exception if the tear down process and test cleanup fails.
+   * @see #tearDown
+   * @see #tearDownAfter()
+   */
+  // TODO rename this method to tearDownBefore and change the access modifier to protected!
+  public void tearDown2() throws Exception {
+  }
+
+  protected void realTearDown() throws Exception {
+    if (logPerTest) {
+      disconnectFromDS();
+      invokeInEveryVM(DistributedTestCase.class, "disconnectFromDS");
+    }
+    cleanupAllVms();
+  }
+  
+  /**
+   * Tears down the test.  Performs additional tear down tasks after the DUnit tests framework using Hydra cleans up
+   * the client VMs.  This method is called by the final {@link #tearDown()} method and should be overridden to perform
+   * post tear down activities.
+   * <p/>
+   * @throws Exception if the test tear down process fails.
+   * @see #tearDown()
+   * @see #tearDown2()
+   */
+  protected void tearDownAfter() throws Exception {
+  }
+
+  public static void cleanupAllVms()
+  {
+    cleanupThisVM();
+    invokeInEveryVM(DistributedTestCase.class, "cleanupThisVM");
+    invokeInLocator(new SerializableRunnable() {
+      public void run() {
+        DistributionMessageObserver.setInstance(null);
+        unregisterInstantiatorsInThisVM();
+      }
+    });
+    DUnitLauncher.closeAndCheckForSuspects();
+  }
+
+
+  private static void cleanupThisVM() {
+    closeCache();
+    
+    SocketCreator.resolve_dns = true;
+    CacheCreation.clearThreadLocals();
+    System.getProperties().remove("gemfire.log-level");
+    System.getProperties().remove("jgroups.resolve_dns");
+    InitialImageOperation.slowImageProcessing = 0;
+    DistributionMessageObserver.setInstance(null);
+    QueryTestUtils.setCache(null);
+    CacheServerTestUtil.clearCacheReference();
+    RegionTestCase.preSnapshotRegion = null;
+    GlobalLockingDUnitTest.region_testBug32356 = null;
+    LogWrapper.close();
+    ClientProxyMembershipID.system = null;
+    MultiVMRegionTestCase.CCRegion = null;
+    InternalClientMembership.unregisterAllListeners();
+    ClientStatsManager.cleanupForTests();
+    ClientServerTestCase.AUTO_LOAD_BALANCE = false;
+    unregisterInstantiatorsInThisVM();
+    DistributionMessageObserver.setInstance(null);
+    QueryObserverHolder.reset();
+    DiskStoreObserver.setInstance(null);
+    System.getProperties().remove("gemfire.log-level");
+    System.getProperties().remove("jgroups.resolve_dns");
+    
+    if (InternalDistributedSystem.systemAttemptingReconnect != null) {
+      InternalDistributedSystem.systemAttemptingReconnect.stopReconnecting();
+    }
+    ExpectedException ex;
+    while((ex = expectedExceptions.poll()) != null) {
+      ex.remove();
+    }
+  }
+
+  private static void closeCache() {
+    GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
+    if(cache != null && !cache.isClosed()) {
+      destroyRegions(cache);
+      cache.close();
+    }
+  }
+  
+  protected static final void destroyRegions(Cache cache)
+      throws InternalGemFireError, Error, VirtualMachineError {
+    if (cache != null && !cache.isClosed()) {
+      //try to destroy the root regions first so that
+      //we clean up any persistent files.
+      for (Iterator itr = cache.rootRegions().iterator(); itr.hasNext();) {
+        Region root = (Region)itr.next();
+        //for colocated regions you can't locally destroy a partitioned
+        //region.
+        if(root.isDestroyed() || root instanceof HARegion || root instanceof PartitionedRegion) {
+          continue;
+        }
+        try {
+          root.localDestroyRegion("teardown");
+        }
+        catch (VirtualMachineError e) {
+          SystemFailure.initiateFailure(e);
+          throw e;
+        }
+        catch (Throwable t) {
+          getLogWriter().error(t);
+        }
+      }
+    }
+  }
+  
+  
+  public static void unregisterAllDataSerializersFromAllVms()
+  {
+    unregisterDataSerializerInThisVM();
+    invokeInEveryVM(new SerializableRunnable() {
+      public void run() {
+        unregisterDataSerializerInThisVM();
+      }
+    });
+    invokeInLocator(new SerializableRunnable() {
+      public void run() {
+        unregisterDataSerializerInThisVM();
+      }
+    });
+  }
+
+  public static void unregisterInstantiatorsInThisVM() {
+    // unregister all the instantiators
+    InternalInstantiator.reinitialize();
+    assertEquals(0, InternalInstantiator.getInstantiators().length);
+  }
+  
+  public static void unregisterDataSerializerInThisVM()
+  {
+    DataSerializerPropogationDUnitTest.successfullyLoadedTestDataSerializer = false;
+    // unregister all the Dataserializers
+    InternalDataSerializer.reinitialize();
+    // ensure that all are unregistered
+    assertEquals(0, InternalDataSerializer.getSerializers().length);
+  }
+
+
+  protected static void disconnectAllFromDS() {
+    disconnectFromDS();
+    invokeInEveryVM(DistributedTestCase.class,
+                    "disconnectFromDS");
+  }
+
+  /**
+   * Disconnects this VM from the distributed system
+   */
+  public static void disconnectFromDS() {
+    testName = null;
+    GemFireCacheImpl.testCacheXml = null;
+    if (system != null) {
+      system.disconnect();
+      system = null;
+    }
+    
+    for (;;) {
+      DistributedSystem ds = InternalDistributedSystem.getConnectedInstance();
+      if (ds == null) {
+        break;
+      }
+      try {
+        ds.disconnect();
+      }
+      catch (Exception e) {
+        // ignore
+      }
+    }
+    
+    {
+      AdminDistributedSystemImpl ads = 
+          AdminDistributedSystemImpl.getConnectedInstance();
+      if (ads != null) {// && ads.isConnected()) {
+        ads.disconnect();
+      }
+    }
+  }
+
+  /**
+   * Strip the package off and gives just the class name.
+   * Needed because of Windows file name limits.
+   */
+  private String getShortClassName() {
+    String result = this.getClass().getName();
+    int idx = result.lastIndexOf('.');
+    if (idx != -1) {
+      result = result.substring(idx+1);
+    }
+    return result;
+  }
+  
+  /** get the host name to use for a server cache in client/server dunit
+   * testing
+   * @param host
+   * @return the host name
+   */
+  public static String getServerHostName(Host host) {
+    return System.getProperty("gemfire.server-bind-address") != null?
+        System.getProperty("gemfire.server-bind-address")
+        : host.getHostName();
+  }
+
+  /** get the IP literal name for the current host, use this instead of  
+   * "localhost" to avoid IPv6 name resolution bugs in the JDK/machine config.
+   * @return an ip literal, this method honors java.net.preferIPvAddresses
+   */
+  public static String getIPLiteral() {
+    try {
+      return SocketCreator.getLocalHost().getHostAddress();
+    } catch (UnknownHostException e) {
+      throw new Error("problem determining host IP address", e);
+    }
+  }
+ 
+ 
+  /**
+   * Get the port that the standard dunit locator is listening on.
+   * @return
+   */
+  public static int getDUnitLocatorPort() {
+    return DUnitEnv.get().getLocatorPort();
+  }
+    
+  
+  /**
+   * Returns a unique name for this test method.  It is based on the
+   * name of the class as well as the name of the method.
+   */
+  public String getUniqueName() {
+    return getShortClassName() + "_" + this.getName();
+  }
+
+  /**
+   * Returns a <code>LogWriter</code> for logging information
+   * @deprecated Use a static logger from the log4j2 LogService.getLogger instead.
+   */
+  @Deprecated
+  public static InternalLogWriter getLogWriter() {
+    return oldLogger;
+  }
+
+  /**
+   * Helper method that causes this test to fail because of the given
+   * exception.
+   */
+  public static void fail(String message, Throwable ex) {
+    StringWriter sw = new StringWriter();
+    PrintWriter pw = new PrintWriter(sw, true);
+    pw.print(message);
+    pw.print(": ");
+    ex.printStackTrace(pw);
+    fail(sw.toString());
+  }
+
+  // utility methods
+
+  /** pause for a default interval */
+  protected void pause() {
+    pause(250);
+  }
+
+  /**
+   * Use of this function indicates a place in the tests tree where t
+   * he use of Thread.sleep() is
+   * highly questionable.
+   * <p>
+   * Some places in the system, especially those that test expirations and other
+   * timeouts, have a very good reason to call {@link Thread#sleep(long)}.  The
+   * <em>other</em> places are marked by the use of this method.
+   * 
+   * @param ms
+   */
+  static public final void staticPause(int ms) {
+//    getLogWriter().info("FIXME: Pausing for " + ms + " ms..."/*, new Exception()*/);
+    final long target = System.currentTimeMillis() + ms;
+    try {
+      for (;;) {
+        long msLeft = target - System.currentTimeMillis();
+        if (msLeft <= 0) {
+          break;
+        }
+        Thread.sleep(msLeft);
+      }
+    }
+    catch (InterruptedException e) {
+      fail("interrupted", e);
+    }
+    
+  }
+  
+  /**
+   * Blocks until the clock used for expiration moves forward.
+   * @return the last time stamp observed
+   */
+  public static final long waitForExpiryClockToChange(LocalRegion lr) {
+    return waitForExpiryClockToChange(lr, lr.cacheTimeMillis());
+  }
+  /**
+   * Blocks until the clock used for expiration moves forward.
+   * @param baseTime the timestamp that the clock must exceed
+   * @return the last time stamp observed
+   */
+  public static final long waitForExpiryClockToChange(LocalRegion lr, final long baseTime) {
+    long nowTime;
+    do {
+      Thread.yield();
+      nowTime = lr.cacheTimeMillis();
+    } while ((nowTime - baseTime) <= 0L);
+    return nowTime;
+  }
+  
+  /** pause for specified ms interval
+   * Make sure system clock has advanced by the specified number of millis before
+   * returning.
+   */
+  public static final void pause(int ms) {
+    LogWriter log = getLogWriter();
+    if (ms >= 1000 || log.fineEnabled()) { // check for fine but log at info
+      getLogWriter().info("Pausing for " + ms + " ms..."/*, new Exception()*/);
+    }
+    final long target = System.currentTimeMillis() + ms;
+    try {
+      for (;;) {
+        long msLeft = target - System.currentTimeMillis();
+        if (msLeft <= 0) {
+          break;
+        }
+        Thread.sleep(msLeft);
+      }
+    }
+    catch (InterruptedException e) {
+      fail("interrupted", e);
+    }
+  }
+  
+  public interface WaitCriterion {
+    public boolean done();
+    public String description();
+  }
+  
+  public interface WaitCriterion2 extends WaitCriterion {
+    /**
+     * If this method returns true then quit waiting even if we are not done.
+     * This allows a wait to fail early.
+     */
+    public boolean stopWaiting();
+  }
+
+  /**
+   * If true, we randomize the amount of time we wait before polling a
+   * {@link WaitCriterion}.
+   */
+  static private final boolean USE_JITTER = true;
+  static private final Random jitter = new Random();
+  
+  /**
+   * Return a jittered interval up to a maximum of <code>ms</code>
+   * milliseconds, inclusive.
+   * 
+   * The result is bounded by 50 ms as a minimum and 5000 ms as a maximum.
+   * 
+   * @param ms total amount of time to wait
+   * @return randomized interval we should wait
+   */
+  private static int jitterInterval(long ms) {
+    final int minLegal = 50;
+    final int maxLegal = 5000;
+    if (ms <= minLegal) {
+      return (int)ms; // Don't ever jitter anything below this.
+    }
+
+    int maxReturn = maxLegal;
+    if (ms < maxLegal) {
+      maxReturn = (int)ms;
+    }
+
+    return minLegal + jitter.nextInt(maxReturn - minLegal + 1);
+  }
+  
+  /**
+   * Wait until given criterion is met
+   * @param ev criterion to wait on
+   * @param ms total time to wait, in milliseconds
+   * @param interval pause interval between waits
+   * @param throwOnTimeout if false, don't generate an error
+   */
+  static public void waitForCriterion(WaitCriterion ev, long ms, 
+      long interval, boolean throwOnTimeout) {
+    long waitThisTime;
+    if (USE_JITTER) {
+      waitThisTime = jitterInterval(interval);
+    }
+    else {
+      waitThisTime = interval;
+    }
+    final long tilt = System.currentTimeMillis() + ms;
+    for (;;) {
+//      getLogWriter().info("Testing to see if event has occurred: " + ev.description());
+      if (ev.done()) {
+        return; // success
+      }
+      if (ev instanceof WaitCriterion2) {
+        WaitCriterion2 ev2 = (WaitCriterion2)ev;
+        if (ev2.stopWaiting()) {
+          if (throwOnTimeout) {
+            fail("stopWaiting returned true: " + ev.description());
+          }
+          return;
+        }
+      }
+
+      // Calculate time left
+      long timeLeft = tilt - System.currentTimeMillis();
+      if (timeLeft <= 0) {
+        if (!throwOnTimeout) {
+          return; // not an error, but we're done
+        }
+        fail("Event never occurred after " + ms + " ms: " + ev.description());
+      }
+      
+      if (waitThisTime > timeLeft) {
+        waitThisTime = timeLeft;
+      }
+      
+      // Wait a little bit
+      Thread.yield();
+      try {
+//        getLogWriter().info("waiting " + waitThisTime + "ms for " + ev.description());
+        Thread.sleep(waitThisTime);
+      } catch (InterruptedException e) {
+        fail("interrupted");
+      }
+    }
+  }
+
+  /**
+   * Wait on a mutex.  This is done in a loop in order to address the
+   * "spurious wakeup" "feature" in Java.
+   * @param ev condition to test
+   * @param mutex object to lock and wait on
+   * @param ms total amount of time to wait
+   * @param interval interval to pause for the wait
+   * @param throwOnTimeout if false, no error is thrown.
+   */
+  static public void waitMutex(WaitCriterion ev, Object mutex, long ms, 
+      long interval, boolean throwOnTimeout) {
+    final long tilt = System.currentTimeMillis() + ms;
+    long waitThisTime;
+    if (USE_JITTER) {
+      waitThisTime = jitterInterval(interval);
+    }
+    else {
+      waitThisTime = interval;
+    }
+    synchronized (mutex) {
+      for (;;) {
+        if (ev.done()) {
+          break;
+        }
+        
+        long timeLeft = tilt - System.currentTimeMillis();
+        if (timeLeft <= 0) {
+          if (!throwOnTimeout) {
+            return; // not an error, but we're done
+          }
+          fail("Event never occurred after " + ms + " ms: " + ev.description());
+        }
+        
+        if (waitThisTime > timeLeft) {
+          waitThisTime = timeLeft;
+        }
+        
+        try {
+          mutex.wait(waitThisTime);
+        } catch (InterruptedException e) {
+          fail("interrupted");
+        }
+      } // for
+    } // synchronized
+  }
+
+  /**
+   * Wait for a thread to join
+   * @param t thread to wait on
+   * @param ms maximum time to wait
+   * @throws AssertionFailure if the thread does not terminate
+   */
+  static public void join(Thread t, long ms, LogWriter logger) {
+    final long tilt = System.currentTimeMillis() + ms;
+    final long incrementalWait;
+    if (USE_JITTER) {
+      incrementalWait = jitterInterval(ms);
+    }
+    else {
+      incrementalWait = ms; // wait entire time, no looping.
+    }
+    final long start = System.currentTimeMillis();
+    for (;;) {
+      // I really do *not* understand why this check is necessary
+      // but it is, at least with JDK 1.6.  According to the source code
+      // and the javadocs, one would think that join() would exit immediately
+      // if the thread is dead.  However, I can tell you from experimentation
+      // that this is not the case. :-(  djp 2008-12-08
+      if (!t.isAlive()) {
+        break;
+      }
+      try {
+        t.join(incrementalWait);
+      } catch (InterruptedException e) {
+        fail("interrupted");
+      }
+      if (System.currentTimeMillis() >= tilt) {
+        break;
+      }
+    } // for
+    if (logger == null) {
+      logger = new LocalLogWriter(LogWriterImpl.INFO_LEVEL, System.out);
+    }
+    if (t.isAlive()) {
+      logger.info("HUNG THREAD");
+      dumpStackTrace(t, t.getStackTrace(), logger);
+      dumpMyThreads(logger);
+      t.interrupt(); // We're in trouble!
+      fail("Thread did not terminate after " + ms + " ms: " + t);
+//      getLogWriter().warning("Thread did not terminate" 
+//          /* , new Exception()*/
+//          );
+    }
+    long elapsedMs = (System.currentTimeMillis() - start);
+    if (elapsedMs > 0) {
+      String msg = "Thread " + t + " took " 
+        + elapsedMs
+        + " ms to exit.";
+      logger.info(msg);
+    }
+  }
+
+  public static void dumpStackTrace(Thread t, StackTraceElement[] stack, LogWriter logger) {
+    StringBuilder msg = new StringBuilder();
+    msg.append("Thread=<")
+      .append(t)
+      .append("> stackDump:\n");
+    for (int i=0; i < stack.length; i++) {
+      msg.append("\t")
+        .append(stack[i])
+        .append("\n");
+    }
+    logger.info(msg.toString());
+  }
+  /**
+   * Dump all thread stacks
+   */
+  public static void dumpMyThreads(LogWriter logger) {
+    OSProcess.printStacks(0, false);
+  }
+  
+  /**
+   * A class that represents an currently logged expected exception, which
+   * should be removed
+   * 
+   * @author Mitch Thomas
+   * @since 5.7bugfix
+   */
+  public static class ExpectedException implements Serializable {
+    private static final long serialVersionUID = 1L;
+
+    final String ex;
+
+    final transient VM v;
+
+    public ExpectedException(String exception) {
+      this.ex = exception;
+      this.v = null;
+    }
+
+    ExpectedException(String exception, VM vm) {
+      this.ex = exception;
+      this.v = vm;
+    }
+
+    public String getRemoveString() {
+      return "<ExpectedException action=remove>" + ex + "</ExpectedException>";
+    }
+
+    public String getAddString() {
+      return "<ExpectedException action=add>" + ex + "</ExpectedException>";
+    }
+
+    public void remove() {
+      SerializableRunnable removeRunnable = new SerializableRunnable(
+          "removeExpectedExceptions") {
+        public void run() {
+          final String remove = getRemoveString();
+          final InternalDistributedSystem sys = InternalDistributedSystem
+              .getConnectedInstance();
+          if (sys != null) {
+            sys.getLogWriter().info(remove);
+          }
+          try {
+            getLogWriter().info(remove);
+          } catch (Exception noHydraLogger) {
+          }
+
+          logger.info(remove);
+        }
+      };
+
+      if (this.v != null) {
+        v.invoke(removeRunnable);
+      }
+      else {
+        invokeInEveryVM(removeRunnable);
+      }
+      String s = getRemoveString();
+      LogManager.getLogger(LogService.BASE_LOGGER_NAME).info(s);
+      // log it locally
+      final InternalDistributedSystem sys = InternalDistributedSystem
+          .getConnectedInstance();
+      if (sys != null) { // avoid creating a system
+        sys.getLogWriter().info(s);
+      }
+      getLogWriter().info(s);
+    }
+  }
+
+  /**
+   * Log in all VMs, in both the test logger and the GemFire logger the
+   * expected exception string to prevent grep logs from complaining. The
+   * expected string is used by the GrepLogs utility and so can contain
+   * regular expression characters.
+   * 
+   * If you do not remove the expected exception, it will be removed at the
+   * end of your test case automatically.
+   * 
+   * @since 5.7bugfix
+   * @param exception
+   *          the exception string to expect
+   * @return an ExpectedException instance for removal
+   */
+  public static ExpectedException addExpectedException(final String exception) {
+    return addExpectedException(exception, null);
+  }
+
+  /**
+   * Log in all VMs, in both the test logger and the GemFire logger the
+   * expected exception string to prevent grep logs from complaining. The
+   * expected string is used by the GrepLogs utility and so can contain
+   * regular expression characters.
+   * 
+   * @since 5.7bugfix
+   * @param exception
+   *          the exception string to expect
+   * @param v
+   *          the VM on which to log the expected exception or null for all VMs
+   * @return an ExpectedException instance for removal purposes
+   */
+  public static ExpectedException addExpectedException(final String exception,
+      VM v) {
+    final ExpectedException ret;
+    if (v != null) {
+      ret = new ExpectedException(exception, v);
+    }
+    else {
+      ret = new ExpectedException(exception);
+    }
+    // define the add and remove expected exceptions
+    final String add = ret.getAddString();
+    SerializableRunnable addRunnable = new SerializableRunnable(
+        "addExpectedExceptions") {
+      public void run() {
+        final InternalDistributedSystem sys = InternalDistributedSystem
+            .getConnectedInstance();
+        if (sys != null) {
+          sys.getLogWriter().info(add);
+        }
+        try {
+          getLogWriter().info(add);
+        } catch (Exception noHydraLogger) {
+        }
+ 
+        logger.info(add);
+      }
+    };
+    if (v != null) {
+      v.invoke(addRunnable);
+    }
+    else {
+      invokeInEveryVM(addRunnable);
+    }
+    
+    LogManager.getLogger(LogService.BASE_LOGGER_NAME).info(add);
+    // Log it locally too
+    final InternalDistributedSystem sys = InternalDistributedSystem
+        .getConnectedInstance();
+    if (sys != null) { // avoid creating a cache
+      sys.getLogWriter().info(add);
+    }
+    getLogWriter().info(add);
+    expectedExceptions.add(ret);
+    return ret;
+  }
+
+  /** 
+   * delete locator state files.  Use this after getting a random port
+   * to ensure that an old locator state file isn't picked up by the
+   * new locator you're starting.
+   * @param ports
+   */
+  public void deleteLocatorStateFile(int... ports) {
+    for (int i=0; i<ports.length; i++) {
+      File stateFile = new File("locator"+ports[i]+"view.dat");
+      if (stateFile.exists()) {
+        stateFile.delete();
+      }
+    }
+  }
+  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/Host.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/Host.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/Host.java
new file mode 100644
index 0000000..4ec6165
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/Host.java
@@ -0,0 +1,212 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+
+import com.gemstone.gemfire.test.dunit.standalone.RemoteDUnitVMIF;
+
+/**
+ * <P>This class represents a host on which a remote method may be
+ * invoked.  It provides access to the VMs and GemFire systems that
+ * run on that host.</P>
+ *
+ * <P>Additionally, it provides access to the Java RMI registry that
+ * runs on the host.  By default, an RMI registry is only started on
+ * the host on which Hydra's Master VM runs.  RMI registries may be
+ * started on other hosts via additional Hydra configuration.</P>
+ *
+ * @author David Whitlock
+ *
+ */
+public abstract class Host implements java.io.Serializable {
+
+  /** The available hosts */
+  protected static List hosts = new ArrayList();
+
+  private static VM locator;
+
+  /** Indicates an unstarted RMI registry */
+  protected static int NO_REGISTRY = -1;
+
+  ////////////////////  Instance Fields  ////////////////////
+
+  /** The name of this host machine */
+  private String hostName;
+
+  /** The VMs that run on this host */
+  private List vms;
+
+  /** The GemFire systems that are available on this host */
+  private List systems;
+  
+  /** Key is system name, value is GemFireSystem instance */
+  private HashMap systemNames;
+  
+  ////////////////////  Static Methods  /////////////////////
+
+  /**
+   * Returns the number of known hosts
+   */
+  public static int getHostCount() {
+    return hosts.size();
+  }
+
+  /**
+   * Makes note of a new <code>Host</code>
+   */
+  protected static void addHost(Host host) {
+    hosts.add(host);
+  }
+
+  /**
+   * Returns a given host
+   *
+   * @param n
+   *        A zero-based identifier of the host
+   *
+   * @throws IllegalArgumentException
+   *         <code>n</code> is more than the number of hosts
+   */
+  public static Host getHost(int n) {
+    int size = hosts.size();
+    if (n >= size) {
+      String s = "Cannot request host " + n + ".  There are only " +
+        size + " hosts.";
+      throw new IllegalArgumentException(s);
+
+    } else {
+      return (Host) hosts.get(n);
+    }
+  }
+
+  /////////////////////  Constructors  //////////////////////
+
+  /**
+   * Creates a new <code>Host</code> with the given name
+   */
+  protected Host(String hostName) {
+    if (hostName == null) {
+      String s = "Cannot create a Host with a null name";
+      throw new NullPointerException(s);
+    }
+
+    this.hostName = hostName;
+    this.vms = new ArrayList();
+    this.systems = new ArrayList();
+    this.systemNames = new HashMap();
+  }
+
+  ////////////////////  Instance Methods  ////////////////////
+
+  /**
+   * Returns the machine name of this host
+   */
+  public String getHostName() {
+    return this.hostName;
+  }
+
+  /**
+   * Returns the number of VMs that run on this host
+   */
+  public int getVMCount() {
+    return this.vms.size();
+  }
+
+  /**
+   * Returns a VM that runs on this host
+   *
+   * @param n
+   *        A zero-based identifier of the VM
+   *
+   * @throws IllegalArgumentException
+   *         <code>n</code> is more than the number of VMs
+   */
+  public VM getVM(int n) {
+    int size = vms.size();
+    if (n >= size) {
+      String s = "Cannot request VM " + n + ".  There are only " +
+        size + " VMs on " + this;
+      throw new IllegalArgumentException(s);
+
+    } else {
+      return (VM) vms.get(n);
+    }
+  }
+
+  /**
+   * Adds a VM to this <code>Host</code> with the given process id and client record.
+   */
+  protected void addVM(int pid, RemoteDUnitVMIF client) {
+    VM vm = new VM(this, pid, client);
+    this.vms.add(vm);
+  }
+
+  public static VM getLocator() {
+    return locator;
+  }
+  
+  private static void setLocator(VM l) {
+    locator = l;
+  }
+  
+  protected void addLocator(int pid, RemoteDUnitVMIF client) {
+    setLocator(new VM(this, pid, client));
+  }
+
+  /**
+   * Returns the number of GemFire systems that run on this host
+   */
+  public int getSystemCount() {
+    return this.systems.size();
+  }
+
+  ////////////////////  Utility Methods  ////////////////////
+
+  public String toString() {
+    StringBuffer sb = new StringBuffer("Host ");
+    sb.append(this.getHostName());
+    sb.append(" with ");
+    sb.append(getVMCount());
+    sb.append(" VMs");
+    return sb.toString();
+  }
+
+  /**
+   * Two <code>Host</code>s are considered equal if they have the same
+   * name.
+   */
+  public boolean equals(Object o) {
+    if (o instanceof Host) {
+      return ((Host) o).getHostName().equals(this.getHostName());
+
+    } else {
+      return false;
+    }
+  }
+
+  /**
+   * A <code>Host</code>'s hash code is based on the hash code of its
+   * name. 
+   */
+  public int hashCode() {
+    return this.getHostName().hashCode();
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RMIException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RMIException.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RMIException.java
new file mode 100644
index 0000000..b1f262b
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RMIException.java
@@ -0,0 +1,170 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import com.gemstone.gemfire.GemFireException;
+
+/**
+ * This exception is thrown when an exception occurs during a remote
+ * method invocation.  This {@link RuntimeException} wraps the actual
+ * exception.  It allows distributed unit tests to verify that an
+ * exception was thrown in a different VM.
+ *
+ * <PRE>
+ *     VM vm0 = host0.getVM(0);
+ *     try {
+ *       vm.invoke(this.getClass(), "getUnknownObject");
+ *
+ *     } catch (RMIException ex) {
+ *       assertEquals(ex.getCause() instanceof ObjectException);
+ *     }
+ * </PRE>
+ *
+ * Note that special steps are taken so that the stack trace of the
+ * cause exception reflects the call stack on the remote machine.
+ * The stack trace of the exception returned by {@link #getCause()}
+ * may not be available.
+ *
+ * @see hydra.RemoteTestModuleIF
+ *
+ * @author David Whitlock
+ *
+ */
+public class RMIException extends GemFireException {
+
+  /** SHADOWED FIELD that holds the cause exception (as opposed to the
+   * HokeyException */
+  private Throwable cause;
+
+  /** The name of the method being invoked */
+  private String methodName;
+
+  /** The name of the class (or class of the object type) whose method
+   * was being invoked */
+  private String className;
+
+  /** The type of exception that was thrown in the remote VM */
+  private String exceptionClassName;
+
+  /** Stack trace for the exception that was thrown in the remote VM */
+  private String stackTrace;
+
+  /** The VM in which the method was executing */
+  private VM vm;
+
+  ////////////////////////  Constructors  ////////////////////////
+
+  /**
+   * Creates a new <code>RMIException</code> that was caused by a
+   * given <code>Throwable</code> while invoking a given method.
+   */
+  public RMIException(VM vm, String className, String methodName,
+                      Throwable cause) {
+    super("While invoking " + className + "." + methodName + " in " +
+          vm, cause);
+    this.cause = cause;
+    this.className = className;
+    this.methodName = methodName;
+    this.vm = vm;
+  }
+
+  /**
+   * Creates a new <code>RMIException</code> to indicate that an
+   * exception of a given type was thrown while invoking a given
+   * method. 
+   *
+   * @param vm
+   *        The VM in which the method was executing
+   * @param className
+   *        The name of the class whose method was being invoked
+   *        remotely 
+   * @param methodName
+   *        The name of the method that was being invoked remotely
+   * @param cause
+   *        The type of exception that was thrown in the remote VM
+   * @param stackTrace
+   *        The stack trace of the exception from the remote VM
+   */
+  public RMIException(VM vm, String className, String methodName, 
+                      Throwable cause, String stackTrace) {
+    super("While invoking " + className + "." + methodName + " in " +
+          vm, new HokeyException(cause, stackTrace));
+    this.vm = vm;
+    this.cause = cause;
+    this.className = className;
+    this.methodName = methodName;
+//    this.exceptionClassName = exceptionClassName; assignment has no effect
+    this.stackTrace = stackTrace;
+  }
+
+  /**
+   * Returns the class name of the exception that was thrown in a
+   * remote method invocation.
+   */
+  public String getExceptionClassName() {
+    return this.exceptionClassName;
+  }
+
+//   /**
+//    * Returns the stack trace for the exception that was thrown in a
+//    * remote method invocation.
+//    */
+//   public String getStackTrace() {
+//     return this.stackTrace;
+//   }
+
+  /**
+   * Returns the cause of this exception.  Note that this is not
+   * necessarily the exception that gets printed out with the stack
+   * trace.
+   */
+  public Throwable getCause() {
+    return this.cause;
+  }
+
+  /**
+   * Returns the VM in which the remote method was invoked
+   */
+  public VM getVM() {
+    return this.vm;
+  }
+
+  //////////////////////  Inner Classes  //////////////////////
+
+  /**
+   * A hokey exception class that makes it looks like we have a real
+   * cause exception.
+   */
+  private static class HokeyException extends Throwable {
+    private String stackTrace;
+    private String toString;
+
+    HokeyException(Throwable cause, String stackTrace) {
+      this.toString = cause.toString();
+      this.stackTrace = stackTrace;
+    }
+
+    public void printStackTrace(java.io.PrintWriter pw) {
+      pw.print(this.stackTrace);
+      pw.flush();
+    }
+
+    public String toString() {
+      return this.toString;
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RepeatableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RepeatableRunnable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RepeatableRunnable.java
new file mode 100644
index 0000000..32e4369
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/RepeatableRunnable.java
@@ -0,0 +1,29 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+/**
+ * A RepeatableRunnable is an object that implements a method that
+ * can be invoked repeatably without causing any side affects.
+ *
+ * @author  dmonnie
+ */
+public interface RepeatableRunnable {
+  
+  public void runRepeatingIfNecessary(long repeatTimeoutMs);
+  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
new file mode 100644
index 0000000..cee0d85
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
@@ -0,0 +1,70 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.Serializable;
+import java.util.concurrent.Callable;
+
+/**
+ * This interface provides both {@link Serializable} and {@link
+ * Callable}.  It is often used in conjunction with {@link
+ * VM#invoke(Callable)}.
+ *
+ * <PRE>
+ * public void testRepilcatedRegionPut() {
+ *   final Host host = Host.getHost(0);
+ *   VM vm0 = host.getVM(0);
+ *   VM vm1 = host.getVM(1);
+ *   final String name = this.getUniqueName();
+ *   final Object value = new Integer(42);
+ *
+ *   SerializableCallable putMethod = new SerializableCallable("Replicated put") {
+ *       public Object call() throws Exception {
+ *         ...// get replicated test region //...
+ *         return region.put(name, value);
+ *       }
+ *      });
+ *   assertNull(vm0.invoke(putMethod));
+ *   assertEquals(value, vm1.invoke(putMethod));
+ *  }
+ * </PRE>
+ * 
+ * @author Mitch Thomas
+ */
+public abstract class SerializableCallable<T> implements Callable<T>, Serializable {
+  
+  private static final long serialVersionUID = -5914706166172952484L;
+  
+  private String name;
+
+  public SerializableCallable() {
+    this.name = null;
+  }
+
+  public SerializableCallable(String name) {
+    this.name = name;
+  }
+
+  public String toString() {
+    if (this.name != null) {
+      return "\"" + this.name + "\"";
+
+    } else {
+      return super.toString();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
new file mode 100644
index 0000000..85ae738
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
@@ -0,0 +1,92 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.Serializable;
+
+/**
+ * This interface provides both {@link Serializable} and {@link
+ * Runnable}.  It is often used in conjunction with {@link
+ * VM#invoke(Runnable)}.
+ *
+ * <PRE>
+ * public void testRegionPutGet() {
+ *   final Host host = Host.getHost(0);
+ *   VM vm0 = host.getVM(0);
+ *   VM vm1 = host.getVM(1);
+ *   final String name = this.getUniqueName();
+ *   final Object value = new Integer(42);
+ *
+ *   vm0.invoke(new SerializableRunnable("Put value") {
+ *       public void run() {
+ *         ...// get the region //...
+ *         region.put(name, value);
+ *       }
+ *      });
+ *   vm1.invoke(new SerializableRunnable("Get value") {
+ *       public void run() {
+ *         ...// get the region //...
+ *         assertEquals(value, region.get(name));
+ *       }
+ *     });
+ *  }
+ * </PRE>
+ */
+public abstract class SerializableRunnable
+  implements Serializable, Runnable {
+
+  private static final long serialVersionUID = 7584289978241650456L;
+  
+  private String name;
+
+  public SerializableRunnable() {
+    this.name = null;
+  }
+
+  /**
+   * This constructor lets you do the following:
+   *
+   * <PRE>
+   * vm.invoke(new SerializableRunnable("Do some work") {
+   *     public void run() {
+   *       // ...
+   *     }
+   *   });
+   * </PRE>
+   */
+  public SerializableRunnable(String name) {
+    this.name = name;
+  }
+  
+  public void setName(String newName) {
+    this.name = newName;
+  }
+  
+  public String getName() {
+    return this.name;
+  }
+
+  public String toString() {
+    if (this.name != null) {
+      return "\"" + this.name + "\"";
+
+    } else {
+      return super.toString();
+    }
+  }
+
+}


[37/52] [abbrv] incubator-geode git commit: GEODE-867: Undoing changes to pauseSender to wait for the pause

Posted by ds...@apache.org.
GEODE-867: Undoing changes to pauseSender to wait for the pause

GEODE-864 changed WANTestBase.pauseSender to wait for the sender to
pause. But apparently in
ConcurrentSerialGatewaySenderOperationsDUnitTest the sender never
actually pauses, causing a hang in precheckin.

Temporarily undoing the changes for GEODE-864 and just changing the one
test to use pauseSenderAndWaitForDispatcher instead. That will leave
GEODE-864 fixed but also fix the hang until we can figure out why the
sender is not paused in this case.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/09bd5307
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/09bd5307
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/09bd5307

Branch: refs/heads/feature/GEODE-831
Commit: 09bd5307994bd970bdf3bf4f1d5f302021e8b8e6
Parents: a724951
Author: Dan Smith <up...@apache.org>
Authored: Wed Jan 27 11:16:40 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Wed Jan 27 11:16:40 2016 -0800

----------------------------------------------------------------------
 .../gemfire/internal/cache/wan/WANTestBase.java | 23 ++++++++++++++++++--
 ...arallelGatewaySenderOperationsDUnitTest.java |  8 +++----
 .../ParallelWANConflationDUnitTest.java         |  8 +++----
 3 files changed, 29 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/09bd5307/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index 5539eb1..0c32d1f 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -2162,14 +2162,33 @@ public class WANTestBase extends DistributedTestCase{
         }
       }
       sender.pause();
-      ((AbstractGatewaySender) sender).getEventProcessor().waitForDispatcherToPause();
-      
     }
     finally {
       exp.remove();
       exln.remove();
     }
   }
+      
+  public static void pauseSenderAndWaitForDispatcherToPause(String senderId) {
+    final ExpectedException exln = addExpectedException("Could not connect");
+    ExpectedException exp = addExpectedException(ForceReattemptException.class
+        .getName());
+    try {
+      Set<GatewaySender> senders = cache.getGatewaySenders();
+      GatewaySender sender = null;
+      for (GatewaySender s : senders) {
+        if (s.getId().equals(senderId)) {
+          sender = s;
+          break;
+        }
+      }
+      sender.pause();
+      ((AbstractGatewaySender)sender).getEventProcessor().waitForDispatcherToPause();
+    } finally {
+      exp.remove();
+      exln.remove();
+    }    
+  }
   
   public static void resumeSender(String senderId) {
     final ExpectedException exln = addExpectedException("Could not connect");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/09bd5307/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
index 3d0eb5b..19f6c4b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
@@ -210,10 +210,10 @@ public class ParallelGatewaySenderOperationsDUnitTest extends WANTestBase {
     vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR", 100 });
     
     //now, pause all of the senders
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+    vm4.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
+    vm5.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
+    vm6.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
+    vm7.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
     
     //SECOND RUN: keep one thread doing puts to the region
     vm4.invokeAsync(WANTestBase.class, "doPuts", new Object[] { testName + "_PR", 1000 });

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/09bd5307/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
index 763b9c4..bce63f5 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
@@ -430,10 +430,10 @@ public class ParallelWANConflationDUnitTest extends WANTestBase {
   }
 
   protected void pauseSenders() {
-    vm4.invoke(() ->pauseSender( "ln" ));
-    vm5.invoke(() ->pauseSender( "ln" ));
-    vm6.invoke(() ->pauseSender( "ln" ));
-    vm7.invoke(() ->pauseSender( "ln" ));
+    vm4.invoke(() ->pauseSenderAndWaitForDispatcherToPause( "ln" ));
+    vm5.invoke(() ->pauseSenderAndWaitForDispatcherToPause( "ln" ));
+    vm6.invoke(() ->pauseSenderAndWaitForDispatcherToPause( "ln" ));
+    vm7.invoke(() ->pauseSenderAndWaitForDispatcherToPause( "ln" ));
   }
 
   protected void startSenders() {


[15/52] [abbrv] incubator-geode git commit: GEODE-815: Update copyright year in NOTICE

Posted by ds...@apache.org.
GEODE-815: Update copyright year in NOTICE


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/80971d52
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/80971d52
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/80971d52

Branch: refs/heads/feature/GEODE-831
Commit: 80971d5250f7bc6fe3341d04c249cbee261dab0d
Parents: 3e762a9
Author: Anthony Baker <ab...@apache.org>
Authored: Mon Jan 25 11:30:05 2016 -0800
Committer: Anthony Baker <ab...@apache.org>
Committed: Mon Jan 25 11:30:47 2016 -0800

----------------------------------------------------------------------
 NOTICE                                | 2 +-
 gemfire-assembly/src/main/dist/NOTICE | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/80971d52/NOTICE
----------------------------------------------------------------------
diff --git a/NOTICE b/NOTICE
index e73e3db..3f5dd07 100644
--- a/NOTICE
+++ b/NOTICE
@@ -1,5 +1,5 @@
 Apache Geode (incubating) 
-Copyright 2015 The Apache Software Foundation.
+Copyright 2016 The Apache Software Foundation.
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/80971d52/gemfire-assembly/src/main/dist/NOTICE
----------------------------------------------------------------------
diff --git a/gemfire-assembly/src/main/dist/NOTICE b/gemfire-assembly/src/main/dist/NOTICE
index e73e3db..3f5dd07 100644
--- a/gemfire-assembly/src/main/dist/NOTICE
+++ b/gemfire-assembly/src/main/dist/NOTICE
@@ -1,5 +1,5 @@
 Apache Geode (incubating) 
-Copyright 2015 The Apache Software Foundation.
+Copyright 2016 The Apache Software Foundation.
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).


[09/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GridAdvisorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GridAdvisorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GridAdvisorDUnitTest.java
index 8b480d6..9a6b3e4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GridAdvisorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GridAdvisorDUnitTest.java
@@ -16,16 +16,27 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import java.io.File;
+import java.io.IOException;
+import java.util.Arrays;
+import java.util.List;
+import java.util.Properties;
+
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.distributed.Locator;
+import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.InternalLocator;
 import com.gemstone.gemfire.internal.AvailablePort.Keeper;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.*;
-import java.io.*;
-import java.util.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the GridAdvisor

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HABug36773DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HABug36773DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HABug36773DUnitTest.java
index ea9eaa5..54da4b6 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HABug36773DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HABug36773DUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is the Bug test for the bug 36773. Skipped sequence id causes missing

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HAOverflowMemObjectSizerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HAOverflowMemObjectSizerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HAOverflowMemObjectSizerDUnitTest.java
index 6246080..2819790 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HAOverflowMemObjectSizerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/HAOverflowMemObjectSizerDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessageImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the size of clientUpdateMessageImpl with the size calculated by

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IncrementalBackupDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IncrementalBackupDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IncrementalBackupDUnitTest.java
index 9ff7339..9c42a1f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IncrementalBackupDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IncrementalBackupDUnitTest.java
@@ -50,12 +50,11 @@ import com.gemstone.gemfire.internal.JarDeployer;
 import com.gemstone.gemfire.internal.cache.persistence.BackupManager;
 import com.gemstone.gemfire.internal.util.IOUtils;
 import com.gemstone.gemfire.internal.util.TransformUtils;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests for the incremental backup feature.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
index 76e4039..03d9edd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptClientServerDUnitTest.java
@@ -32,11 +32,10 @@ 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.UpdateOperation.UpdateMessage;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests interrupting gemfire threads and seeing what happens

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
index 7f9b209..416dff9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/InterruptsDUnitTest.java
@@ -28,11 +28,10 @@ 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.cache.UpdateOperation.UpdateMessage;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests interrupting gemfire threads during a put operation to see what happens

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IteratorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IteratorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IteratorDUnitTest.java
index 28dd590..41fc8d6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IteratorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/IteratorDUnitTest.java
@@ -22,13 +22,12 @@ package com.gemstone.gemfire.internal.cache;
 import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.util.Iterator;
 
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
-
 /**
  * Test that keys iterator do not returned keys with removed token as its values
  * @author sbawaska

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapClearGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapClearGIIDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapClearGIIDUnitTest.java
index ab0d1de..3910c3c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapClearGIIDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapClearGIIDUnitTest.java
@@ -21,20 +21,22 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.RegionEvent;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
-import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
-import dunit.*;
-
-import java.util.Properties;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author ashahid

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapInterface2JUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapInterface2JUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapInterface2JUnitTest.java
index 3545685..91fea15 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapInterface2JUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/MapInterface2JUnitTest.java
@@ -41,10 +41,9 @@ import com.gemstone.gemfire.cache.query.CacheUtils;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.internal.util.StopWatch;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * @author asif
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/NetSearchMessagingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/NetSearchMessagingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/NetSearchMessagingDUnitTest.java
index 4c60566..b1375a8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/NetSearchMessagingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/NetSearchMessagingDUnitTest.java
@@ -34,12 +34,11 @@ 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.cache.SearchLoadAndWriteProcessor.NetSearchRequestMessage;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionDUnitTest.java
index 060aea7..4482533 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionDUnitTest.java
@@ -25,10 +25,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-
-import dunit.DistributedTestCase;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Performs eviction dunit tests for off-heap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionStatsDUnitTest.java
index 3a8eef3..a2d0555 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OffHeapEvictionStatsDUnitTest.java
@@ -21,8 +21,7 @@ import java.util.Properties;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Performs eviction stat dunit tests for off-heap regions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
index 433af3d..9daf69f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/OplogJUnitTest.java
@@ -57,12 +57,11 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.cache.Oplog.OPLOG_TYPE;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import com.jayway.awaitility.Awaitility;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Testing Oplog API's
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/P2PDeltaPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/P2PDeltaPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/P2PDeltaPropagationDUnitTest.java
index ee0045b..508347d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/P2PDeltaPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/P2PDeltaPropagationDUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PRBadToDataDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PRBadToDataDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PRBadToDataDUnitTest.java
index a6ac9a3..f1e7988 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PRBadToDataDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PRBadToDataDUnitTest.java
@@ -24,11 +24,10 @@ import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests a toData that always throws an IOException.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionListenerDUnitTest.java
index bb5fd46..3eb3b7d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionListenerDUnitTest.java
@@ -32,11 +32,10 @@ import com.gemstone.gemfire.cache.control.RebalanceOperation;
 import com.gemstone.gemfire.cache.partition.PartitionListenerAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedMember;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 @SuppressWarnings({"serial", "rawtypes", "deprecation", "unchecked"})
 public class PartitionListenerDUnitTest extends CacheTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAPIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAPIDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAPIDUnitTest.java
index e1ad4b4..bb34cc1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAPIDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAPIDUnitTest.java
@@ -46,10 +46,9 @@ import com.gemstone.gemfire.cache30.TestCacheLoader;
 import com.gemstone.gemfire.distributed.internal.ReplyException;
 
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PartitionedRegionAPIDUnitTest extends
 		PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAsSubRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAsSubRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAsSubRegionDUnitTest.java
index 2f99b95..94eb775 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAsSubRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionAsSubRegionDUnitTest.java
@@ -24,9 +24,8 @@ import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This dunit test verifies that PartitionedRegion destroyRegion, localDestroyRegion and close call works

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
index 3d6895f..d5e7f9c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketCreationDistributionDUnitTest.java
@@ -16,22 +16,30 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache.Scope;
-import java.util.*;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Iterator;
+import java.util.List;
+import java.util.NoSuchElementException;
+import java.util.Set;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.MirrorType;
 import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.MirrorType;
 import com.gemstone.gemfire.cache.PartitionAttributes;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.PartitionedRegionStorageException;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache30.*;
-import com.gemstone.gemfire.cache.PartitionedRegionStorageException;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore.BucketVisitor;
-
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheCloseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheCloseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheCloseDUnitTest.java
index 8c31086..d458947 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheCloseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheCloseDUnitTest.java
@@ -27,11 +27,10 @@ import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to verify the meta-data cleanUp done at the time of cache close Op. This

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheXMLExampleDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheXMLExampleDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheXMLExampleDUnitTest.java
index 0a348b2..ee55669 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheXMLExampleDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCacheXMLExampleDUnitTest.java
@@ -16,13 +16,12 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import dunit.Host;
-import dunit.VM;
-
 import java.util.Properties;
 
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.util.test.TestUtil;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCreationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCreationDUnitTest.java
index 637a02c..367782a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCreationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionCreationDUnitTest.java
@@ -34,12 +34,11 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings("serial")
 public class PartitionedRegionCreationDUnitTest extends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDUnitTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDUnitTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDUnitTestCase.java
index 74f201d..d81e686 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDUnitTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDUnitTestCase.java
@@ -30,11 +30,10 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LogWriterImpl;
 import com.gemstone.gemfire.internal.logging.PureLogWriter;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-
 /**
  * This class is extended by some PartitionedRegion related DUnit test cases 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDelayedRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDelayedRecoveryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDelayedRecoveryDUnitTest.java
index 9e47c1d..1d89967 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDelayedRecoveryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDelayedRecoveryDUnitTest.java
@@ -26,11 +26,10 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDestroyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDestroyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDestroyDUnitTest.java
index 2d5e85a..4733fff 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDestroyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDestroyDUnitTest.java
@@ -28,12 +28,11 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.RegionDestroyedException;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test aims to test the destroyRegion functionality.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEntryCountDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEntryCountDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEntryCountDUnitTest.java
index f03d83b..dbaa433 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEntryCountDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEntryCountDUnitTest.java
@@ -23,11 +23,10 @@ import com.gemstone.gemfire.cache.EvictionAttributes;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * This class tests total entry count of partitioned regions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEvictionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEvictionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEvictionDUnitTest.java
index fe4109f..5fe0b45 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEvictionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionEvictionDUnitTest.java
@@ -46,12 +46,11 @@ import com.gemstone.gemfire.internal.cache.control.HeapMemoryMonitor;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
 import com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class PartitionedRegionEvictionDUnitTest extends CacheTestCase {
   public PartitionedRegionEvictionDUnitTest(final String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHADUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHADUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHADUnitTest.java
index 15bbfc7..9ce79e1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHADUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHADUnitTest.java
@@ -36,13 +36,12 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserver;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * @author tapshank, Created on Jan 17, 2006

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHAFailureAndRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHAFailureAndRecoveryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHAFailureAndRecoveryDUnitTest.java
index ae36161..726423d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHAFailureAndRecoveryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionHAFailureAndRecoveryDUnitTest.java
@@ -16,20 +16,28 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import java.util.*;
-
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.TimeUnit;
+
 import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CacheListener;
-import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
 import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache30.*;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.cache30.CertifiableTestCacheListener;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.NanoTimer;
-
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * This is a Dunit test for PartitionedRegion cleanup on Node Failure through

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionInvalidateDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionInvalidateDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionInvalidateDUnitTest.java
index 65f13de..4061a13 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionInvalidateDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionInvalidateDUnitTest.java
@@ -28,10 +28,9 @@ import com.gemstone.gemfire.cache.RegionEvent;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This tests invalidateRegion functionality on partitioned regions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryDUnitTest.java
index 8bae5c2..4bbdbe4 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryDUnitTest.java
@@ -33,10 +33,9 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.util.ObjectSizer;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class is to test localMaxMemory property of partition region while

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryOffHeapDUnitTest.java
index 49e6672..a9b7619 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionLocalMaxMemoryOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.EvictionAttributes;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests PartitionedRegion localMaxMemory with Off-Heap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionMultipleDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionMultipleDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionMultipleDUnitTest.java
index f11e4a1..6ace0a5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionMultipleDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionMultipleDUnitTest.java
@@ -19,8 +19,11 @@ package com.gemstone.gemfire.internal.cache;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache30.*;
-import dunit.*;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test is dunit test for the multiple Partition Regions in 4 VMs.
@@ -28,7 +31,6 @@ import dunit.*;
  * @author gthombar, modified by Tushar (for bug#35713)
  *  
  */
-
 public class PartitionedRegionMultipleDUnitTest extends
     PartitionedRegionDUnitTestCase
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionOffHeapEvictionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionOffHeapEvictionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionOffHeapEvictionDUnitTest.java
index 672b8a7..042e1f7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionOffHeapEvictionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionOffHeapEvictionDUnitTest.java
@@ -23,8 +23,7 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.control.OffHeapMemoryMonitor;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class PartitionedRegionOffHeapEvictionDUnitTest extends
     PartitionedRegionEvictionDUnitTest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionPRIDDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionPRIDDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionPRIDDUnitTest.java
index 428a5d1..496026d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionPRIDDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionPRIDDUnitTest.java
@@ -19,15 +19,14 @@ package com.gemstone.gemfire.internal.cache;
 import java.util.ArrayList;
 import java.util.Iterator;
 import java.util.List;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
 import java.util.*;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryDUnitTest.java
index e3c9c6d..b4af7d1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryDUnitTest.java
@@ -58,11 +58,10 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.partitioned.QueryMessage;
 import com.gemstone.gemfire.pdx.JSONFormatter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionRedundancyZoneDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionRedundancyZoneDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionRedundancyZoneDUnitTest.java
index 4c18910..39fcc76 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionRedundancyZoneDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionRedundancyZoneDUnitTest.java
@@ -28,11 +28,10 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 public class PartitionedRegionRedundancyZoneDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSerializableObjectJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSerializableObjectJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSerializableObjectJUnitTest.java
index d7f982a..6244cea 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSerializableObjectJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSerializableObjectJUnitTest.java
@@ -35,9 +35,9 @@ import static org.junit.Assert.*;
 
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
 import junit.framework.TestCase;
 
 @Category(IntegrationTest.class)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopDUnitTest.java
index b538d81..e5e238e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopDUnitTest.java
@@ -65,11 +65,10 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PartitionedRegionSingleHopDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopWithServerGroupDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopWithServerGroupDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopWithServerGroupDUnitTest.java
index ed506dc..ee256a9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopWithServerGroupDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSingleHopWithServerGroupDUnitTest.java
@@ -41,11 +41,10 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSizeDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSizeDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSizeDUnitTest.java
index 0835877..c4c9796 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSizeDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionSizeDUnitTest.java
@@ -31,13 +31,12 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * This test verifies the size API for 100 thousand put operations (done

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatsDUnitTest.java
index 8583bc8..fe2a104 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatsDUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.cache.control.RebalanceOperation;
 import com.gemstone.gemfire.cache.control.RebalanceResults;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author tapshank, Created on Jan 19, 2006

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
index 0d57b03..7840a2b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionTestUtilsDUnitTest.java
@@ -36,9 +36,8 @@ import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedMember;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Confirm that the utils used for testing work as advertised

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionWithSameNameDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionWithSameNameDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionWithSameNameDUnitTest.java
index 0294560..55d9a82 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionWithSameNameDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PartitionedRegionWithSameNameDUnitTest.java
@@ -22,20 +22,24 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache.Scope;
-import java.util.*;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.MirrorType;
 import com.gemstone.gemfire.cache.PartitionAttributes;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache30.*;
 import com.gemstone.gemfire.cache.RegionExistsException;
-import dunit.*;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author gthombar This test is to verify creation of partition region and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
index 4d51997..b192a43 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllDAckDUnitTest.java
@@ -19,29 +19,29 @@
  *
  * Created on September 15, 2005, 5:51 PM
  */
-
 package com.gemstone.gemfire.internal.cache;
+
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.CacheFactory;
-//import com.gemstone.gemfire.cache.CacheListener;
 import com.gemstone.gemfire.cache.CacheTransactionManager;
 import com.gemstone.gemfire.cache.CacheWriter;
 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.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
-
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Properties;
 /**
  *
  * @author vjadhav

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
index 3293066..0aa77f0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/PutAllGlobalDUnitTest.java
@@ -19,8 +19,16 @@
  *
  * Created on September 16, 2005, 3:02 PM
  */
-
 package com.gemstone.gemfire.internal.cache;
+
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
@@ -36,16 +44,11 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor;
-
-import dunit.*;
-
-import java.io.IOException;
-import java.net.InetAddress;
-import java.net.ServerSocket;
-import java.net.Socket;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Properties;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
index 949f1ac..8a58653 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoteTransactionDUnitTest.java
@@ -96,13 +96,12 @@ import com.gemstone.gemfire.internal.cache.execute.data.Customer;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /**
  * @author sbawaska

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
index dc0d5bd..7ccdd6a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveAllDAckDUnitTest.java
@@ -19,8 +19,11 @@
  *
  * Created on September 15, 2005, 5:51 PM
  */
-
 package com.gemstone.gemfire.internal.cache;
+
+import java.util.ArrayList;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
@@ -33,11 +36,10 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
-
-import java.util.ArrayList;
-import java.util.Properties;
 /**
  * Adapted from RemoveAllDAckDUnitTest
  * @author darrel

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
index 4008e67..b32f4f5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveDAckDUnitTest.java
@@ -19,8 +19,10 @@
  *
  * Created on September 15, 2005, 12:41 PM
  */
-
 package com.gemstone.gemfire.internal.cache;
+
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheException;
@@ -31,10 +33,10 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
-
-import java.util.Properties;
 /**
  *
  * @author vjadhav

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
index 6767388..008d09b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/RemoveGlobalDUnitTest.java
@@ -21,14 +21,27 @@
  */
 
 package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
+
+import java.util.Properties;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheWriter;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TimeoutException;
+import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
-
-import java.util.Properties;
 /**
  *
  * @author vjadhav

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
index 839a569..10bdab3 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SimpleDiskRegionJUnitTest.java
@@ -34,10 +34,9 @@ import org.junit.experimental.categories.Category;
 import static org.junit.Assert.*;
 
 import com.gemstone.gemfire.StatisticsFactory;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Testing methods for SimpleDiskRegion.java api's
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
index 7467993..a6023c7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SingleHopStatsDUnitTest.java
@@ -41,10 +41,9 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class SingleHopStatsDUnitTest extends CacheTestCase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
index c4255f0..19170f2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SizingFlagDUnitTest.java
@@ -46,11 +46,10 @@ import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * A test of the when we will use the object sizer to determine 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
index 7b369c7..e3858fb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/SystemFailureDUnitTest.java
@@ -24,10 +24,9 @@ import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.util.*;
 import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-
-import dunit.Host;
-import dunit.RMIException;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.Serializable;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
index d622d4b..663ef61 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TXReservationMgrJUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.CommitConflictException;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 @Category(IntegrationTest.class)
 public class TXReservationMgrJUnitTest {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
index 0db1052..06a8f09 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/TransactionsWithDeltaDUnitTest.java
@@ -43,10 +43,9 @@ import com.gemstone.gemfire.internal.cache.execute.CustomerIDPartitionResolver;
 import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
index 88516fe..1c25dcc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/control/RebalanceOperationDUnitTest.java
@@ -73,12 +73,11 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
 import com.gemstone.gemfire.internal.cache.partitioned.BucketCountLoadProbe;
 import com.gemstone.gemfire.internal.cache.partitioned.LoadProbe;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
index 76adfa7..10a7df7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowAsyncRollingOpLogJUnitTest.java
@@ -29,11 +29,10 @@ import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
 import com.gemstone.gemfire.internal.cache.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * 1) Performance of Get Operation for Entry faulting in from current Op Log 2)
  * Performance of Get operation for Entry faulting in from previous Op Log 3)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
index 5a2d1cf..df09e2c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/DiskRegionOverflowSyncRollingOpLogJUnitTest.java
@@ -30,11 +30,10 @@ import static org.junit.Assert.*;
 import com.gemstone.gemfire.*;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * 1) Performance of Get Operation for Entry faulting in from current Op Log 2)
  * Performance of Get operation for Entry faulting in from previous Op Log 3)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
index 1d65c41..719a9b2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/diskPerf/MultiThreadedOplogPerJUnitPerformanceTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.DiskStoreFactoryImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 @Category(IntegrationTest.class)
 public class MultiThreadedOplogPerJUnitPerformanceTest
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
index 8dd3fbb..63fdf64 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/Bug51193DUnitTest.java
@@ -41,10 +41,9 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.tier.ClientHandShake;
 import com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings("serial")
 public class Bug51193DUnitTest extends DistributedTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
index 8950010..1e78da2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ClientServerFunctionExecutionDUnitTest.java
@@ -33,9 +33,8 @@ import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 import java.io.Serializable;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
index 0d759ad..81b9984 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/ColocationFailoverDUnitTest.java
@@ -39,11 +39,10 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ColocationFailoverDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
index 7b837a7..286a5bd 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/DistributedRegionFunctionExecutionDUnitTest.java
@@ -52,11 +52,10 @@ import com.gemstone.gemfire.internal.cache.functions.DistribuedRegionFunctionFun
 import com.gemstone.gemfire.internal.cache.functions.DistributedRegionFunction;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DistributedRegionFunctionExecutionDUnitTest extends
     DistributedTestCase {



[17/52] [abbrv] incubator-geode git commit: GEODE-833: Changing gemfire-junit dependency to testCompile

Posted by ds...@apache.org.
GEODE-833: Changing gemfire-junit dependency to testCompile

It was provided, but that means it's part of the compilation classpath
for the src directory, which doesn't make sense.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/f03ae074
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/f03ae074
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/f03ae074

Branch: refs/heads/feature/GEODE-831
Commit: f03ae074a152fde3c79239afd6bd2891734ce927
Parents: 3bdaff6
Author: Dan Smith <up...@apache.org>
Authored: Fri Jan 22 11:47:32 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Mon Jan 25 11:37:47 2016 -0800

----------------------------------------------------------------------
 gemfire-core/build.gradle | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f03ae074/gemfire-core/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-core/build.gradle b/gemfire-core/build.gradle
index 925a2b6..7194350 100755
--- a/gemfire-core/build.gradle
+++ b/gemfire-core/build.gradle
@@ -86,7 +86,7 @@ dependencies {
   
   jcaCompile sourceSets.main.output
 
-  provided project(path: ':gemfire-junit', configuration: 'testOutput')
+  testCompile project(path: ':gemfire-junit', configuration: 'testOutput')
 
   // Test Dependencies
   // External


[49/52] [abbrv] incubator-geode git commit: added category

Posted by ds...@apache.org.
added category


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/09643957
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/09643957
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/09643957

Branch: refs/heads/feature/GEODE-831
Commit: 09643957aac5a7bc9d882eb6f48ac2aa36be2038
Parents: 3ca7b3e
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Jan 28 11:45:16 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Jan 28 11:45:16 2016 -0800

----------------------------------------------------------------------
 .../gemstone/gemfire/internal/offheap/FreeListManagerTest.java    | 3 +++
 1 file changed, 3 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/09643957/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
index 73b0e37..3b519a0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
@@ -13,9 +13,12 @@ import org.junit.Before;
 import org.junit.BeforeClass;
 import org.junit.Ignore;
 import org.junit.Test;
+import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.OutOfOffHeapMemoryException;
+import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
+@Category(UnitTest.class)
 public class FreeListManagerTest {
   static {
     ClassLoader.getSystemClassLoader().setDefaultAssertionStatus(true);


[46/52] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into develop

Posted by ds...@apache.org.
Merge remote-tracking branch 'origin/develop' into develop


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/c194f766
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/c194f766
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/c194f766

Branch: refs/heads/feature/GEODE-831
Commit: c194f76653cbeaa40f2efb42ace5511a0556d222
Parents: 46ae4ef 6df4b8f
Author: Dan Smith <up...@apache.org>
Authored: Thu Jan 28 10:12:27 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Thu Jan 28 10:12:27 2016 -0800

----------------------------------------------------------------------
 gemfire-pulse/build.gradle | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------



[13/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

* Move classes from dunit to com.gemstone.gemfire.test.dunit
* Reoranize imports on classes in com.gemstone.gemfire.test.dunit


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/d89038db
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/d89038db
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/d89038db

Branch: refs/heads/feature/GEODE-831
Commit: d89038db8c94f480ab099e69bc4d3ce036d64463
Parents: 861b6ee
Author: Kirk Lund <kl...@pivotal.io>
Authored: Mon Jan 25 10:43:01 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Jan 25 10:43:01 2016 -0800

----------------------------------------------------------------------
 .../com/gemstone/gemfire/TXExpiryJUnitTest.java |    5 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |    7 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |    7 +-
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |    9 +-
 .../ClientServerRegisterInterestsDUnitTest.java |   13 +-
 .../internal/AutoConnectionSourceDUnitTest.java |   11 +-
 .../CacheServerSSLConnectionDUnitTest.java      |    7 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |    9 +-
 .../cache/client/internal/LocatorTestBase.java  |   11 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |    7 +-
 .../pooling/ConnectionManagerJUnitTest.java     |    5 +-
 .../management/MemoryThresholdsDUnitTest.java   |   13 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |   13 +-
 .../management/ResourceManagerDUnitTest.java    |    9 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |    3 +-
 .../PartitionRegionHelperDUnitTest.java         |   11 +-
 .../gemfire/cache/query/QueryTestUtils.java     |    5 +-
 .../query/cq/dunit/CqQueryTestListener.java     |    5 +-
 .../query/dunit/CompactRangeIndexDUnitTest.java |   11 +-
 .../cache/query/dunit/CqTimeTestListener.java   |    5 +-
 .../cache/query/dunit/GroupByDUnitImpl.java     |    7 +-
 .../dunit/GroupByPartitionedQueryDUnitTest.java |    7 +-
 .../query/dunit/GroupByQueryDUnitTest.java      |    7 +-
 .../cache/query/dunit/HashIndexDUnitTest.java   |    9 +-
 .../cache/query/dunit/HelperTestCase.java       |    9 +-
 .../dunit/NonDistinctOrderByDUnitImpl.java      |    7 +-
 .../NonDistinctOrderByPartitionedDUnitTest.java |    7 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    |   13 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   11 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |   13 +-
 .../QueryParamsAuthorizationDUnitTest.java      |    7 +-
 .../QueryUsingFunctionContextDUnitTest.java     |    7 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |    7 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   34 +-
 ...esourceManagerWithQueryMonitorDUnitTest.java |   11 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |    7 +-
 .../IndexCreationDeadLockJUnitTest.java         |    3 +-
 .../IndexMaintenanceAsynchJUnitTest.java        |    5 +-
 .../functional/LikePredicateJUnitTest.java      |    3 +-
 .../internal/ExecutionContextJUnitTest.java     |    3 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |    5 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |    9 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |    9 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |    9 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |    9 +-
 .../index/CopyOnReadIndexDUnitTest.java         |   11 +-
 .../index/IndexCreationInternalsJUnitTest.java  |    3 +-
 .../index/IndexMaintainceJUnitTest.java         |    3 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |    9 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |    9 +-
 .../index/MultiIndexCreationDUnitTest.java      |   11 +-
 .../index/PutAllWithIndexPerfDUnitTest.java     |    5 +-
 .../PRBasicIndexCreationDUnitTest.java          |   11 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   11 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |    9 +-
 .../partitioned/PRBasicQueryDUnitTest.java      |    5 +-
 .../PRBasicRemoveIndexDUnitTest.java            |    5 +-
 .../PRColocatedEquiJoinDUnitTest.java           |    5 +-
 .../partitioned/PRInvalidQueryDUnitTest.java    |    5 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |    9 +-
 .../PRQueryCacheClosedJUnitTest.java            |    3 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |    3 +-
 .../query/partitioned/PRQueryDUnitTest.java     |    7 +-
 .../query/partitioned/PRQueryPerfDUnitTest.java |    5 +-
 .../PRQueryRegionCloseDUnitTest.java            |    9 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |    9 +-
 .../PRQueryRegionDestroyedJUnitTest.java        |    3 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    |   11 +-
 .../snapshot/ParallelSnapshotDUnitTest.java     |    7 +-
 .../snapshot/SnapshotByteArrayDUnitTest.java    |    5 +-
 .../cache/snapshot/SnapshotDUnitTest.java       |    5 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |    5 +-
 .../gemfire/cache30/Bug34387DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug34948DUnitTest.java      |   26 +-
 .../gemfire/cache30/Bug35214DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug38013DUnitTest.java      |   25 +-
 .../gemfire/cache30/Bug38741DUnitTest.java      |    7 +-
 .../gemfire/cache30/CacheCloseDUnitTest.java    |   16 +-
 .../gemfire/cache30/CacheLoaderTestCase.java    |   14 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   26 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |    7 +-
 .../cache30/CacheSerializableRunnable.java      |   10 +-
 .../cache30/CacheStatisticsDUnitTest.java       |   13 +-
 .../gemstone/gemfire/cache30/CacheTestCase.java |    7 +-
 .../gemfire/cache30/CacheXml30DUnitTest.java    |    3 +-
 .../gemfire/cache30/CacheXml41DUnitTest.java    |    4 +
 .../gemfire/cache30/CacheXml45DUnitTest.java    |    7 +-
 .../gemfire/cache30/CacheXml51DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml57DUnitTest.java    |    6 +
 .../gemfire/cache30/CacheXml60DUnitTest.java    |    4 +
 .../gemfire/cache30/CacheXml61DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml81DUnitTest.java    |    2 +-
 .../cache30/CachedAllEventsDUnitTest.java       |   16 +-
 .../gemfire/cache30/CallbackArgDUnitTest.java   |   29 +-
 .../cache30/CertifiableTestCacheListener.java   |    5 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   27 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   33 +-
 .../cache30/ClientMembershipDUnitTest.java      |   11 +-
 .../ClientRegisterInterestDUnitTest.java        |    7 +-
 .../cache30/ClientServerCCEDUnitTest.java       |    9 +-
 .../gemfire/cache30/ClientServerTestCase.java   |    3 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   11 +-
 .../gemfire/cache30/DiskRegionDUnitTest.java    |   45 +-
 .../gemfire/cache30/DiskRegionTestImpl.java     |   19 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   37 +-
 ...tedAckOverflowRegionCCEOffHeapDUnitTest.java |    3 +-
 ...tributedAckPersistentRegionCCEDUnitTest.java |   15 +-
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedAckRegionCCEDUnitTest.java       |   15 +-
 ...DistributedAckRegionCCEOffHeapDUnitTest.java |    3 +-
 ...istributedAckRegionCompressionDUnitTest.java |    3 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   34 +-
 .../DistributedAckRegionOffHeapDUnitTest.java   |    3 +-
 .../DistributedMulticastRegionDUnitTest.java    |   11 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |   11 +-
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedNoAckRegionDUnitTest.java        |   17 +-
 .../DistributedNoAckRegionOffHeapDUnitTest.java |    3 +-
 .../gemfire/cache30/DynamicRegionDUnitTest.java |   21 +-
 .../gemfire/cache30/GlobalLockingDUnitTest.java |   15 +-
 .../cache30/GlobalRegionCCEDUnitTest.java       |    7 +-
 .../GlobalRegionCCEOffHeapDUnitTest.java        |    3 +-
 .../gemfire/cache30/GlobalRegionDUnitTest.java  |   25 +-
 .../cache30/GlobalRegionOffHeapDUnitTest.java   |    3 +-
 .../cache30/LRUEvictionControllerDUnitTest.java |    5 +-
 .../gemfire/cache30/LocalRegionDUnitTest.java   |   17 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  |   17 +-
 .../OffHeapLRUEvictionControllerDUnitTest.java  |    3 +-
 .../PRBucketSynchronizationDUnitTest.java       |    7 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   22 +-
 ...tionedRegionMembershipListenerDUnitTest.java |    3 +-
 .../PartitionedRegionOffHeapDUnitTest.java      |    3 +-
 .../cache30/PreloadedRegionTestCase.java        |   14 +-
 .../gemfire/cache30/ProxyDUnitTest.java         |   34 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |   23 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   28 +-
 .../gemfire/cache30/PutAllMultiVmDUnitTest.java |   25 +-
 .../gemfire/cache30/QueueMsgDUnitTest.java      |   28 +-
 .../cache30/RRSynchronizationDUnitTest.java     |    7 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     |   13 +-
 .../cache30/RegionExpirationDUnitTest.java      |   14 +-
 .../RegionMembershipListenerDUnitTest.java      |   28 +-
 .../RegionReliabilityListenerDUnitTest.java     |   26 +-
 .../cache30/RegionReliabilityTestCase.java      |   64 +-
 .../gemfire/cache30/RegionTestCase.java         |    9 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |   22 +-
 .../gemfire/cache30/RequiredRolesDUnitTest.java |   28 +-
 .../cache30/RolePerformanceDUnitTest.java       |   15 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |   22 +-
 .../gemfire/cache30/SlowRecDUnitTest.java       |   35 +-
 .../gemfire/cache30/TXDistributedDUnitTest.java |   11 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |   41 +-
 .../cache30/TXRestrictionsDUnitTest.java        |   14 +-
 .../gemfire/cache30/TestCacheCallback.java      |    5 +-
 .../distributed/DistributedMemberDUnitTest.java |   26 +-
 .../distributed/DistributedSystemDUnitTest.java |    7 +-
 .../distributed/HostedLocatorsDUnitTest.java    |    9 +-
 .../gemfire/distributed/LocatorDUnitTest.java   |   13 +-
 .../gemfire/distributed/LocatorJUnitTest.java   |    5 +-
 .../gemfire/distributed/RoleDUnitTest.java      |   16 +-
 .../distributed/SystemAdminDUnitTest.java       |    5 +-
 .../distributed/internal/Bug40751DUnitTest.java |    9 +-
 .../ConsoleDistributionManagerDUnitTest.java    |    9 +-
 .../internal/DistributionAdvisorDUnitTest.java  |   13 +-
 .../internal/DistributionManagerDUnitTest.java  |    9 +-
 .../internal/ProductUseLogDUnitTest.java        |   11 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   11 +-
 .../internal/locks/CollaborationJUnitTest.java  |    5 +-
 .../membership/gms/MembershipManagerHelper.java |    5 +-
 .../StreamingOperationManyDUnitTest.java        |   20 +-
 .../StreamingOperationOneDUnitTest.java         |   23 +-
 .../TcpServerBackwardCompatDUnitTest.java       |    7 +-
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java |    5 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |    9 +-
 .../disttx/DistTXPersistentDebugDUnitTest.java  |    2 +-
 .../disttx/DistributedTransactionDUnitTest.java |    7 +-
 .../ClassNotFoundExceptionDUnitTest.java        |    9 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |    3 +-
 .../gemfire/internal/JarDeployerDUnitTest.java  |    7 +-
 .../internal/PdxDeleteFieldDUnitTest.java       |    7 +-
 .../gemfire/internal/PdxRenameDUnitTest.java    |    7 +-
 .../gemfire/internal/SocketCloserJUnitTest.java |    5 +-
 .../gemfire/internal/cache/BackupDUnitTest.java |   13 +-
 .../internal/cache/Bug33359DUnitTest.java       |    8 +-
 .../internal/cache/Bug33726DUnitTest.java       |    8 +-
 .../internal/cache/Bug37241DUnitTest.java       |    8 +-
 .../internal/cache/Bug37377DUnitTest.java       |   11 +-
 .../internal/cache/Bug39079DUnitTest.java       |    7 +-
 .../internal/cache/Bug40299DUnitTest.java       |   11 +-
 .../internal/cache/Bug40632DUnitTest.java       |    9 +-
 .../internal/cache/Bug41091DUnitTest.java       |    7 +-
 .../internal/cache/Bug41733DUnitTest.java       |   15 +-
 .../internal/cache/Bug41957DUnitTest.java       |   29 +-
 .../internal/cache/Bug42055DUnitTest.java       |    9 +-
 .../internal/cache/Bug45164DUnitTest.java       |    7 +-
 .../internal/cache/Bug45934DUnitTest.java       |    7 +-
 .../internal/cache/Bug47667DUnitTest.java       |    7 +-
 .../internal/cache/CacheAdvisorDUnitTest.java   |   30 +-
 .../internal/cache/ClearDAckDUnitTest.java      |   11 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |    6 +-
 .../cache/ClientServerGetAllDUnitTest.java      |   33 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |   11 +-
 .../ClientServerTransactionCCEDUnitTest.java    |    5 +-
 .../cache/ClientServerTransactionDUnitTest.java |   11 +-
 .../ConcurrentDestroySubRegionDUnitTest.java    |    9 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |   11 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |    3 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |    3 +-
 .../cache/ConnectDisconnectDUnitTest.java       |   13 +-
 .../internal/cache/DeltaFaultInDUnitTest.java   |    9 +-
 .../cache/DeltaPropagationDUnitTest.java        |    9 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |    7 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |    9 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   15 +-
 .../cache/DiskRegionClearJUnitTest.java         |    3 +-
 .../internal/cache/DiskRegionJUnitTest.java     |    5 +-
 ...DistrbutedRegionProfileOffHeapDUnitTest.java |    5 +-
 .../cache/DistributedCacheTestCase.java         |   23 +-
 .../internal/cache/EventTrackerDUnitTest.java   |    7 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |    7 +-
 .../internal/cache/EvictionTestBase.java        |   11 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |    9 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |   13 +-
 .../internal/cache/GIIFlowControlDUnitTest.java |    9 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |   25 +-
 .../internal/cache/HABug36773DUnitTest.java     |    7 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |    7 +-
 .../cache/IncrementalBackupDUnitTest.java       |   11 +-
 .../cache/InterruptClientServerDUnitTest.java   |    9 +-
 .../internal/cache/InterruptsDUnitTest.java     |    9 +-
 .../internal/cache/IteratorDUnitTest.java       |    7 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   14 +-
 .../internal/cache/MapInterface2JUnitTest.java  |    3 +-
 .../cache/NetSearchMessagingDUnitTest.java      |   11 +-
 .../cache/OffHeapEvictionDUnitTest.java         |    7 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |    3 +-
 .../gemfire/internal/cache/OplogJUnitTest.java  |    5 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |    7 +-
 .../internal/cache/PRBadToDataDUnitTest.java    |    9 +-
 .../cache/PartitionListenerDUnitTest.java       |    9 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |    7 +-
 .../PartitionedRegionAsSubRegionDUnitTest.java  |    5 +-
 ...gionBucketCreationDistributionDUnitTest.java |   22 +-
 .../PartitionedRegionCacheCloseDUnitTest.java   |    9 +-
 ...rtitionedRegionCacheXMLExampleDUnitTest.java |    5 +-
 .../PartitionedRegionCreationDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionDUnitTestCase.java   |    5 +-
 ...rtitionedRegionDelayedRecoveryDUnitTest.java |    9 +-
 .../PartitionedRegionDestroyDUnitTest.java      |   11 +-
 .../PartitionedRegionEntryCountDUnitTest.java   |    9 +-
 .../PartitionedRegionEvictionDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionHADUnitTest.java     |   13 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |   22 +-
 .../PartitionedRegionInvalidateDUnitTest.java   |    7 +-
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |    7 +-
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java |    3 +-
 .../PartitionedRegionMultipleDUnitTest.java     |    8 +-
 ...rtitionedRegionOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/PartitionedRegionPRIDDUnitTest.java   |    9 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |    9 +-
 ...artitionedRegionRedundancyZoneDUnitTest.java |    9 +-
 ...tionedRegionSerializableObjectJUnitTest.java |    2 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |    9 +-
 ...RegionSingleHopWithServerGroupDUnitTest.java |    9 +-
 .../cache/PartitionedRegionSizeDUnitTest.java   |   13 +-
 .../cache/PartitionedRegionStatsDUnitTest.java  |    7 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |    5 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |   14 +-
 .../internal/cache/PutAllDAckDUnitTest.java     |   16 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   25 +-
 .../cache/RemoteTransactionDUnitTest.java       |   13 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   12 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   10 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   23 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |    3 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |    7 +-
 .../internal/cache/SizingFlagDUnitTest.java     |    9 +-
 .../internal/cache/SystemFailureDUnitTest.java  |    7 +-
 .../cache/TXReservationMgrJUnitTest.java        |    3 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |    7 +-
 .../control/RebalanceOperationDUnitTest.java    |   11 +-
 ...egionOverflowAsyncRollingOpLogJUnitTest.java |    5 +-
 ...RegionOverflowSyncRollingOpLogJUnitTest.java |    5 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |    3 +-
 .../cache/execute/Bug51193DUnitTest.java        |    7 +-
 .../ClientServerFunctionExecutionDUnitTest.java |    5 +-
 .../execute/ColocationFailoverDUnitTest.java    |    9 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |    9 +-
 .../FunctionExecution_ExceptionDUnitTest.java   |    9 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |   11 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |   11 +-
 .../execute/LocalDataSetIndexingDUnitTest.java  |    5 +-
 .../LocalFunctionExecutionDUnitTest.java        |    9 +-
 .../MemberFunctionExecutionDUnitTest.java       |    9 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |    7 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |    9 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |    7 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |   11 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |    5 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |    5 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |    5 +-
 .../cache/execute/PRClientServerTestBase.java   |   11 +-
 .../cache/execute/PRColocationDUnitTest.java    |   12 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |    7 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |   13 +-
 .../PRFunctionExecutionTimeOutDUnitTest.java    |    7 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |    7 +-
 .../execute/PRPerformanceTestDUnitTest.java     |    7 +-
 .../cache/execute/PRTransactionDUnitTest.java   |    3 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |    3 +-
 .../functions/DistributedRegionFunction.java    |    5 +-
 .../internal/cache/functions/TestFunction.java  |    5 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |    3 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |    5 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |    5 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |    7 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |    7 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |    7 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |    7 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |    7 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |    7 +-
 .../cache/ha/HAConflationDUnitTest.java         |    7 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |    7 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |    7 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |    9 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   11 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |    9 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |    3 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |    7 +-
 .../internal/cache/ha/HARegionDUnitTest.java    |    7 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |    7 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |    3 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |    6 +-
 .../ha/OperationsPropagationDUnitTest.java      |    7 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |    7 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |    7 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   29 +-
 .../cache/partitioned/Bug39356DUnitTest.java    |    9 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |    9 +-
 .../partitioned/ElidedPutAllDUnitTest.java      |    7 +-
 .../partitioned/PartitionResolverDUnitTest.java |    7 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |    4 +-
 ...rtitionedRegionMetaDataCleanupDUnitTest.java |    9 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |    9 +-
 ...tentColocatedPartitionedRegionDUnitTest.java |   11 +-
 .../PersistentPartitionedRegionDUnitTest.java   |   15 +-
 .../PersistentPartitionedRegionTestBase.java    |    9 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |    9 +-
 .../cache/partitioned/ShutdownAllDUnitTest.java |   15 +-
 ...treamingPartitionOperationManyDUnitTest.java |   29 +-
 ...StreamingPartitionOperationOneDUnitTest.java |   34 +-
 .../fixed/FixedPartitioningDUnitTest.java       |    7 +-
 .../fixed/FixedPartitioningTestBase.java        |    9 +-
 ...ngWithColocationAndPersistenceDUnitTest.java |    5 +-
 .../PersistentRVVRecoveryDUnitTest.java         |   11 +-
 .../PersistentRecoveryOrderDUnitTest.java       |   11 +-
 ...rsistentRecoveryOrderOldConfigDUnitTest.java |    7 +-
 .../PersistentReplicatedTestBase.java           |    7 +-
 .../internal/cache/tier/Bug40396DUnitTest.java  |    9 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |    7 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |    7 +-
 .../CacheServerMaxConnectionsJUnitTest.java     |    5 +-
 .../cache/tier/sockets/CacheServerTestUtil.java |    3 +-
 .../CacheServerTransactionsDUnitTest.java       |    7 +-
 .../tier/sockets/ClearPropagationDUnitTest.java |    7 +-
 .../tier/sockets/ClientConflationDUnitTest.java |    7 +-
 .../sockets/ClientHealthMonitorJUnitTest.java   |    5 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |    7 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   11 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |    7 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |    5 +-
 .../DataSerializerPropogationDUnitTest.java     |    7 +-
 .../DestroyEntryPropagationDUnitTest.java       |    7 +-
 .../sockets/DurableClientBug39997DUnitTest.java |    7 +-
 .../DurableClientQueueSizeDUnitTest.java        |    7 +-
 .../DurableClientReconnectAutoDUnitTest.java    |    5 +-
 .../DurableClientReconnectDUnitTest.java        |    7 +-
 .../sockets/DurableClientStatsDUnitTest.java    |    7 +-
 .../sockets/DurableRegistrationDUnitTest.java   |    7 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |    7 +-
 .../sockets/EventIDVerificationDUnitTest.java   |    7 +-
 .../EventIDVerificationInP2PDUnitTest.java      |    7 +-
 .../ForceInvalidateEvictionDUnitTest.java       |    7 +-
 ...ForceInvalidateOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |    7 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |    2 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |    5 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |    7 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |    7 +-
 .../InstantiatorPropagationDUnitTest.java       |    7 +-
 .../tier/sockets/InterestListDUnitTest.java     |    9 +-
 .../sockets/InterestListEndpointDUnitTest.java  |    9 +-
 .../sockets/InterestListFailoverDUnitTest.java  |    7 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |    6 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |    7 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |    7 +-
 .../sockets/NewRegionAttributesDUnitTest.java   |    7 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |    5 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |    7 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |    7 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |    7 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |    7 +-
 .../sockets/ReliableMessagingDUnitTest.java     |    7 +-
 .../sockets/UnregisterInterestDUnitTest.java    |    7 +-
 .../sockets/UpdatePropagationDUnitTest.java     |    7 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |    7 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |    7 +-
 .../versions/RegionVersionVectorJUnitTest.java  |    3 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |    7 +-
 .../AsyncEventQueueStatsDUnitTest.java          |    3 +-
 .../ConcurrentAsyncEventQueueDUnitTest.java     |    3 +-
 .../CompressionCacheConfigDUnitTest.java        |    7 +-
 .../CompressionCacheListenerDUnitTest.java      |    9 +-
 ...ompressionCacheListenerOffHeapDUnitTest.java |    3 +-
 .../CompressionRegionConfigDUnitTest.java       |   11 +-
 .../CompressionRegionFactoryDUnitTest.java      |    9 +-
 .../CompressionRegionOperationsDUnitTest.java   |    9 +-
 ...ressionRegionOperationsOffHeapDUnitTest.java |    3 +-
 .../compression/CompressionStatsDUnitTest.java  |    9 +-
 .../internal/jta/dunit/CommitThread.java        |   28 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   42 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |   44 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   11 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |   43 +-
 .../internal/jta/dunit/RollbackThread.java      |   28 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   26 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   51 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |   31 +-
 .../DistributedSystemLogFileJUnitTest.java      |    5 +-
 .../logging/LocatorLogFileJUnitTest.java        |    5 +-
 .../logging/MergeLogFilesJUnitTest.java         |    3 +-
 .../internal/offheap/OffHeapRegionBase.java     |    5 +-
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    |    5 +-
 .../process/LocalProcessLauncherDUnitTest.java  |    7 +-
 .../statistics/StatisticsDUnitTest.java         |    9 +-
 .../statistics/ValueMonitorJUnitTest.java       |    4 +-
 .../management/CacheManagementDUnitTest.java    |    8 +-
 .../management/ClientHealthStatsDUnitTest.java  |   13 +-
 .../management/CompositeTypeTestDUnitTest.java  |    5 +-
 .../management/DLockManagementDUnitTest.java    |    5 +-
 .../management/DiskManagementDUnitTest.java     |    9 +-
 .../management/DistributedSystemDUnitTest.java  |    9 +-
 .../management/LocatorManagementDUnitTest.java  |    7 +-
 .../gemstone/gemfire/management/MBeanUtil.java  |    5 +-
 .../gemfire/management/ManagementTestBase.java  |   13 +-
 .../MemberMBeanAttributesDUnitTest.java         |    5 +-
 .../management/OffHeapManagementDUnitTest.java  |    9 +-
 .../gemfire/management/QueryDataDUnitTest.java  |    8 +-
 .../management/RegionManagementDUnitTest.java   |    5 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |    7 +-
 .../stats/DistributedSystemStatsDUnitTest.java  |    5 +-
 .../internal/cli/CliUtilDUnitTest.java          |   11 +-
 .../cli/commands/CliCommandTestBase.java        |    7 +-
 .../cli/commands/ConfigCommandsDUnitTest.java   |   11 +-
 ...eateAlterDestroyRegionCommandsDUnitTest.java |   10 +-
 .../cli/commands/DeployCommandsDUnitTest.java   |    8 +-
 .../commands/DiskStoreCommandsDUnitTest.java    |   11 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |   10 +-
 .../commands/GemfireDataCommandsDUnitTest.java  |   11 +-
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |    8 +-
 .../cli/commands/IndexCommandsDUnitTest.java    |   10 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |    6 +-
 .../ListAndDescribeRegionDUnitTest.java         |    6 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |    6 +-
 .../cli/commands/MemberCommandsDUnitTest.java   |    6 +-
 .../MiscellaneousCommandsDUnitTest.java         |    9 +-
 ...laneousCommandsExportLogsPart1DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart2DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart4DUnitTest.java |    6 +-
 .../cli/commands/QueueCommandsDUnitTest.java    |    8 +-
 .../SharedConfigurationCommandsDUnitTest.java   |   11 +-
 .../cli/commands/ShowDeadlockDUnitTest.java     |    8 +-
 .../cli/commands/ShowMetricsDUnitTest.java      |    8 +-
 .../cli/commands/ShowStackTraceDUnitTest.java   |    6 +-
 .../cli/commands/UserCommandsDUnitTest.java     |    5 +-
 .../SharedConfigurationDUnitTest.java           |   11 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |   13 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |    4 +-
 .../internal/pulse/TestHeapDUnitTest.java       |    3 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |   10 +-
 .../ClientsWithVersioningRetryDUnitTest.java    |    9 +-
 .../pdx/DistributedSystemIdDUnitTest.java       |    9 +-
 .../pdx/JSONPdxClientServerDUnitTest.java       |    8 +-
 .../pdx/PDXAsyncEventQueueDUnitTest.java        |    7 +-
 .../gemfire/pdx/PdxClientServerDUnitTest.java   |    9 +-
 .../pdx/PdxDeserializationDUnitTest.java        |    9 +-
 .../gemfire/pdx/PdxSerializableDUnitTest.java   |    9 +-
 .../gemfire/pdx/PdxTypeExportDUnitTest.java     |    5 +-
 .../gemfire/pdx/VersionClassLoader.java         |   16 +-
 .../gemfire/redis/RedisDistDUnitTest.java       |   11 +-
 .../web/controllers/RestAPITestBase.java        |    7 +-
 .../security/ClientAuthenticationDUnitTest.java |    6 +-
 .../security/ClientAuthorizationDUnitTest.java  |    6 +-
 .../security/ClientAuthorizationTestBase.java   |    4 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |    3 +-
 .../DeltaClientAuthorizationDUnitTest.java      |    3 +-
 .../DeltaClientPostAuthorizationDUnitTest.java  |    5 +-
 .../security/P2PAuthenticationDUnitTest.java    |    7 +-
 .../gemfire/security/SecurityTestUtil.java      |    3 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |  215 +++
 .../gemstone/gemfire/test/dunit/DUnitEnv.java   |   79 +
 .../gemfire/test/dunit/DistributedTestCase.java | 1432 +++++++++++++++++
 .../com/gemstone/gemfire/test/dunit/Host.java   |  212 +++
 .../gemfire/test/dunit/RMIException.java        |  170 +++
 .../gemfire/test/dunit/RepeatableRunnable.java  |   29 +
 .../test/dunit/SerializableCallable.java        |   70 +
 .../test/dunit/SerializableRunnable.java        |   92 ++
 .../com/gemstone/gemfire/test/dunit/VM.java     | 1345 ++++++++++++++++
 .../test/dunit/standalone/DUnitLauncher.java    |    9 +-
 .../dunit/standalone/StandAloneDUnitEnv.java    |    3 +-
 .../test/dunit/tests/BasicDUnitTest.java        |   10 +-
 .../gemfire/test/dunit/tests/VMDUnitTest.java   |    9 +-
 .../src/test/java/dunit/AsyncInvocation.java    |  217 ---
 gemfire-core/src/test/java/dunit/DUnitEnv.java  |   80 -
 .../test/java/dunit/DistributedTestCase.java    | 1438 ------------------
 gemfire-core/src/test/java/dunit/Host.java      |  210 ---
 .../src/test/java/dunit/RMIException.java       |  170 ---
 .../src/test/java/dunit/RepeatableRunnable.java |   29 -
 .../test/java/dunit/SerializableCallable.java   |   70 -
 .../test/java/dunit/SerializableRunnable.java   |   92 --
 gemfire-core/src/test/java/dunit/VM.java        | 1347 ----------------
 .../LuceneFunctionReadPathDUnitTest.java        |    7 +-
 533 files changed, 6275 insertions(+), 6085 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/TXExpiryJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/TXExpiryJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/TXExpiryJUnitTest.java
index 3664ad5..674f0c9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/TXExpiryJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/TXExpiryJUnitTest.java
@@ -51,11 +51,10 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.TXManagerImpl;
 import com.gemstone.gemfire.internal.cache.TXStateProxy;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Tests transaction expiration functionality
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
index aeab59e..3502021 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/CacheRegionClearStatsDUnitTest.java
@@ -25,10 +25,9 @@ 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.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 /**
  * verifies the count of clear operation
  *  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
index 604e405..2606a8f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ClientServerTimeSyncDUnitTest.java
@@ -29,10 +29,9 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.internal.DSClock;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ClientServerTimeSyncDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
index 67a847c..677ab14 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/ConnectionPoolAndLoaderDUnitTest.java
@@ -27,11 +27,10 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * This tests cases where we have both 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/ClientServerRegisterInterestsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/ClientServerRegisterInterestsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/ClientServerRegisterInterestsDUnitTest.java
index 1d0d6ba..89c4e58 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/ClientServerRegisterInterestsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/ClientServerRegisterInterestsDUnitTest.java
@@ -33,19 +33,18 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * The ClientServerRegisterInterestsDUnitTest class is a test suite of test cases testing the interaction between a
  * client and a server in a Register Interests scenario.
  *
  * @author John Blum
- * @see dunit.DistributedTestCase
+ * @see com.gemstone.gemfire.test.dunit.DistributedTestCase
  * @since 8.0
  */
 public class ClientServerRegisterInterestsDUnitTest extends DistributedTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
index 3a61945..e8d4915 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
@@ -36,11 +36,10 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.membership.ClientMembership;
 import com.gemstone.gemfire.management.membership.ClientMembershipEvent;
 import com.gemstone.gemfire.management.membership.ClientMembershipListenerAdapter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests cases that are particular for the auto connection source
@@ -394,7 +393,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
         System.err.println("Attempt: " + (i++));
         putInVM(vm, regionName, key, value);
         break;
-      } catch (NoAvailableLocatorsException | dunit.RMIException e) {
+      } catch (NoAvailableLocatorsException | com.gemstone.gemfire.test.dunit.RMIException e) {
         if( !(e instanceof NoAvailableLocatorsException)
             && !(e.getCause() instanceof NoAvailableServersException)) {
           throw e;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/CacheServerSSLConnectionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/CacheServerSSLConnectionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/CacheServerSSLConnectionDUnitTest.java
index 3705c7c..3150edd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/CacheServerSSLConnectionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/CacheServerSSLConnectionDUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.security.AuthenticationRequiredException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Tests cacheserver ssl support added. See https://svn.gemstone.com/trac/gemfire/ticket/48995 for details
  * @author tushark

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
index 7a0ddaf..2d1b75f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
@@ -47,11 +47,10 @@ import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
index 530b61a..72f1a5c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorTestBase.java
@@ -42,12 +42,11 @@ import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/SSLNoClientAuthDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/SSLNoClientAuthDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/SSLNoClientAuthDUnitTest.java
index 5ca5573..1c79129 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/SSLNoClientAuthDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/SSLNoClientAuthDUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.security.AuthenticationRequiredException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Test for GEODE-396
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
index eb93bbc..a398975 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/pooling/ConnectionManagerJUnitTest.java
@@ -59,11 +59,10 @@ import com.gemstone.gemfire.internal.cache.PoolStats;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * @author dsmith
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index 2f8f7c0..9f84325 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@ -79,13 +79,12 @@ import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor;
 import com.gemstone.gemfire.internal.cache.control.ResourceListener;
 import com.gemstone.gemfire.internal.cache.control.TestMemoryThresholdListener;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests the Heap Memory thresholds of {@link ResourceManager}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
index 0552641..afe551b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
@@ -68,13 +68,12 @@ import com.gemstone.gemfire.internal.cache.control.ResourceListener;
 import com.gemstone.gemfire.internal.cache.control.TestMemoryThresholdListener;
 import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests the Off-Heap Memory thresholds of {@link ResourceManager}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/ResourceManagerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/ResourceManagerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/ResourceManagerDUnitTest.java
index cf29981..19f0612 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/ResourceManagerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/ResourceManagerDUnitTest.java
@@ -61,11 +61,10 @@ import com.gemstone.gemfire.internal.cache.partitioned.RemoveBucketMessage;
 import com.gemstone.gemfire.internal.cache.partitioned.RemoveBucketMessage.RemoveBucketResponse;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.logging.LogService;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests com.gemstone.gemfire.cache.control.ResourceManager.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
index dc0116d..48f1c56 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/mapInterface/PutAllGlobalLockJUnitTest.java
@@ -36,10 +36,9 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 @Category(IntegrationTest.class)
 public class PutAllGlobalLockJUnitTest {
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
index 4be3fe4..f70e7a2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/partition/PartitionRegionHelperDUnitTest.java
@@ -45,14 +45,13 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.FixedPartitioningTestBase;
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.FixedPartitioningTestBase.Months_Accessor;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.QuarterPartitionResolver;
 
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 public class PartitionRegionHelperDUnitTest extends CacheTestCase {
 
   public PartitionRegionHelperDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
index 57f2204..5ce23a4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
@@ -43,9 +43,8 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.types.CollectionType;
 import com.gemstone.gemfire.cache.query.types.ObjectType;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Utility class for testing supported queries

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryTestListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryTestListener.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryTestListener.java
index c230f38..8c43e47 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryTestListener.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryTestListener.java
@@ -30,9 +30,8 @@ import com.gemstone.gemfire.cache.client.Pool;
 import com.gemstone.gemfire.cache.query.CqEvent;
 import com.gemstone.gemfire.cache.query.CqStatusListener;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * @author rmadduri

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
index 9cdf2fe..f579e58 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CompactRangeIndexDUnitTest.java
@@ -25,12 +25,11 @@ import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable.CacheSerializableRunnableException;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CompactRangeIndexDUnitTest extends DistributedTestCase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CqTimeTestListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CqTimeTestListener.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CqTimeTestListener.java
index 7c530f1..5f3d45d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CqTimeTestListener.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/CqTimeTestListener.java
@@ -25,9 +25,8 @@ import com.gemstone.gemfire.cache.Operation;
 import com.gemstone.gemfire.cache.query.CqEvent;
 import com.gemstone.gemfire.cache.query.CqListener;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * @author anil.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByDUnitImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByDUnitImpl.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByDUnitImpl.java
index 774917f..25d8c80 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByDUnitImpl.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByDUnitImpl.java
@@ -26,10 +26,9 @@ import com.gemstone.gemfire.cache.query.functional.GroupByTestImpl;
 import com.gemstone.gemfire.cache.query.functional.GroupByTestInterface;
 import com.gemstone.gemfire.cache.query.functional.NonDistinctOrderByTestImplementation;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByPartitionedQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByPartitionedQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByPartitionedQueryDUnitTest.java
index b1252d0..c1f1cec 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByPartitionedQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByPartitionedQueryDUnitTest.java
@@ -29,12 +29,11 @@ import com.gemstone.gemfire.cache.query.IndexNameConflictException;
 import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.RegionNotFoundException;
 import com.gemstone.gemfire.cache.query.functional.GroupByTestImpl;
+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.junit.categories.DistributedTest;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * 
  * @author ashahid

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByQueryDUnitTest.java
index 5c56652..095142a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/GroupByQueryDUnitTest.java
@@ -37,12 +37,11 @@ import com.gemstone.gemfire.cache.query.Struct;
 import com.gemstone.gemfire.cache.query.TypeMismatchException;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache30.CacheTestCase;
+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.junit.categories.DistributedTest;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * 
  * @author ashahid

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
index eea8726..afd2119 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HashIndexDUnitTest.java
@@ -21,11 +21,10 @@ import java.util.Properties;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.cache.query.QueryTestUtils;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class HashIndexDUnitTest extends DistributedTestCase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
index 24661a0..08a4882 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/HelperTestCase.java
@@ -45,11 +45,10 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class HelperTestCase extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByDUnitImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByDUnitImpl.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByDUnitImpl.java
index 53e323b..05f3ba1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByDUnitImpl.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByDUnitImpl.java
@@ -24,10 +24,9 @@ import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.RegionNotFoundException;
 import com.gemstone.gemfire.cache.query.functional.NonDistinctOrderByTestImplementation;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public abstract class NonDistinctOrderByDUnitImpl extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByPartitionedDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByPartitionedDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByPartitionedDUnitTest.java
index 207bfb7..a87df2e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByPartitionedDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/NonDistinctOrderByPartitionedDUnitTest.java
@@ -30,12 +30,11 @@ import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.RegionNotFoundException;
 import com.gemstone.gemfire.cache.query.functional.NonDistinctOrderByTestImplementation;
 import com.gemstone.gemfire.cache30.CacheTestCase;
+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.junit.categories.DistributedTest;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * 
  * @author ashahid

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxStringQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxStringQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxStringQueryDUnitTest.java
index b354ce6..52a3763 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxStringQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxStringQueryDUnitTest.java
@@ -60,13 +60,12 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.pdx.internal.PdxString;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.pdx.internal.PdxString;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class PdxStringQueryDUnitTest extends CacheTestCase{
   private static int bridgeServerPort;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryDataInconsistencyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryDataInconsistencyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryDataInconsistencyDUnitTest.java
index 2366c4a..5833883 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryDataInconsistencyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryDataInconsistencyDUnitTest.java
@@ -40,12 +40,11 @@ import com.gemstone.gemfire.cache.query.partitioned.PRQueryDUnitHelper;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.execute.PRClientServerTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This tests the data inconsistency during update on an index and querying the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUsingXMLDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUsingXMLDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUsingXMLDUnitTest.java
index 35f84a7..1ebe01d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUsingXMLDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUsingXMLDUnitTest.java
@@ -61,15 +61,14 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
-
 public class QueryIndexUsingXMLDUnitTest extends CacheTestCase {
 
   static private final String WAIT_PROPERTY = "QueryIndexBuckets.maxWaitTime";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
index f9b7366..8030f09 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryParamsAuthorizationDUnitTest.java
@@ -31,10 +31,9 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test for accessing query bind parameters from authorization callbacks

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
index 03e7ac9..27619c0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
@@ -55,10 +55,9 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.LocalDataSet;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.execute.PRClientServerTestBase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This tests the querying using a RegionFunctionContext which provides a filter

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingPoolDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingPoolDUnitTest.java
index 37f203b..35f71fe 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingPoolDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingPoolDUnitTest.java
@@ -49,10 +49,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests remote (client/server) query execution.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/RemoteQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/RemoteQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/RemoteQueryDUnitTest.java
index 4b8a280..dfbe69e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/RemoteQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/RemoteQueryDUnitTest.java
@@ -16,27 +16,35 @@
  */
 package com.gemstone.gemfire.cache.query.dunit;
 
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+import java.util.Comparator;
+import java.util.Properties;
+
 import com.gemstone.gemfire.DataSerializable;
 import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.*;
+import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
+import com.gemstone.gemfire.cache.query.SelectResults;
+import com.gemstone.gemfire.cache.query.Struct;
+import com.gemstone.gemfire.cache.query.internal.QueryObserverAdapter;
+import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
+import com.gemstone.gemfire.cache.query.internal.ResultsBag;
 import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
+import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.*;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.io.IOException;
-import java.util.Comparator;
-import java.util.Properties;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import cacheRunner.Portfolio;
 import cacheRunner.Position;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/ResourceManagerWithQueryMonitorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/ResourceManagerWithQueryMonitorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/ResourceManagerWithQueryMonitorDUnitTest.java
index 19271c1..372111c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/ResourceManagerWithQueryMonitorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/ResourceManagerWithQueryMonitorDUnitTest.java
@@ -65,12 +65,11 @@ import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
 import com.gemstone.gemfire.internal.cache.control.ResourceListener;
 import com.gemstone.gemfire.internal.cache.control.TestMemoryThresholdListener;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ResourceManagerWithQueryMonitorDUnitTest extends ClientServerTestCase {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/SelectStarQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/SelectStarQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/SelectStarQueryDUnitTest.java
index d34bd29..b943aca 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/SelectStarQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/SelectStarQueryDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
 import com.gemstone.gemfire.pdx.PdxInstance;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test for #44807 to eliminate unnecessary serialization/deserialization in

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexCreationDeadLockJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexCreationDeadLockJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexCreationDeadLockJUnitTest.java
index 5de9b50..37abacf 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexCreationDeadLockJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexCreationDeadLockJUnitTest.java
@@ -46,10 +46,9 @@ import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.QueryService;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
 *
 * @author prafulla

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexMaintenanceAsynchJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexMaintenanceAsynchJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexMaintenanceAsynchJUnitTest.java
index 6025caa..84612b5 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexMaintenanceAsynchJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/IndexMaintenanceAsynchJUnitTest.java
@@ -45,11 +45,10 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverAdapter;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
 import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  *
  * @author Ketan

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LikePredicateJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LikePredicateJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LikePredicateJUnitTest.java
index 97c9d4b..3e4a570 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LikePredicateJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/LikePredicateJUnitTest.java
@@ -57,10 +57,9 @@ import com.gemstone.gemfire.cache.query.internal.ResultsCollectionWrapper;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
 import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * 
  * @author asif

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/ExecutionContextJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/ExecutionContextJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/ExecutionContextJUnitTest.java
index db0a274..35b5995 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/ExecutionContextJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/ExecutionContextJUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.cache.query.SelectResults;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.data.Position;
 import com.gemstone.gemfire.internal.cache.InternalCache;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * @author Asif
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
index 5a4f9a5..7ad5f66 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
@@ -28,11 +28,10 @@ import com.gemstone.gemfire.cache.query.CacheUtils;
 import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.QueryService;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 import java.util.HashSet;
 import java.util.Set;
 



[23/52] [abbrv] incubator-geode git commit: Update README instructions for building with gradle instead of gradlew

Posted by ds...@apache.org.
Update README instructions for building with gradle instead of gradlew


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/2609946d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/2609946d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/2609946d

Branch: refs/heads/feature/GEODE-831
Commit: 2609946d8863d4e576820ac92d4318fd5f295b5a
Parents: 42dd4a7
Author: Anthony Baker <ab...@apache.org>
Authored: Mon Jan 25 12:35:55 2016 -0800
Committer: Anthony Baker <ab...@apache.org>
Committed: Mon Jan 25 12:38:58 2016 -0800

----------------------------------------------------------------------
 README.md | 7 +++----
 1 file changed, 3 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2609946d/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
index e90b769..57f5e4d 100755
--- a/README.md
+++ b/README.md
@@ -32,11 +32,10 @@ Geode includes the following features:
 
 # Geode in 5 minutes
 
-With JDK 1.8 or a more recent version installed, obtain the source archive. 
-Extract and build from source:
+With both a recent version of Gradle and JDK 1.8 or a more recent version installed, obtain the source archive.
+Extract the source archive and build from the expanded directory:
 
-    $ cd geode
-    $ ./gradlew build installDist
+    $ gradle build installDist
 
 Start a locator and server:
 


[38/52] [abbrv] incubator-geode git commit: Fixed typo while comparing two network address.

Posted by ds...@apache.org.
Fixed typo while comparing two network address.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/8a8571f4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/8a8571f4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/8a8571f4

Branch: refs/heads/feature/GEODE-831
Commit: 8a8571f43e4dbefa02d00e4d57a8f7965ed4fa09
Parents: 3bd930f
Author: Hitesh Khamesra <hk...@pivotal.io>
Authored: Wed Jan 27 10:07:01 2016 -0800
Committer: Hitesh Khamesra <hk...@pivotal.io>
Committed: Wed Jan 27 15:52:56 2016 -0800

----------------------------------------------------------------------
 .../gemfire/cache/client/internal/AutoConnectionSourceImpl.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8a8571f4/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceImpl.java
index 1098fbe..6fe1c6b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceImpl.java
@@ -75,7 +75,7 @@ public class AutoConnectionSourceImpl implements ConnectionSource {
         return 0;
       }
       
-      int result = o1.getAddress().getCanonicalHostName().compareTo(o1.getAddress().getCanonicalHostName());
+      int result = o1.getAddress().getCanonicalHostName().compareTo(o2.getAddress().getCanonicalHostName());
       if(result != 0) {
         return result;
       }


[48/52] [abbrv] incubator-geode git commit: GEODE-735: create unit test for OffHeapHelper

Posted by ds...@apache.org.
GEODE-735: create unit test for OffHeapHelper

This closes #79


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/46eaaa9b
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/46eaaa9b
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/46eaaa9b

Branch: refs/heads/feature/GEODE-831
Commit: 46eaaa9b10fe11101c8f7e0c8cb601d43789ceca
Parents: a5437b2
Author: Ken Howe <kh...@pivotal.io>
Authored: Tue Jan 26 14:37:18 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Jan 28 11:34:35 2016 -0800

----------------------------------------------------------------------
 .../offheap/OffHeapHelperJUnitTest.java         | 314 +++++++++++++++++++
 1 file changed, 314 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/46eaaa9b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
new file mode 100644
index 0000000..fd0eb4f
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
@@ -0,0 +1,314 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.internal.offheap;
+
+import static org.junit.Assert.*;
+import static org.mockito.Mockito.mock;
+import static org.hamcrest.CoreMatchers.*;
+
+import java.nio.ByteBuffer;
+
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.LogWriter;
+import com.gemstone.gemfire.internal.cache.EntryEventImpl;
+import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
+import com.gemstone.gemfire.test.junit.categories.UnitTest;
+
+/**
+ * @author khowe
+ */
+@Category(UnitTest.class)
+public class OffHeapHelperJUnitTest extends AbstractStoredObjectTestBase {
+
+  private MemoryChunkWithRefCount storedObject                 = null;
+  private Object                  deserializedRegionEntryValue = null;
+  private byte[]                  serializedRegionEntryValue   = null;
+  private MemoryAllocator         ma;
+
+  @Before
+  public void setUp() {
+    OutOfOffHeapMemoryListener ooohml = mock(OutOfOffHeapMemoryListener.class);
+    OffHeapMemoryStats stats = mock(OffHeapMemoryStats.class);
+    LogWriter lw = mock(LogWriter.class);
+
+    ma = SimpleMemoryAllocatorImpl.create(ooohml, stats, lw, 3, OffHeapStorage.MIN_SLAB_SIZE * 3,
+        OffHeapStorage.MIN_SLAB_SIZE);
+
+  }
+
+  /**
+   * Extracted from JUnit setUp() to reduce test overhead for cases where
+   * offheap memory isn't needed.
+   */
+  private void allocateOffHeapSerialized() {
+    Object regionEntryValue = getValue();
+    storedObject = createValueAsSerializedStoredObject(regionEntryValue);
+    deserializedRegionEntryValue = storedObject.getValueAsDeserializedHeapObject();
+    serializedRegionEntryValue = storedObject.getSerializedValue();
+  }
+
+  private void allocateOffHeapDeserialized() {
+    Object regionEntryValue = getValue();
+    storedObject = createValueAsUnserializedStoredObject(regionEntryValue);
+    deserializedRegionEntryValue = storedObject.getValueAsDeserializedHeapObject();
+    serializedRegionEntryValue = storedObject.getSerializedValue();
+  }
+
+  @After
+  public void tearDown() {
+    SimpleMemoryAllocatorImpl.freeOffHeapMemory();
+  }
+
+  @Override
+  public Object getValue() {
+    return Long.valueOf(Long.MAX_VALUE);
+  }
+
+  @Override
+  public byte[] getValueAsByteArray() {
+    return convertValueToByteArray(getValue());
+  }
+
+  private byte[] convertValueToByteArray(Object value) {
+    return ByteBuffer.allocate(Long.SIZE / Byte.SIZE).putLong((Long) value).array();
+  }
+
+  @Override
+  public Object convertByteArrayToObject(byte[] valueInByteArray) {
+    return ByteBuffer.wrap(valueInByteArray).getLong();
+  }
+
+  @Override
+  public Object convertSerializedByteArrayToObject(byte[] valueInSerializedByteArray) {
+    return EntryEventImpl.deserialize(valueInSerializedByteArray);
+  }
+
+  @Override
+  protected MemoryChunkWithRefCount createValueAsUnserializedStoredObject(Object value) {
+    byte[] valueInByteArray;
+    if (value instanceof Long) {
+      valueInByteArray = convertValueToByteArray(value);
+    } else {
+      valueInByteArray = (byte[]) value;
+    }
+
+    boolean isSerialized = false;
+    boolean isCompressed = false;
+
+    MemoryChunkWithRefCount createdObject = createChunk(valueInByteArray, isSerialized, isCompressed);
+    return createdObject;
+  }
+
+  @Override
+  protected MemoryChunkWithRefCount createValueAsSerializedStoredObject(Object value) {
+    byte[] valueInSerializedByteArray = EntryEventImpl.serialize(value);
+
+    boolean isSerialized = true;
+    boolean isCompressed = false;
+
+    MemoryChunkWithRefCount createdObject = createChunk(valueInSerializedByteArray, isSerialized, isCompressed);
+    return createdObject;
+  }
+
+  private GemFireChunk createChunk(byte[] v, boolean isSerialized, boolean isCompressed) {
+    GemFireChunk chunk = (GemFireChunk) ma.allocateAndInitialize(v, isSerialized, isCompressed, GemFireChunk.TYPE);
+    return chunk;
+  }
+
+  @Test
+  public void getHeapFormOfSerializedStoredObjectReturnsDeserializedObject() {
+    allocateOffHeapSerialized();
+    Object heapObject = OffHeapHelper.getHeapForm(storedObject);
+    assertThat("getHeapForm returns non-null object", heapObject, notNullValue());
+    assertThat("Heap and off heap objects are different objects", heapObject, is(not(storedObject)));
+    assertThat("Deserialzed values of offHeap object and returned object are equal", heapObject,
+        is(equalTo(deserializedRegionEntryValue)));
+  }
+
+  @Test
+  public void getHeapFormOfNonOffHeapObjectReturnsOriginal() {
+    Object testObject = getValue();
+    Object heapObject = OffHeapHelper.getHeapForm(testObject);
+    assertNotNull(heapObject);
+    assertSame(testObject, heapObject);
+  }
+
+  @Test
+  public void getHeapFormWithNullReturnsNull() {
+    Object testObject = null;
+    Object returnObject = OffHeapHelper.getHeapForm(testObject);
+    assertThat(returnObject, is(equalTo(null)));
+  }
+
+  @Test
+  public void copyAndReleaseWithNullReturnsNull() {
+    Object testObject = null;
+    Object returnObject = OffHeapHelper.copyAndReleaseIfNeeded(testObject);
+    assertThat(returnObject, is(equalTo(null)));
+  }
+
+  @Test
+  public void copyAndReleaseWithRetainedDeserializedObjectDecreasesRefCnt() {
+    allocateOffHeapDeserialized();
+    assertTrue(storedObject.retain());
+    assertThat("Retained chunk ref count", storedObject.getRefCount(), is(2));
+    OffHeapHelper.copyAndReleaseIfNeeded(storedObject);
+    assertThat("Chunk ref count decreases", storedObject.getRefCount(), is(1));
+  }
+
+  @Test
+  public void copyAndReleaseWithNonRetainedObjectDecreasesRefCnt() {
+    allocateOffHeapDeserialized();
+    // assertTrue(storedObject.retain());
+    assertThat("Retained chunk ref count", storedObject.getRefCount(), is(1));
+    OffHeapHelper.copyAndReleaseIfNeeded(storedObject);
+    assertThat("Chunk ref count decreases", storedObject.getRefCount(), is(0));
+  }
+
+  @Test
+  public void copyAndReleaseWithDeserializedReturnsValueOfOriginal() {
+    allocateOffHeapDeserialized();
+    assertTrue(storedObject.retain());
+    Object returnObject = OffHeapHelper.copyAndReleaseIfNeeded(storedObject);
+    assertThat(returnObject, is(equalTo(deserializedRegionEntryValue)));
+  }
+
+  @Test
+  public void copyAndReleaseWithSerializedReturnsValueOfOriginal() {
+    allocateOffHeapSerialized();
+    assertTrue(storedObject.retain());
+    Object returnObject = ((VMCachedDeserializable) OffHeapHelper.copyAndReleaseIfNeeded(storedObject))
+        .getSerializedValue();
+    assertThat(returnObject, is(equalTo(serializedRegionEntryValue)));
+  }
+
+  @Test
+  public void copyAndReleaseNonStoredObjectReturnsOriginal() {
+    Object testObject = getValue();
+    Object returnObject = OffHeapHelper.copyAndReleaseIfNeeded(testObject);
+    assertThat(returnObject, is(testObject));
+  }
+
+  @Test
+  public void copyIfNeededWithNullReturnsNull() {
+    Object testObject = null;
+    Object returnObject = OffHeapHelper.copyAndReleaseIfNeeded(testObject);
+    assertThat(returnObject, is(equalTo(null)));
+  }
+
+  @Test
+  public void copyIfNeededNonOffHeapReturnsOriginal() {
+    Object testObject = getValue();
+    Object returnObject = OffHeapHelper.copyIfNeeded(testObject);
+    assertThat(returnObject, is(testObject));
+  }
+
+  @Test
+  public void copyIfNeededOffHeapSerializedReturnsValueOfOriginal() {
+    allocateOffHeapSerialized();
+    Object returnObject = ((VMCachedDeserializable) OffHeapHelper.copyIfNeeded(storedObject)).getSerializedValue();
+    assertThat(returnObject, is(equalTo(serializedRegionEntryValue)));
+  }
+
+  @Test
+  public void copyIfNeededOffHeapDeserializedReturnsOriginal() {
+    allocateOffHeapDeserialized();
+    Object returnObject = OffHeapHelper.copyIfNeeded(storedObject);
+    assertThat(returnObject, is(equalTo(deserializedRegionEntryValue)));
+  }
+
+  @Test
+  public void copyIfNeededWithOffHeapDeserializedObjDoesNotRelease() {
+    allocateOffHeapDeserialized();
+    int initialRefCountOfObject = storedObject.getRefCount();
+    OffHeapHelper.copyIfNeeded(storedObject);
+    assertThat("Ref count after copy", storedObject.getRefCount(), is(initialRefCountOfObject));
+  }
+
+  @Test
+  public void copyIfNeededWithOffHeapSerializedObjDoesNotRelease() {
+    allocateOffHeapSerialized();
+    int initialRefCountOfObject = storedObject.getRefCount();
+    OffHeapHelper.copyIfNeeded(storedObject);
+    assertThat("Ref count after copy", storedObject.getRefCount(), is(initialRefCountOfObject));
+  }
+
+  @Test
+  public void releaseOfOffHeapDecrementsRefCount() {
+    allocateOffHeapSerialized();
+    assertThat("Initial Ref Count", storedObject.getRefCount(), is(1));
+    OffHeapHelper.release(storedObject);
+    assertThat("Ref Count Decremented", storedObject.getRefCount(), is(0));
+  }
+
+  @Test
+  public void releaseOfOffHeapReturnsTrue() {
+    allocateOffHeapSerialized();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.release(storedObject), is(true));
+  }
+
+  @Test
+  public void releaseOfNonOffHeapReturnsFalse() {
+    Object testObject = getValue();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.release(testObject), is(false));
+  }
+
+  @Test
+  public void releaseWithOutTrackingOfOffHeapDecrementsRefCount() {
+    allocateOffHeapSerialized();
+    assertThat("Initial Ref Count", storedObject.getRefCount(), is(1));
+    OffHeapHelper.releaseWithNoTracking(storedObject);
+    assertThat("Ref Count Decremented", storedObject.getRefCount(), is(0));
+  }
+
+  @Test
+  public void releaseWithoutTrackingOfOffHeapReturnsTrue() {
+    allocateOffHeapSerialized();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.releaseWithNoTracking(storedObject), is(true));
+  }
+
+  @Test
+  public void releaseWithoutTrackingOfNonOffHeapReturnsFalse() {
+    Object testObject = getValue();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.releaseWithNoTracking(testObject), is(false));
+  }
+
+  @Test
+  public void releaseAndTrackOwnerOfOffHeapDecrementsRefCount() {
+    allocateOffHeapSerialized();
+    assertThat("Initial Ref Count", storedObject.getRefCount(), is(1));
+    OffHeapHelper.releaseAndTrackOwner(storedObject, "owner");
+    assertThat("Ref Count Decremented", storedObject.getRefCount(), is(0));
+  }
+
+  @Test
+  public void releaseAndTrackOwnerOfOffHeapReturnsTrue() {
+    allocateOffHeapSerialized();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.releaseAndTrackOwner(storedObject, "owner"), is(true));
+  }
+
+  @Test
+  public void releaseAndTrackOwnerOfNonOffHeapReturnsFalse() {
+    Object testObject = getValue();
+    assertThat("Releasing OFfHeap object is true", OffHeapHelper.releaseAndTrackOwner(testObject, "owner"), is(false));
+  }
+
+}


[43/52] [abbrv] incubator-geode git commit: GEODE-872: Removing duplicate code from ConcurrentSerialGatewaySenderOperationsDUnitTest

Posted by ds...@apache.org.
GEODE-872: Removing duplicate code from ConcurrentSerialGatewaySenderOperationsDUnitTest

This test was almost an exact copy of
SerialGatewaySenderOperationsDUnitTest, with a few lines changes. The
non concurrent test had already fixed the suspect string, but the
concurrent test did not. By throwing away the code from Concurrent* and
making it extend the non-concurrent test, this bug is fixed.

The test has also been tuned to do fewer operations and take less time.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/22606309
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/22606309
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/22606309

Branch: refs/heads/feature/GEODE-831
Commit: 22606309a2cb95db34d10fbd3000ca31755c8fad
Parents: 68a85fe
Author: Dan Smith <up...@apache.org>
Authored: Wed Jan 27 15:05:58 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Thu Jan 28 09:37:50 2016 -0800

----------------------------------------------------------------------
 .../gemfire/internal/cache/wan/WANTestBase.java |   8 +-
 ...tSerialGatewaySenderOperationsDUnitTest.java | 469 +---------
 .../SerialGatewaySenderOperationsDUnitTest.java | 901 ++++++++-----------
 3 files changed, 407 insertions(+), 971 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/22606309/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index 3dd4742..a212baa 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -2239,10 +2239,14 @@ public class WANTestBase extends DistributedTestCase{
     }
   }
   
-  public static void startReceivers() throws IOException {
+  public static void startReceivers() {
     Set<GatewayReceiver> receivers = cache.getGatewayReceivers();
     for (GatewayReceiver receiver : receivers) {
-      receiver.start();
+      try {
+        receiver.start();
+      } catch (IOException e) {
+        throw new RuntimeException(e);
+      }
     }
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/22606309/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
index b709334..b2a9a3b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
@@ -19,16 +19,17 @@ package com.gemstone.gemfire.internal.cache.wan.concurrent;
 import java.util.Set;
 
 import com.gemstone.gemfire.cache.wan.GatewaySender;
+import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-import com.gemstone.gemfire.test.dunit.AsyncInvocation;
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
+import com.gemstone.gemfire.internal.cache.wan.serial.SerialGatewaySenderOperationsDUnitTest;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author skumar
  *
  */
-public class ConcurrentSerialGatewaySenderOperationsDUnitTest  extends WANTestBase {
+public class ConcurrentSerialGatewaySenderOperationsDUnitTest  extends SerialGatewaySenderOperationsDUnitTest {
 
   private static final long serialVersionUID = 1L;
 
@@ -36,466 +37,24 @@ public class ConcurrentSerialGatewaySenderOperationsDUnitTest  extends WANTestBa
     super(name);
   }
 
-  public void setUp() throws Exception {
-    super.setUp();
-    addExpectedException("Broken pipe");
-    addExpectedException("Connection reset");
-    addExpectedException("Unexpected IOException");
+  protected void createSenderVM5() {
+    vm5.invoke(() -> WANTestBase.createConcurrentSender( "ln", 2,
+        false, 100, 10, false, true, null, true, 5, OrderPolicy.KEY ));
   }
 
-  public void testSerialGatewaySenderOperationsWithoutStarting() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 5, OrderPolicy.KEY });
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 5, OrderPolicy.KEY });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifyGatewaySenderOperations", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifyGatewaySenderOperations", new Object[] { "ln" });
-
+  protected void createSenderVM4() {
+    vm4.invoke(() -> WANTestBase.createConcurrentSender( "ln", 2,
+        false, 100, 10, false, true, null, true, 5, OrderPolicy.KEY ));
   }
 
-  
-  public void testStartPauseResumeSerialGatewaySender() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 5 , OrderPolicy.KEY});
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 5 , OrderPolicy.KEY});
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderPausedState", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderPausedState", new Object[] { "ln" });
-
-    AsyncInvocation inv1 = vm4.invokeAsync(WANTestBase.class, "doPuts",
-        new Object[] { testName + "_RR", 1000 });
-
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-
-    try {
-      inv1.join();
-    } catch (InterruptedException e) {
-      e.printStackTrace();
-      fail("Interrupted the async invocation.");
-    }
-
-    getLogWriter().info("Completed puts in the region");
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "validateQueueContentsForConcurrentSerialGatewaySender", new Object[] { "ln", 0 });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "validateQueueContentsForConcurrentSerialGatewaySender", new Object[] { "ln", 0 });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-
-  }
-
-  public void testStopSerialGatewaySender() throws Throwable {
-    addExpectedException("Broken pipe");
-    addExpectedException("Connection reset");
-    addExpectedException("RegionDestroyedException");
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 3, OrderPolicy.KEY});
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 3, OrderPolicy.KEY });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 20 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 20 });
-    
-    vm2.invoke(WANTestBase.class, "stopReceivers");
-    vm3.invoke(WANTestBase.class, "stopReceivers");
-    
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
-    
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-    
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-    /**
-     * Should have no effect on GatewaySenderState
-     */
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    AsyncInvocation vm4async = vm4.invokeAsync(WANTestBase.class, "startSender", new Object[] { "ln" });
-    AsyncInvocation vm5async = vm5.invokeAsync(WANTestBase.class, "startSender", new Object[] { "ln" });
-    int START_WAIT_TIME = 30000;
-    vm4async.getResult(START_WAIT_TIME);
-    vm5async.getResult(START_WAIT_TIME);
-    
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-      110 });
-    
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 130 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 130 });
-    
-    vm2.invoke(WANTestBase.class, "startReceivers");
-    vm3.invoke(WANTestBase.class, "startReceivers");
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-    vm5.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_RR", 110 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_RR", 110 });
-    
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-  }
-
-
-  public void testStopOneSerialGatewaySenderBothPrimary() throws Throwable {
-    addExpectedException("Broken pipe");
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 4, OrderPolicy.KEY });
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 4, OrderPolicy.KEY });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        100 });
-
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        200 });
-    
-    getLogWriter().info("Completed puts in the region");
-
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 200 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 200 });
-    
-  //Do some puts while restarting a sender
-    AsyncInvocation asyncPuts = vm4.invokeAsync(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        2000 });
-    
-    Thread.sleep(10);
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    
-    asyncPuts.getResult();
-    getLogWriter().info("Completed puts in the region");
-    
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 2000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 2000 });
-    
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-  }
-
-  public void Bug46921_testStopOneSerialGatewaySender_PrimarySecondary() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 4, OrderPolicy.PARTITION });
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 4, OrderPolicy.PARTITION });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-    
-    getLogWriter().info("Completed puts in the region");
-
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
+  protected void validateQueueClosedVM4() {
+    vm4.invoke(() -> WANTestBase.validateQueueClosedForConcurrentSerialGatewaySender( "ln"));
   }
   
-  public void testStopOneSender_StartAnotherSender() {
-    addExpectedException("Broken pipe");
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 4, OrderPolicy.PARTITION });
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-      false, 100, 10, false, true, null, true, 4, OrderPolicy.PARTITION });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-      testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-    getLogWriter().info("Completed puts in the region");
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
+  private void validateQueueContents(VM vm, String site, int size) {
+    vm.invoke(() -> WANTestBase.validateQueueContentsForConcurrentSerialGatewaySender( site, size));
   }
 
-  public void test_Bug44153_StopOneSender_StartAnotherSender_CheckQueueSize() {
-    addExpectedException("Broken pipe");
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true, 3, OrderPolicy.PARTITION });
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "validateQueueContentsForConcurrentSerialGatewaySender", new Object[] { "ln", 1000});
-
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-      false, 100, 10, false, true, null, true, 3, OrderPolicy.PARTITION });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "validateQueueContentsForConcurrentSerialGatewaySender", new Object[] { "ln", 1000});
-
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm4.invoke(ConcurrentSerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    vm4.invoke(WANTestBase.class, "validateQueueClosedForConcurrentSerialGatewaySender", new Object[] { "ln"});
-
-
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-
-    vm5.invoke(WANTestBase.class, "validateQueueContentsForConcurrentSerialGatewaySender", new Object[] { "ln",
-        11000 });
-    vm4.invoke(WANTestBase.class, "validateQueueClosedForConcurrentSerialGatewaySender", new Object[] { "ln"});
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    getLogWriter().info("Completed puts in the region");
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-  }
-  
   public static void verifySenderPausedState(String senderId) {
     Set<GatewaySender> senders = cache.getGatewaySenders();
     AbstractGatewaySender sender = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/22606309/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
index d30289b..7f4535e 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
@@ -27,6 +27,7 @@ import com.gemstone.gemfire.internal.cache.wan.GatewaySenderException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author skumar
@@ -42,11 +43,11 @@ public class SerialGatewaySenderOperationsDUnitTest extends WANTestBase {
 
   public void setUp() throws Exception {
     super.setUp();
-    addExpectedException("Connection reset");
     addExpectedException("Broken pipe");
+    addExpectedException("Connection reset");
+    addExpectedException("Unexpected IOException");
     addExpectedException("Connection refused");
     addExpectedException("could not get remote locator information");
-    addExpectedException("Unexpected IOException");
     
     //Stopping the gateway closed the region,
     //which causes this exception to get logged
@@ -54,111 +55,107 @@ public class SerialGatewaySenderOperationsDUnitTest extends WANTestBase {
   }
 
   public void testSerialGatewaySenderOperationsWithoutStarting() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifyGatewaySenderOperations", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifyGatewaySenderOperations", new Object[] { "ln" });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        100 ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifyGatewaySenderOperations( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifyGatewaySenderOperations( "ln" ));
+
+  }
+
+  protected void createSenderRegions() {
+    vm4.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm5.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm6.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm7.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+  }
+
+  protected void createReceiverRegions() {
+    vm2.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", null, isOffHeap() ));
+    vm3.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", null, isOffHeap() ));
+  }
+
+  protected void createSenderCaches(Integer lnPort) {
+    vm4.invoke(() -> WANTestBase.createCache( lnPort ));
+    vm5.invoke(() -> WANTestBase.createCache( lnPort ));
+    vm6.invoke(() -> WANTestBase.createCache( lnPort ));
+    vm7.invoke(() -> WANTestBase.createCache( lnPort ));
+  }
+
+  protected void createReceivers(Integer nyPort) {
+    vm2.invoke(() -> WANTestBase.createReceiver( nyPort ));
+    vm3.invoke(() -> WANTestBase.createReceiver( nyPort ));
+  }
 
+  protected void createSenderVM5() {
+    vm5.invoke(() -> WANTestBase.createSender( "ln", 2,
+        false, 100, 10, false, true, null, true ));
+  }
+
+  protected void createSenderVM4() {
+    vm4.invoke(() -> WANTestBase.createSender( "ln", 2,
+        false, 100, 10, false, true, null, true ));
   }
 
   
   public void testStartPauseResumeSerialGatewaySender() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderPausedState", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderPausedState", new Object[] { "ln" });
-
-    AsyncInvocation inv1 = vm4.invokeAsync(WANTestBase.class, "doPuts",
-        new Object[] { testName + "_RR", 1000 });
-
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        100 ));
+
+    vm4.invoke(() -> WANTestBase.pauseSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.pauseSender( "ln" ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderPausedState( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderPausedState( "ln" ));
+
+    AsyncInvocation inv1 = vm4.invokeAsync(() -> WANTestBase.doPuts( testName + "_RR", 10 ));
+
+    vm4.invoke(() -> WANTestBase.resumeSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.resumeSender( "ln" ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderResumedState( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderResumedState( "ln" ));
 
     try {
       inv1.join();
@@ -169,456 +166,351 @@ public class SerialGatewaySenderOperationsDUnitTest extends WANTestBase {
 
     getLogWriter().info("Completed puts in the region");
     
-    vm4.invoke(WANTestBase.class,
-        "validateQueueContents", new Object[] { "ln", 0 });
-    vm5.invoke(WANTestBase.class,
-        "validateQueueContents", new Object[] { "ln", 0 });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
+    validateQueueContents(vm4, "ln", 0);
+    validateQueueContents(vm5, "ln", 0);
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
 
   }
 
   public void testStopSerialGatewaySender() throws Throwable {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        20 ));
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        20 ));
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 20 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 20 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 20 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 20 ));
     
-    vm2.invoke(WANTestBase.class, "stopReceivers");
-    vm3.invoke(WANTestBase.class, "stopReceivers");
+    vm2.invoke(() -> WANTestBase.stopReceivers());
+    vm3.invoke(() -> WANTestBase.stopReceivers());
     
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        20 });
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        20 ));
     
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 20 ));
+    vm5.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 20 ));
     
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.stopSender( "ln" ));
 
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
 
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 0 ));
+    vm5.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 0 ));
     /**
      * Should have no effect on GatewaySenderState
      */
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.resumeSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.resumeSender( "ln" ));
 
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
 
-    AsyncInvocation vm4async = vm4.invokeAsync(WANTestBase.class, "startSender", new Object[] { "ln" });
-    AsyncInvocation vm5async = vm5.invokeAsync(WANTestBase.class, "startSender", new Object[] { "ln" });
+    AsyncInvocation vm4async = vm4.invokeAsync(() -> WANTestBase.startSender( "ln" ));
+    AsyncInvocation vm5async = vm5.invokeAsync(() -> WANTestBase.startSender( "ln" ));
     int START_WAIT_TIME = 30000;
     vm4async.getResult(START_WAIT_TIME);
     vm5async.getResult(START_WAIT_TIME);
 
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 20 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 20 ));
+    vm5.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 20 ));
 
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-      110 });
+    vm5.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+      110 ));
     
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 130 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 130 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 130 ));
+    vm5.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 130 ));
     
-    vm2.invoke(WANTestBase.class, "startReceivers");
-    vm3.invoke(WANTestBase.class, "startReceivers");
+    vm2.invoke(() -> WANTestBase.startReceivers());
+    vm3.invoke(() -> WANTestBase.startReceivers());
 
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderResumedState", new Object[] { "ln" });
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderResumedState( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderResumedState( "ln" ));
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_RR", 110 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_RR", 110 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+      testName + "_RR", 110 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+      testName + "_RR", 110 ));
     
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
-    vm5.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 0 ));
+    vm5.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 0 ));
+  }
+
+  protected void startSenders() {
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.startSender( "ln" ));
   }
 
   public void testStopOneSerialGatewaySenderBothPrimary() throws Throwable {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        100 });
-
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        100 ));
+
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        200 });
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        200 ));
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 200 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 200 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 200 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 200 ));
     
     //Do some puts while restarting a sender
-    AsyncInvocation asyncPuts = vm4.invokeAsync(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        2000 });
+    AsyncInvocation asyncPuts = vm4.invokeAsync(() -> WANTestBase.doPuts( testName + "_RR",
+        300 ));
     
     Thread.sleep(10);
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
     
     asyncPuts.getResult();
     getLogWriter().info("Completed puts in the region");
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 2000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 2000 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 300 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 300 ));
     
-    Thread.sleep(5000);
-    vm4.invoke(WANTestBase.class, "validateQueueSizeStat", new Object[] { "ln", 0 });
+    vm4.invoke(() -> WANTestBase.validateQueueSizeStat( "ln", 0 ));
     
     
   }
 
   public void testStopOneSerialGatewaySender_PrimarySecondary() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
+
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        100 ));
     
     getLogWriter().info("Completed puts in the region");
 
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
+    vm3.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
   }
   
   public void testStopOneSender_StartAnotherSender() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-      false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-      testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        10000 });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    vm2.invoke(() -> WANTestBase.createReceiver( nyPort ));
+    vm2.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", null, isOffHeap() ));
+
+    vm4.invoke(() -> WANTestBase.createCache( lnPort ));
+    createSenderVM4();
+    vm4.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
+
+    vm5.invoke(() -> WANTestBase.createCache( lnPort ));
+    createSenderVM5();
+    vm5.invoke(() -> WANTestBase.createReplicatedRegion(
+      testName + "_RR", "ln", isOffHeap() ));
+    vm5.invoke(() -> WANTestBase.startSender( "ln" ));
+
+    vm5.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        100 ));
     getLogWriter().info("Completed puts in the region");
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
   }
 
   public void test_Bug44153_StopOneSender_StartAnotherSender_CheckQueueSize() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
-    vm4.invoke(WANTestBase.class, "validateQueueContents", new Object[] { "ln",
-      1000 });
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-      false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "doPutsFrom", new Object[] { testName + "_RR", 1000, 11000 });
-
-    vm5.invoke(WANTestBase.class, "validateQueueContents", new Object[] { "ln",
-        10000 });
-    vm5.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm5.invoke(SerialGatewaySenderOperationsDUnitTest.class,
-        "verifySenderStoppedState", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm4.invoke(WANTestBase.class, "validateQueueContents", new Object[] { "ln",
-      1000 });
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    vm4.invoke(() -> WANTestBase.createCache( lnPort ));
+    createSenderVM4();
+    vm4.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
+    validateQueueContents(vm4, "ln", 10);
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+
+    vm4.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
+
+    vm5.invoke(() -> WANTestBase.createCache( lnPort ));
+    createSenderVM5();
+    vm5.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", "ln", isOffHeap() ));
+    vm5.invoke(() -> WANTestBase.startSender( "ln" ));
+
+    vm5.invoke(() -> WANTestBase.doPutsFrom( testName + "_RR", 10, 110 ));
+
+    validateQueueContents(vm5, "ln", 100);
+    validateQueueClosedVM4();
+    vm5.invoke(() -> WANTestBase.stopSender( "ln" ));
+    vm5.invoke(() -> SerialGatewaySenderOperationsDUnitTest.verifySenderStoppedState( "ln" ));
+
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
+    validateQueueContents(vm4, "ln", 10);
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+
+    vm5.invoke(() -> WANTestBase.startSender( "ln" ));
+    vm2.invoke(() -> WANTestBase.createReceiver( nyPort ));
+    vm2.invoke(() -> WANTestBase.createReplicatedRegion(
+        testName + "_RR", null, isOffHeap() ));
     getLogWriter().info("Completed puts in the region");
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 10000 });
-    vm5.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 11000 });
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 100 ));
+    vm5.invoke(() -> WANTestBase.stopSender( "ln" ));
+
+    vm4.invoke(() -> WANTestBase.startSender( "ln" ));
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 110 ));
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
   }
   
+  private void validateQueueClosedVM4() {
+    // TODO Auto-generated method stub
+    
+  }
+
+  private void validateQueueContents(VM vm, String site, int size) {
+    vm.invoke(() -> WANTestBase.validateQueueContents( site,
+        size ));
+  }
+
   /**
    * Destroy SerialGatewaySender on all the nodes.
    */
   public void testDestroySerialGatewaySenderOnAllNodes() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
     
     //before destroying, stop the sender
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
+    vm5.invoke(() -> WANTestBase.stopSender( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "removeSenderFromTheRegion", new Object[] { "ln", testName + "_RR" });
-    vm5.invoke(WANTestBase.class, "removeSenderFromTheRegion", new Object[] { "ln", testName + "_RR" });
+    vm4.invoke(() -> WANTestBase.removeSenderFromTheRegion( "ln", testName + "_RR" ));
+    vm5.invoke(() -> WANTestBase.removeSenderFromTheRegion( "ln", testName + "_RR" ));
 
-    vm4.invoke(WANTestBase.class, "destroySender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "destroySender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.destroySender( "ln" ));
+    vm5.invoke(() -> WANTestBase.destroySender( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "verifySenderDestroyed", new Object[] { "ln", false });
-    vm5.invoke(WANTestBase.class, "verifySenderDestroyed", new Object[] { "ln", false });
+    vm4.invoke(() -> WANTestBase.verifySenderDestroyed( "ln", false ));
+    vm5.invoke(() -> WANTestBase.verifySenderDestroyed( "ln", false ));
   }
 
   /**
    * Destroy SerialGatewaySender on a single node.
    */
   public void testDestroySerialGatewaySenderOnSingleNode() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
     
     //before destroying, stop the sender
-    vm4.invoke(WANTestBase.class, "stopSender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.stopSender( "ln" ));
         
-    vm4.invoke(WANTestBase.class, "removeSenderFromTheRegion", new Object[] { "ln", testName + "_RR" });
+    vm4.invoke(() -> WANTestBase.removeSenderFromTheRegion( "ln", testName + "_RR" ));
     
-    vm4.invoke(WANTestBase.class, "destroySender", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.destroySender( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "verifySenderDestroyed", new Object[] { "ln", false });
-    vm5.invoke(WANTestBase.class, "verifySenderRunningState", new Object[] { "ln" });
+    vm4.invoke(() -> WANTestBase.verifySenderDestroyed( "ln", false ));
+    vm5.invoke(() -> WANTestBase.verifySenderRunningState( "ln" ));
   }
   
   /**
@@ -626,56 +518,37 @@ public class SerialGatewaySenderOperationsDUnitTest extends WANTestBase {
    * Hence, exception is thrown by the sender API.
    */
   public void testDestroySerialGatewaySenderExceptionScenario() {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] { lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        false, 100, 10, false, true, null, true });
-
-    vm2.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", null, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createReplicatedRegion", new Object[] {
-        testName + "_RR", "ln", isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_RR",
-        1000 });
+    Integer lnPort = (Integer)vm0.invoke(() -> WANTestBase.createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() -> WANTestBase.createFirstRemoteLocator( 2, lnPort ));
+
+    createReceivers(nyPort);
+
+    createSenderCaches(lnPort);
+
+    createSenderVM4();
+    createSenderVM5();
+
+    createReceiverRegions();
+
+    createSenderRegions();
+
+    startSenders();
+
+    vm4.invoke(() -> WANTestBase.doPuts( testName + "_RR",
+        10 ));
     
     try {
-      vm4.invoke(WANTestBase.class, "destroySender", new Object[] { "ln" });
+      vm4.invoke(() -> WANTestBase.destroySender( "ln" ));
     } catch (RMIException e) {
       assertTrue("Cause of the exception should be GatewaySenderException", e.getCause() instanceof GatewaySenderException);
     }
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName + "_RR", 1000 });
+    vm2.invoke(() -> WANTestBase.validateRegionSize(
+        testName + "_RR", 10 ));
   }
   
   public static void verifySenderPausedState(String senderId) {
     Set<GatewaySender> senders = cache.getGatewaySenders();
-    GatewaySender sender = null;
+    AbstractGatewaySender sender = null;
     for (GatewaySender s : senders) {
       if (s.getId().equals(senderId)) {
         sender = (AbstractGatewaySender)s;


[32/52] [abbrv] incubator-geode git commit: GEODE-858: Remove 1 second sleep from InternalLocator.startTcpServer

Posted by ds...@apache.org.
GEODE-858: Remove 1 second sleep from InternalLocator.startTcpServer

There is no reason for this sleep, it is causing tests to take longer.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/1ccf2266
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/1ccf2266
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/1ccf2266

Branch: refs/heads/feature/GEODE-831
Commit: 1ccf22662d61db9dafc2a21260c3fe9a856ad172
Parents: 30d2d64
Author: Dan Smith <up...@apache.org>
Authored: Mon Jan 25 16:50:36 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 17:01:37 2016 -0800

----------------------------------------------------------------------
 .../gemfire/distributed/internal/InternalLocator.java       | 9 ---------
 1 file changed, 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/1ccf2266/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
index 50a0fa9..c346a45 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
@@ -621,15 +621,6 @@ public class InternalLocator extends Locator implements ConnectListener {
   private void startTcpServer() throws IOException {
     logger.info(LocalizedMessage.create(LocalizedStrings.InternalLocator_STARTING_0, this));
     server.start();
-    
-    try { 
-      Thread.sleep(1000); 
-    } 
-    catch (InterruptedException ie) {
-      // always safe to exit this thread...
-      Thread.currentThread().interrupt();
-      logger.warn(LocalizedMessage.create(LocalizedStrings.ONE_ARG, "Interrupted"), ie);
-    }
   }
   
   public SharedConfiguration getSharedConfiguration() {


[12/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
index cfda0bd..3e69990 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
@@ -44,11 +44,10 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author shobhit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexOperationsOnOverflowRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexOperationsOnOverflowRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexOperationsOnOverflowRegionDUnitTest.java
index 2005f0c..e999787 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexOperationsOnOverflowRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexOperationsOnOverflowRegionDUnitTest.java
@@ -44,11 +44,10 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator.TestHook;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test creates a persistent-overflow region and performs updates in region

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
index 80656e0..d0b0c30 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
@@ -41,11 +41,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
 import com.gemstone.gemfire.internal.cache.Token;
 import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test is similar to {@link ConcurrentIndexUpdateWithoutWLDUnitTest} except

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
index 6d4a6b4..5f52042 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
@@ -42,11 +42,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
 import com.gemstone.gemfire.internal.cache.Token;
 import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/CopyOnReadIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/CopyOnReadIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/CopyOnReadIndexDUnitTest.java
index 63be4a6..a176ee7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/CopyOnReadIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/CopyOnReadIndexDUnitTest.java
@@ -42,12 +42,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class CopyOnReadIndexDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexCreationInternalsJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexCreationInternalsJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexCreationInternalsJUnitTest.java
index e6a8c06..3f23810 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexCreationInternalsJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexCreationInternalsJUnitTest.java
@@ -45,10 +45,9 @@ import com.gemstone.gemfire.cache.query.internal.CompiledRegion;
 import com.gemstone.gemfire.cache.query.internal.QCompiler;
 import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  *
  * @author ericz

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
index dcb38f1..9b9b1f7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexMaintainceJUnitTest.java
@@ -51,10 +51,9 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.functional.StructSetOrResultsSet;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverAdapter;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * 
  * @author vaibhav

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
index 8ccdf84..f12df85 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/IndexTrackingQueryObserverDUnitTest.java
@@ -42,11 +42,10 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator.TestHook;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author shobhit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/InitializeIndexEntryDestroyQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/InitializeIndexEntryDestroyQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/InitializeIndexEntryDestroyQueryDUnitTest.java
index 10170d4..6b07d48 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/InitializeIndexEntryDestroyQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/InitializeIndexEntryDestroyQueryDUnitTest.java
@@ -34,11 +34,10 @@ import com.gemstone.gemfire.cache.query.internal.Undefined;
 import com.gemstone.gemfire.cache.query.partitioned.PRQueryDUnitHelper;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test creates a local region. Creates and removes index in a parallel running thread.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MultiIndexCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MultiIndexCreationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MultiIndexCreationDUnitTest.java
index 3acbfd6..a81078a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MultiIndexCreationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MultiIndexCreationDUnitTest.java
@@ -30,12 +30,11 @@ import com.gemstone.gemfire.cache.query.internal.QueryObserverAdapter;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
 import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class MultiIndexCreationDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
index 4a5c46a..040a671 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/PutAllWithIndexPerfDUnitTest.java
@@ -39,11 +39,10 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
-import dunit.Host;
-import dunit.VM;
-
 /**
  * @author shobhit
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDUnitTest.java
index 1db6398..a72dec2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDUnitTest.java
@@ -25,12 +25,11 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author rdubey

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
index 1fb19d8..07345b4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicIndexCreationDeadlockDUnitTest.java
@@ -29,12 +29,11 @@ import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author rdubey

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicMultiIndexCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicMultiIndexCreationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicMultiIndexCreationDUnitTest.java
index 053bae6..2326709 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicMultiIndexCreationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicMultiIndexCreationDUnitTest.java
@@ -26,11 +26,10 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 public class PRBasicMultiIndexCreationDUnitTest extends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicQueryDUnitTest.java
index d4554dd..50cf97e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicQueryDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This tests creates partition regions with 1 Datastore & 1 Accessor node, 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicRemoveIndexDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicRemoveIndexDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicRemoveIndexDUnitTest.java
index ed644cc..f0c927e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicRemoveIndexDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRBasicRemoveIndexDUnitTest.java
@@ -18,9 +18,8 @@ package com.gemstone.gemfire.cache.query.partitioned;
 
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Basic funtional test for removing index from a partitioned region system.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRColocatedEquiJoinDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRColocatedEquiJoinDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRColocatedEquiJoinDUnitTest.java
index bae5f96..c812e72 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRColocatedEquiJoinDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRColocatedEquiJoinDUnitTest.java
@@ -53,9 +53,8 @@ import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author shobhit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRInvalidQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRInvalidQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRInvalidQueryDUnitTest.java
index bcff432..2028ff7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRInvalidQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRInvalidQueryDUnitTest.java
@@ -24,9 +24,8 @@ package com.gemstone.gemfire.cache.query.partitioned;
 
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRInvalidQueryDUnitTest extends PartitionedRegionDUnitTestCase
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheCloseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheCloseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheCloseDUnitTest.java
index 3a2da05..dd12b21 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheCloseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheCloseDUnitTest.java
@@ -34,11 +34,10 @@ import java.util.Random;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRQueryCacheCloseDUnitTest extends PartitionedRegionDUnitTestCase
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
index 68a067e..6a546b1 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.query.RegionNotFoundException;
 import com.gemstone.gemfire.cache.query.SelectResults;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Test verifies Region#query()for PartitionedRegion on a single VM with
  * Region#destroyRegion() being called on the same with some delay.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
index bcd79a6..331a05f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
@@ -86,10 +86,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.SerializableRunnable;
-
 /**
  * This is a helper class for the various Partitioned Query DUnit Test Cases
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitTest.java
index b47a029..9912f08 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitTest.java
@@ -46,10 +46,9 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRQueryDUnitTest extends PartitionedRegionDUnitTestCase
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryPerfDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryPerfDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryPerfDUnitTest.java
index 9d444d7..069ea52 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryPerfDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryPerfDUnitTest.java
@@ -21,9 +21,8 @@ import java.io.Serializable;
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *This tests executes an array of queries to be executed over the PR ,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionCloseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionCloseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionCloseDUnitTest.java
index bdca4fc..56a643c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionCloseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionCloseDUnitTest.java
@@ -32,13 +32,12 @@ import java.util.Random;
 
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 public class PRQueryRegionCloseDUnitTest extends PartitionedRegionDUnitTestCase
 {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedDUnitTest.java
index 0fcb69e..3401d27 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedDUnitTest.java
@@ -32,13 +32,12 @@ import java.util.Random;
 
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 public class PRQueryRegionDestroyedDUnitTest extends PartitionedRegionDUnitTestCase
 {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
index 9a841a3..95d846e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.query.RegionNotFoundException;
 import com.gemstone.gemfire.cache.query.SelectResults;
 import com.gemstone.gemfire.cache.query.data.PortfolioData;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Test verifies Region#query()for PartitionedRegion on a single VM with
  * Region#destroyRegion() being called on the same with some delay.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRemoteNodeExceptionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRemoteNodeExceptionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRemoteNodeExceptionDUnitTest.java
index 8904e4c..830d35b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRemoteNodeExceptionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRemoteNodeExceptionDUnitTest.java
@@ -41,12 +41,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
 import com.gemstone.gemfire.internal.cache.BucketRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /**
  * This test verifies exception handling on coordinator node for remote as

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/ParallelSnapshotDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/ParallelSnapshotDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/ParallelSnapshotDUnitTest.java
index 8e2aad2..ea1195e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/ParallelSnapshotDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/ParallelSnapshotDUnitTest.java
@@ -31,10 +31,9 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.internal.cache.snapshot.SnapshotFileMapper;
 import com.gemstone.gemfire.internal.cache.snapshot.SnapshotOptionsImpl;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ParallelSnapshotDUnitTest extends CacheTestCase {
   static byte[] ffff = new byte[] { 0xf, 0xf, 0xf, 0xf };

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotByteArrayDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotByteArrayDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotByteArrayDUnitTest.java
index f564e15..e43d39b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotByteArrayDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotByteArrayDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.cache.snapshot.RegionGenerator.RegionType;
 import com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class SnapshotByteArrayDUnitTest extends CacheTestCase {
   private final File snap = new File("snapshot-ops");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotDUnitTest.java
index 1e5120c..764f276 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotDUnitTest.java
@@ -36,9 +36,8 @@ import com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class SnapshotDUnitTest extends CacheTestCase {
   public SnapshotDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotPerformanceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotPerformanceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotPerformanceDUnitTest.java
index 93d8596..309363e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotPerformanceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/snapshot/SnapshotPerformanceDUnitTest.java
@@ -30,9 +30,8 @@ import com.gemstone.gemfire.cache.snapshot.RegionGenerator.RegionType;
 import com.gemstone.gemfire.cache.snapshot.RegionGenerator.SerializationType;
 import com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class SnapshotPerformanceDUnitTest extends CacheTestCase {
   public SnapshotPerformanceDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34387DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34387DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34387DUnitTest.java
index b0c4366..9c35b1b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34387DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34387DUnitTest.java
@@ -16,13 +16,22 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
 /**
  * Test create + localDestroy for bug 34387
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34948DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34948DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34948DUnitTest.java
index e2eef8e..eb55ce2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34948DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug34948DUnitTest.java
@@ -16,13 +16,25 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-import java.io.*;
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+
+import com.gemstone.gemfire.DataSerializable;
+import com.gemstone.gemfire.DataSerializer;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to make sure cache values are lazily deserialized

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug35214DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug35214DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug35214DUnitTest.java
index a1f76d8..04b214f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug35214DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug35214DUnitTest.java
@@ -17,10 +17,23 @@
 package com.gemstone.gemfire.cache30;
 
 import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.ExpirationAction;
+import com.gemstone.gemfire.cache.ExpirationAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * Make sure entry expiration does not happen during gii for bug 35214
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38013DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38013DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38013DUnitTest.java
index 91032c7..a7595c7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38013DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38013DUnitTest.java
@@ -16,13 +16,24 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-import java.io.*;
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+
+import com.gemstone.gemfire.DataSerializable;
+import com.gemstone.gemfire.DataSerializer;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to make sure PR cache values are lazily deserialized

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38741DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38741DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38741DUnitTest.java
index b344755..417456f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38741DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/Bug38741DUnitTest.java
@@ -50,10 +50,9 @@ import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessageImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheCloseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheCloseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheCloseDUnitTest.java
index c4b2a6b..1938483 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheCloseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheCloseDUnitTest.java
@@ -16,12 +16,16 @@
  */
 package com.gemstone.gemfire.cache30;
 
-//import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.cache.util.*;
-//import com.gemstone.gemfire.distributed.DistributedSystem;
-//import dunit.*;
-import java.util.*;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
 
 /**
  * Test to make sure cache close is working.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLoaderTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLoaderTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLoaderTestCase.java
index 54b9611..fc23365 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLoaderTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLoaderTestCase.java
@@ -16,10 +16,16 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.cache.util.*;
-//import java.util.*;
-//import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheWriterException;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.TimeoutException;
 
 /**
  * An abstract class whose test methods test the functionality of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheMapTxnDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheMapTxnDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheMapTxnDUnitTest.java
index 9e00eef..588ec7e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheMapTxnDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheMapTxnDUnitTest.java
@@ -20,21 +20,25 @@
  *
  * Created on August 9, 2005, 11:18 AM
  */
-
 package com.gemstone.gemfire.cache30;
 
-/**
- *
- * @author  prafulla
- */
-
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-
-import java.util.*;
+import java.util.Properties;
+import java.util.Set;
 
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+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.UnsupportedOperationInTransactionException;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CacheMapTxnDUnitTest extends DistributedTestCase{
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheRegionsReliablityStatsCheckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheRegionsReliablityStatsCheckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheRegionsReliablityStatsCheckDUnitTest.java
index 0ce4761..3834f83 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheRegionsReliablityStatsCheckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheRegionsReliablityStatsCheckDUnitTest.java
@@ -32,10 +32,9 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.CachePerfStats;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CacheRegionsReliablityStatsCheckDUnitTest extends CacheTestCase {
 	public CacheRegionsReliablityStatsCheckDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheSerializableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheSerializableRunnable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheSerializableRunnable.java
index d2aaa19..8b80def 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheSerializableRunnable.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheSerializableRunnable.java
@@ -16,10 +16,12 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheRuntimeException;
+import com.gemstone.gemfire.test.dunit.RepeatableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
-import util.TestException;
-import dunit.*;
 import junit.framework.AssertionFailedError;
 
 /**
@@ -81,7 +83,7 @@ public abstract class CacheSerializableRunnable
         try {
           Thread.sleep(50);
         } catch (InterruptedException ex) {
-          throw new TestException("interrupted", ex);
+          throw new RuntimeException("interrupted", ex);
         }
       }
     } while (lastErr != null && System.currentTimeMillis() - start < repeatTimeoutMs);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheStatisticsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheStatisticsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheStatisticsDUnitTest.java
index 71b3a80..a07a749 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheStatisticsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheStatisticsDUnitTest.java
@@ -16,10 +16,17 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheStatistics;
+import com.gemstone.gemfire.cache.EntryDestroyedException;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.StatisticsDisabledException;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the {@link CacheStatistics} that are maintained by a {@link

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheTestCase.java
index a627620..7f32a46 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheTestCase.java
@@ -54,10 +54,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
 import com.gemstone.gemfire.internal.logging.LogService;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * The abstract superclass of tests that require the creation of a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml30DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml30DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml30DUnitTest.java
index 5c07546..6df49b2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml30DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml30DUnitTest.java
@@ -61,10 +61,9 @@ import com.gemstone.gemfire.internal.cache.xmlcache.ClientCacheCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionCreation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.DistributedTestCase;
-
 /**
  * Tests the functionality of loading a declarative caching file when
  * a <code>Cache</code> is {@link CacheFactory#create created}.  The

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
index 2e9f9cc..f6a0aa2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
@@ -19,11 +19,15 @@ package com.gemstone.gemfire.cache30;
 import com.gemstone.gemfire.cache.*;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.internal.cache.xmlcache.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 import java.io.*;
 
+<<<<<<< HEAD
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import dunit.DistributedTestCase;
+=======
+>>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
 import org.xml.sax.SAXException;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml45DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml45DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml45DUnitTest.java
index 8425d79..30284a4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml45DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml45DUnitTest.java
@@ -22,10 +22,9 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.xmlcache.*;
-
-import dunit.Host;
-import dunit.DistributedTestCase;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.*;
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml51DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml51DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml51DUnitTest.java
index a013780..00d2fd5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml51DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml51DUnitTest.java
@@ -23,9 +23,8 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.DiskWriteAttributesImpl;
 import com.gemstone.gemfire.internal.cache.xmlcache.*;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the declarative caching functionality introduced in the GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
index 6e5bf09..06ae560 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
@@ -52,11 +52,17 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionCreation;
+<<<<<<< HEAD
 
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import dunit.Host;
 import dunit.SerializableCallable;
 import dunit.VM;
+=======
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
+>>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
 
 import junit.framework.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
index ac78127..c54af3d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
@@ -31,9 +31,13 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.ResourceManagerCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.SerializerCreation;
+<<<<<<< HEAD
 
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import dunit.DistributedTestCase;
+=======
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+>>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml61DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml61DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml61DUnitTest.java
index 252dbab..f462025 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml61DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml61DUnitTest.java
@@ -39,9 +39,8 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.ResourceManagerCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.SerializerCreation;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml81DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml81DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml81DUnitTest.java
index 831875a..ac2e2ba 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml81DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml81DUnitTest.java
@@ -16,7 +16,6 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import dunit.DistributedTestCase;
 import org.junit.Rule;
 import org.junit.Test;
 import org.xml.sax.Locator;
@@ -32,6 +31,7 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.XmlParser;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 /**
  * Tests 8.1 schema based configuration. From this point all config test cases

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CachedAllEventsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CachedAllEventsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CachedAllEventsDUnitTest.java
index 5a8a7f7..c0a1fc4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CachedAllEventsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CachedAllEventsDUnitTest.java
@@ -16,10 +16,18 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.InterestPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.SubscriptionAttributes;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * Make sure that create are distributed and done in
  * remote regions that are CACHED_ALL_EVENTS*.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CallbackArgDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CallbackArgDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CallbackArgDUnitTest.java
index 1b0a4ff..49e38c0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CallbackArgDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CallbackArgDUnitTest.java
@@ -16,12 +16,29 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import java.util.*;
-import dunit.*;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Iterator;
+import java.util.List;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TransactionEvent;
+import com.gemstone.gemfire.cache.TransactionListener;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.cache.util.TransactionListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * Test the getCallbackArgument in light of bug 34075.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CertifiableTestCacheListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CertifiableTestCacheListener.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CertifiableTestCacheListener.java
index 438b083..c1f53c7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CertifiableTestCacheListener.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CertifiableTestCacheListener.java
@@ -26,9 +26,8 @@ import java.util.*;
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.cache.EntryEvent;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 public class CertifiableTestCacheListener extends TestCacheListener implements Declarable2 {
   final public Set destroys = Collections.synchronizedSet(new HashSet());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmCallBkDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmCallBkDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmCallBkDUnitTest.java
index 18df006..849768a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmCallBkDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmCallBkDUnitTest.java
@@ -20,24 +20,29 @@
  *
  * Created on August 11, 2005, 7:37 PM
  */
+package com.gemstone.gemfire.cache30;
 
+import java.util.Properties;
 
-package com.gemstone.gemfire.cache30;
+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.CacheTransactionManager;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *
  * @author  prafulla/vjadhav
  */
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-
-import java.util.*;
-
-import com.gemstone.gemfire.distributed.DistributedSystem;
-
-
 public class ClearMultiVmCallBkDUnitTest extends DistributedTestCase{
     
     /** Creates a new instance of ClearMultiVmCallBkDUnitTest */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmDUnitTest.java
index 8e0f12b..5a87127 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClearMultiVmDUnitTest.java
@@ -20,25 +20,32 @@
  *
  * Created on August 11, 2005, 7:37 PM
  */
-
 package com.gemstone.gemfire.cache30;
 
+import java.util.Properties;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionDestroyedException;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  *
  * @author  prafulla
  */
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-
-import java.util.*;
-
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.TXStateProxy;
-
-//import com.gemstone.gemfire.cache30.*;
-
 public class ClearMultiVmDUnitTest extends DistributedTestCase{
     
     /** Creates a new instance of ClearMultiVmDUnitTest */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientMembershipDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientMembershipDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientMembershipDUnitTest.java
index 76b5b75..5589453 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientMembershipDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientMembershipDUnitTest.java
@@ -53,12 +53,11 @@ import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.management.membership.ClientMembership;
 import com.gemstone.gemfire.management.membership.ClientMembershipEvent;
 import com.gemstone.gemfire.management.membership.ClientMembershipListener;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /**
  * Tests the ClientMembership API including ClientMembershipListener.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientRegisterInterestDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientRegisterInterestDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientRegisterInterestDUnitTest.java
index d2c610d..958b863 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientRegisterInterestDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientRegisterInterestDUnitTest.java
@@ -25,12 +25,11 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.SubscriptionNotEnabledException;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Tests the client register interest
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerCCEDUnitTest.java
index 784d0c8..181fea7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerCCEDUnitTest.java
@@ -44,11 +44,10 @@ import com.gemstone.gemfire.internal.cache.TombstoneService;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * concurrency-control tests for client/server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerTestCase.java
index c03f2d0..6a3c5e0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ClientServerTestCase.java
@@ -35,8 +35,7 @@ import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Provides helper methods for testing clients and servers. This

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
index b5e4170..9ec99a2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ConcurrentLeaveDuringGIIDUnitTest.java
@@ -24,15 +24,14 @@ import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation;
 import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHook;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHookType;
+import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIITestHookType;
+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.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.RegionMap;
 
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 public class ConcurrentLeaveDuringGIIDUnitTest extends CacheTestCase {
 
   public ConcurrentLeaveDuringGIIDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionDUnitTest.java
index dc1d849..6247ee1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionDUnitTest.java
@@ -16,19 +16,42 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-
+import java.io.File;
+import java.lang.reflect.Array;
+import java.util.BitSet;
+import java.util.Collection;
+import java.util.Iterator;
+import java.util.Set;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.DiskStore;
+import com.gemstone.gemfire.cache.DiskStoreFactory;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.EntryNotFoundException;
+import com.gemstone.gemfire.cache.EvictionAction;
+import com.gemstone.gemfire.cache.EvictionAttributes;
+import com.gemstone.gemfire.cache.LoaderHelper;
+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.internal.OSProcess;
-import com.gemstone.gemfire.internal.cache.*;
+import com.gemstone.gemfire.internal.cache.CachedDeserializable;
+import com.gemstone.gemfire.internal.cache.DiskRegion;
+import com.gemstone.gemfire.internal.cache.DiskRegionStats;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.internal.cache.lru.LRUCapacityController;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.*;
-
-import java.util.*;
-import java.io.*;
-import java.lang.reflect.Array;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests the functionality of cache regions whose contents may be

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionTestImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionTestImpl.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionTestImpl.java
index 77d8f70..974bebb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionTestImpl.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DiskRegionTestImpl.java
@@ -16,11 +16,20 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import junit.framework.Assert;
-import dunit.*;
-import java.util.*;
+import static org.junit.Assert.*;
+
 import java.io.Serializable;
-import com.gemstone.gemfire.cache.*;
+import java.util.Arrays;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryNotFoundException;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * An instance of this class is delegated to by test classes that test
@@ -29,7 +38,7 @@ import com.gemstone.gemfire.cache.*;
  * @author Eric Zoerner
  *
  */
-public class DiskRegionTestImpl extends Assert  implements Serializable {
+public class DiskRegionTestImpl implements Serializable {
   
   final RegionTestCase rtc;
 



[19/52] [abbrv] incubator-geode git commit: Using System.nanoTime in RemoteDUnitVM

Posted by ds...@apache.org.
Using System.nanoTime in RemoteDUnitVM

This should be more efficient than System.currentTimeMillis.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/20d47eb4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/20d47eb4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/20d47eb4

Branch: refs/heads/feature/GEODE-831
Commit: 20d47eb4104b558e5fae0b10ca21673f7b787f06
Parents: 68e9ec2
Author: Dan Smith <up...@apache.org>
Authored: Thu Jan 21 15:33:47 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Mon Jan 25 11:37:47 2016 -0800

----------------------------------------------------------------------
 .../test/dunit/standalone/RemoteDUnitVM.java    | 41 ++++++++++----------
 1 file changed, 21 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/20d47eb4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/RemoteDUnitVM.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/RemoteDUnitVM.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/RemoteDUnitVM.java
index 51c6177..6d016bc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/RemoteDUnitVM.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/RemoteDUnitVM.java
@@ -18,6 +18,7 @@ package com.gemstone.gemfire.test.dunit.standalone;
 
 import java.rmi.RemoteException;
 import java.rmi.server.UnicastRemoteObject;
+import java.util.concurrent.TimeUnit;
 
 import org.apache.logging.log4j.Logger;
 
@@ -50,15 +51,24 @@ public class RemoteDUnitVM extends UnicastRemoteObject implements RemoteDUnitVMI
    public MethExecutorResult executeMethodOnObject( Object obj, String methodName ) {
      String name = obj.getClass().getName() + "." + methodName + 
        " on object: " + obj;
-     logger.info("Received method: " + name);
-     long start = System.currentTimeMillis();
+     long start = start(name);
      MethExecutorResult result = MethExecutor.executeObject( obj, methodName );
-     long delta = System.currentTimeMillis() - start;
-     logger.info( "Got result: " + result.toString().trim()  + " from " +
-               name + " (took " + delta + " ms)");
+     logDelta(name, start, result);
      return result;
    }
 
+  protected long start(String name) {
+    logger.info("Received method: " + name);
+    long start = System.nanoTime();
+    return start;
+  }
+
+  protected void logDelta(String name, long start, MethExecutorResult result) {
+    long delta = TimeUnit.NANOSECONDS.toMillis(System.nanoTime() - start);
+     logger.info( "Got result: " + result.toString() + " from " + name + 
+               " (took " + delta + " ms)");
+  }
+
    /**
     * Executes a given instance method on a given object with the given
     * arguments. 
@@ -69,13 +79,10 @@ public class RemoteDUnitVM extends UnicastRemoteObject implements RemoteDUnitVMI
      String name = obj.getClass().getName() + "." + methodName + 
               (args != null ? " with " + args.length + " args": "") +
        " on object: " + obj;
-     logger.info("Received method: " + name);
-     long start = System.currentTimeMillis();
+     long start = start(name);
      MethExecutorResult result = 
        MethExecutor.executeObject(obj, methodName, args);
-     long delta = System.currentTimeMillis() - start;
-     logger.info( "Got result: " + result.toString() + " from " + name + 
-               " (took " + delta + " ms)");
+     logDelta(name, start, result);
      return result;
    }
 
@@ -90,12 +97,9 @@ public class RemoteDUnitVM extends UnicastRemoteObject implements RemoteDUnitVMI
    */ 
    public MethExecutorResult executeMethodOnClass( String className, String methodName ) {
      String name = className + "." + methodName;
-     logger.info("Received method: " +  name);
-     long start = System.currentTimeMillis();
+     long start = start(name);
      MethExecutorResult result = MethExecutor.execute( className, methodName );
-     long delta = System.currentTimeMillis() - start;
-     logger.info( "Got result: " + result.toString() + " from " + name + 
-               " (took " + delta + " ms)");
+     logDelta(name, start, result);
      
      return result;
    }
@@ -109,13 +113,10 @@ public class RemoteDUnitVM extends UnicastRemoteObject implements RemoteDUnitVMI
                                                   Object[] args) {
      String name = className + "." + methodName + 
        (args != null ? " with " + args.length + " args": "");
-     logger.info("Received method: " + name);
-     long start = System.currentTimeMillis();
+     long start = start(name);
      MethExecutorResult result = 
        MethExecutor.execute(className, methodName, args);
-     long delta = System.currentTimeMillis() - start;
-     logger.info( "Got result: " + result.toString() + " from " + name +
-               " (took " + delta + " ms)");
+     logDelta(name, start, result);
      return result;
    }
 


[02/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/DistributedTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/DistributedTestCase.java b/gemfire-core/src/test/java/dunit/DistributedTestCase.java
deleted file mode 100755
index e89f694..0000000
--- a/gemfire-core/src/test/java/dunit/DistributedTestCase.java
+++ /dev/null
@@ -1,1438 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.io.File;
-import java.io.PrintWriter;
-import java.io.Serializable;
-import java.io.StringWriter;
-import java.net.UnknownHostException;
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.LinkedHashSet;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-import java.util.Random;
-import java.util.concurrent.ConcurrentLinkedQueue;
-
-import org.apache.logging.log4j.LogManager;
-import org.apache.logging.log4j.Logger;
-import org.junit.experimental.categories.Category;
-import org.springframework.data.gemfire.support.GemfireCache;
-
-import junit.framework.TestCase;
-
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.DiskStoreFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.hdfs.internal.HDFSStoreImpl;
-import com.gemstone.gemfire.cache.hdfs.internal.hoplog.HoplogConfig;
-import com.gemstone.gemfire.cache.query.QueryTestUtils;
-import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
-import com.gemstone.gemfire.cache30.ClientServerTestCase;
-import com.gemstone.gemfire.cache30.GlobalLockingDUnitTest;
-import com.gemstone.gemfire.cache30.MultiVMRegionTestCase;
-import com.gemstone.gemfire.cache30.RegionTestCase;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.CreationStackGenerator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManagerHelper;
-import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.ClientStatsManager;
-import com.gemstone.gemfire.internal.cache.DiskStoreObserver;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.HARegion;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.tier.InternalClientMembership;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.DataSerializerPropogationDUnitTest;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LocalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
-import com.gemstone.gemfire.internal.logging.ManagerLogWriter;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
-import com.gemstone.gemfire.management.internal.cli.LogWrapper;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher;
-
-/**
- * This class is the superclass of all distributed unit tests.
- * 
- * tests/hydra/JUnitTestTask is the main DUnit driver. It supports two 
- * additional public static methods if they are defined in the test case:
- * 
- * public static void caseSetUp() -- comparable to JUnit's BeforeClass annotation
- * 
- * public static void caseTearDown() -- comparable to JUnit's AfterClass annotation
- *
- * @author David Whitlock
- */
-@Category(DistributedTest.class)
-@SuppressWarnings("serial")
-public abstract class DistributedTestCase extends TestCase implements java.io.Serializable {
-  private static final Logger logger = LogService.getLogger();
-  private static final LogWriterLogger oldLogger = LogWriterLogger.create(logger);
-  private static final LinkedHashSet<String> testHistory = new LinkedHashSet<String>();
-
-  private static void setUpCreationStackGenerator() {
-    // the following is moved from InternalDistributedSystem to fix #51058
-    InternalDistributedSystem.TEST_CREATION_STACK_GENERATOR.set(
-    new CreationStackGenerator() {
-      @Override
-      public Throwable generateCreationStack(final DistributionConfig config) {
-        final StringBuilder sb = new StringBuilder();
-        final String[] validAttributeNames = config.getAttributeNames();
-        for (int i = 0; i < validAttributeNames.length; i++) {
-          final String attName = validAttributeNames[i];
-          final Object actualAtt = config.getAttributeObject(attName);
-          String actualAttStr = actualAtt.toString();
-          sb.append("  ");
-          sb.append(attName);
-          sb.append("=\"");
-          if (actualAtt.getClass().isArray()) {
-            actualAttStr = InternalDistributedSystem.arrayToString(actualAtt);
-          }
-          sb.append(actualAttStr);
-          sb.append("\"");
-          sb.append("\n");
-        }
-        return new Throwable("Creating distributed system with the following configuration:\n" + sb.toString());
-      }
-    });
-  }
-  
-  private static void tearDownCreationStackGenerator() {
-    InternalDistributedSystem.TEST_CREATION_STACK_GENERATOR.set(InternalDistributedSystem.DEFAULT_CREATION_STACK_GENERATOR);
-  }
-  
-  /** This VM's connection to the distributed system */
-  public static InternalDistributedSystem system;
-  private static Class lastSystemCreatedInTest;
-  private static Properties lastSystemProperties;
-  public static volatile String testName;
-  
-  private static ConcurrentLinkedQueue<ExpectedException> expectedExceptions = new ConcurrentLinkedQueue<ExpectedException>();
-
-  /** For formatting timing info */
-  private static final DecimalFormat format = new DecimalFormat("###.###");
-
-  public static boolean reconnect = false;
-
-  public static final boolean logPerTest = Boolean.getBoolean("dunitLogPerTest");
-
-  ///////////////////////  Utility Methods  ///////////////////////
-  
-  public void attachDebugger(VM vm, final String msg) {
-    vm.invoke(new SerializableRunnable("Attach Debugger") {
-      public void run() {
-        com.gemstone.gemfire.internal.util.DebuggerSupport.
-        waitForJavaDebugger(getSystem().getLogWriter().convertToLogWriterI18n(), msg);
-      } 
-    });
-  }
-
-
-  /**
-   * Invokes a <code>SerializableRunnable</code> in every VM that
-   * DUnit knows about.
-   *
-   * @see VM#invoke(Runnable)
-   */
-  public static void invokeInEveryVM(SerializableRunnable work) {
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-
-      for (int v = 0; v < host.getVMCount(); v++) {
-        VM vm = host.getVM(v);
-        vm.invoke(work);
-      }
-    }
-  }
-
-  public static void invokeInLocator(SerializableRunnable work) {
-    Host.getLocator().invoke(work);
-  }
-  
-  /**
-   * Invokes a <code>SerializableCallable</code> in every VM that
-   * DUnit knows about.
-   *
-   * @return a Map of results, where the key is the VM and the value is the result
-   * @see VM#invoke(Callable)
-   */
-  protected static Map invokeInEveryVM(SerializableCallable work) {
-    HashMap ret = new HashMap();
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-      for (int v = 0; v < host.getVMCount(); v++) {
-        VM vm = host.getVM(v);
-        ret.put(vm, vm.invoke(work));
-      }
-    }
-    return ret;
-  }
-
-  /**
-   * Invokes a method in every remote VM that DUnit knows about.
-   *
-   * @see VM#invoke(Class, String)
-   */
-  protected static void invokeInEveryVM(Class c, String method) {
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-
-      for (int v = 0; v < host.getVMCount(); v++) {
-        VM vm = host.getVM(v);
-        vm.invoke(c, method);
-      }
-    }
-  }
-
-  /**
-   * Invokes a method in every remote VM that DUnit knows about.
-   *
-   * @see VM#invoke(Class, String)
-   */
-  protected static void invokeInEveryVM(Class c, String method, Object[] methodArgs) {
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-
-      for (int v = 0; v < host.getVMCount(); v++) {
-        VM vm = host.getVM(v);
-        vm.invoke(c, method, methodArgs);
-      }
-    }
-  }
-  
-  /**
-   * The number of milliseconds to try repeating validation code in the
-   * event that AssertionFailedError is thrown.  For ACK scopes, no
-   * repeat should be necessary.
-   */
-  protected long getRepeatTimeoutMs() {
-    return 0;
-  }
-  
-  protected void invokeRepeatingIfNecessary(VM vm, RepeatableRunnable task) {
-    vm.invokeRepeatingIfNecessary(task, getRepeatTimeoutMs());
-  }
-  
-  /**
-   * Invokes a <code>SerializableRunnable</code> in every VM that
-   * DUnit knows about.  If work.run() throws an assertion failure, 
-   * its execution is repeated, until no assertion failure occurs or
-   * repeatTimeout milliseconds have passed.
-   *
-   * @see VM#invoke(Runnable)
-   */
-  protected void invokeInEveryVMRepeatingIfNecessary(RepeatableRunnable work) {
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-
-      for (int v = 0; v < host.getVMCount(); v++) {
-        VM vm = host.getVM(v);
-        vm.invokeRepeatingIfNecessary(work, getRepeatTimeoutMs());
-      }
-    }
-  }
-
-  /** Return the total number of VMs on all hosts */
-  protected static int getVMCount() {
-    int count = 0;
-    for (int h = 0; h < Host.getHostCount(); h++) {
-      Host host = Host.getHost(h);
-      count += host.getVMCount();
-    }
-    return count;
-  }
-
-
-  /** print a stack dump for this vm
-      @author bruce
-      @since 5.0
-   */
-  public static void dumpStack() {
-    com.gemstone.gemfire.internal.OSProcess.printStacks(0, false);
-  }
-  
-  /** print a stack dump for the given vm
-      @author bruce
-      @since 5.0
-   */
-  public static void dumpStack(VM vm) {
-    vm.invoke(dunit.DistributedTestCase.class, "dumpStack");
-  }
-  
-  /** print stack dumps for all vms on the given host
-      @author bruce
-      @since 5.0
-   */
-  public static void dumpStack(Host host) {
-    for (int v=0; v < host.getVMCount(); v++) {
-      host.getVM(v).invoke(dunit.DistributedTestCase.class, "dumpStack");
-    }
-  }
-  
-  /** print stack dumps for all vms
-      @author bruce
-      @since 5.0
-   */
-  public static void dumpAllStacks() {
-    for (int h=0; h < Host.getHostCount(); h++) {
-      dumpStack(Host.getHost(h));
-    }
-  }
-
-
-  public static String noteTiming(long operations, String operationUnit,
-                                  long beginTime, long endTime,
-                                  String timeUnit)
-  {
-    long delta = endTime - beginTime;
-    StringBuffer sb = new StringBuffer();
-    sb.append("  Performed ");
-    sb.append(operations);
-    sb.append(" ");
-    sb.append(operationUnit);
-    sb.append(" in ");
-    sb.append(delta);
-    sb.append(" ");
-    sb.append(timeUnit);
-    sb.append("\n");
-
-    double ratio = ((double) operations) / ((double) delta);
-    sb.append("    ");
-    sb.append(format.format(ratio));
-    sb.append(" ");
-    sb.append(operationUnit);
-    sb.append(" per ");
-    sb.append(timeUnit);
-    sb.append("\n");
-
-    ratio = ((double) delta) / ((double) operations);
-    sb.append("    ");
-    sb.append(format.format(ratio));
-    sb.append(" ");
-    sb.append(timeUnit);
-    sb.append(" per ");
-    sb.append(operationUnit);
-    sb.append("\n");
-
-    return sb.toString();
-  }
-
-  /**
-   * Creates a new LogWriter and adds it to the config properties. The config
-   * can then be used to connect to DistributedSystem, thus providing early
-   * access to the LogWriter before connecting. This call does not connect
-   * to the DistributedSystem. It simply creates and returns the LogWriter
-   * that will eventually be used by the DistributedSystem that connects using
-   * config.
-   * 
-   * @param config the DistributedSystem config properties to add LogWriter to
-   * @return early access to the DistributedSystem LogWriter
-   */
-  protected static LogWriter createLogWriter(Properties config) { // TODO:LOG:CONVERT: this is being used for ExpectedExceptions
-    Properties nonDefault = config;
-    if (nonDefault == null) {
-      nonDefault = new Properties();
-    }
-    addHydraProperties(nonDefault);
-    
-    DistributionConfig dc = new DistributionConfigImpl(nonDefault);
-    LogWriter logger = LogWriterFactory.createLogWriterLogger(
-        false/*isLoner*/, false/*isSecurityLog*/, dc, 
-        false);        
-    
-    // if config was non-null, then these will be added to it...
-    nonDefault.put(DistributionConfig.LOG_WRITER_NAME, logger);
-    
-    return logger;
-  }
-  
-  /**
-   * Fetches the GemFireDescription for this test and adds its 
-   * DistributedSystem properties to the provided props parameter.
-   * 
-   * @param config the properties to add hydra's test properties to
-   */
-  protected static void addHydraProperties(Properties config) {
-    Properties p = DUnitEnv.get().getDistributedSystemProperties();
-    for (Iterator iter = p.entrySet().iterator();
-        iter.hasNext(); ) {
-      Map.Entry entry = (Map.Entry) iter.next();
-      String key = (String) entry.getKey();
-      String value = (String) entry.getValue();
-      if (config.getProperty(key) == null) {
-        config.setProperty(key, value);
-      }
-    }
-  }
-  
-  ////////////////////////  Constructors  ////////////////////////
-
-  /**
-   * Creates a new <code>DistributedTestCase</code> test with the
-   * given name.
-   */
-  public DistributedTestCase(String name) {
-    super(name);
-    DUnitLauncher.launchIfNeeded();
-  }
-
-  ///////////////////////  Instance Methods  ///////////////////////
-
-
-  protected Class getTestClass() {
-    Class clazz = getClass();
-    while (clazz.getDeclaringClass() != null) {
-      clazz = clazz.getDeclaringClass();
-    }
-    return clazz;
-  }
-  
-  
-  /**
-   * This finds the log level configured for the test run.  It should be used
-   * when creating a new distributed system if you want to specify a log level.
-   * @return the dunit log-level setting
-   */
-  public static String getDUnitLogLevel() {
-    Properties p = DUnitEnv.get().getDistributedSystemProperties();
-    String result = p.getProperty(DistributionConfig.LOG_LEVEL_NAME);
-    if (result == null) {
-      result = ManagerLogWriter.levelToString(DistributionConfig.DEFAULT_LOG_LEVEL);
-    }
-    return result;
-  }
-
-  public final static Properties getAllDistributedSystemProperties(Properties props) {
-    Properties p = DUnitEnv.get().getDistributedSystemProperties();
-    
-    // our tests do not expect auto-reconnect to be on by default
-    if (!p.contains(DistributionConfig.DISABLE_AUTO_RECONNECT_NAME)) {
-      p.put(DistributionConfig.DISABLE_AUTO_RECONNECT_NAME, "true");
-    }
-
-    for (Iterator iter = props.entrySet().iterator();
-    iter.hasNext(); ) {
-      Map.Entry entry = (Map.Entry) iter.next();
-      String key = (String) entry.getKey();
-      Object value = entry.getValue();
-      p.put(key, value);
-    }
-    return p;
-  }
-
-  public void setSystem(Properties props, DistributedSystem ds) {
-    system = (InternalDistributedSystem)ds;
-    lastSystemProperties = props;
-    lastSystemCreatedInTest = getTestClass();
-  }
-  /**
-   * Returns this VM's connection to the distributed system.  If
-   * necessary, the connection will be lazily created using the given
-   * <code>Properties</code>.  Note that this method uses hydra's
-   * configuration to determine the location of log files, etc.
-   * Note: "final" was removed so that WANTestBase can override this method.
-   * This was part of the xd offheap merge.
-   *
-   * @see hydra.DistributedConnectionMgr#connect
-   * @since 3.0
-   */
-  public /*final*/ InternalDistributedSystem getSystem(Properties props) {
-    // Setting the default disk store name is now done in setUp
-    if (system == null) {
-      system = InternalDistributedSystem.getAnyInstance();
-    }
-    if (system == null || !system.isConnected()) {
-      // Figure out our distributed system properties
-      Properties p = getAllDistributedSystemProperties(props);
-      lastSystemCreatedInTest = getTestClass();
-      if (logPerTest) {
-        String testMethod = getTestName();
-        String testName = lastSystemCreatedInTest.getName() + '-' + testMethod;
-        String oldLogFile = p.getProperty(DistributionConfig.LOG_FILE_NAME);
-        p.put(DistributionConfig.LOG_FILE_NAME, 
-            oldLogFile.replace("system.log", testName+".log"));
-        String oldStatFile = p.getProperty(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME);
-        p.put(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME, 
-            oldStatFile.replace("statArchive.gfs", testName+".gfs"));
-      }
-      system = (InternalDistributedSystem)DistributedSystem.connect(p);
-      lastSystemProperties = p;
-    } else {
-      boolean needNewSystem = false;
-      if(!getTestClass().equals(lastSystemCreatedInTest)) {
-        Properties newProps = getAllDistributedSystemProperties(props);
-        needNewSystem = !newProps.equals(lastSystemProperties);
-        if(needNewSystem) {
-          getLogWriter().info(
-              "Test class has changed and the new DS properties are not an exact match. "
-                  + "Forcing DS disconnect. Old props = "
-                  + lastSystemProperties + "new props=" + newProps);
-        }
-      } else {
-        Properties activeProps = system.getProperties();
-        for (Iterator iter = props.entrySet().iterator();
-        iter.hasNext(); ) {
-          Map.Entry entry = (Map.Entry) iter.next();
-          String key = (String) entry.getKey();
-          String value = (String) entry.getValue();
-          if (!value.equals(activeProps.getProperty(key))) {
-            needNewSystem = true;
-            getLogWriter().info("Forcing DS disconnect. For property " + key
-                                + " old value = " + activeProps.getProperty(key)
-                                + " new value = " + value);
-            break;
-          }
-        }
-      }
-      if(needNewSystem) {
-        // the current system does not meet our needs to disconnect and
-        // call recursively to get a new system.
-        getLogWriter().info("Disconnecting from current DS in order to make a new one");
-        disconnectFromDS();
-        getSystem(props);
-      }
-    }
-    return system;
-  }
-
-
-  /**
-   * Crash the cache in the given VM in such a way that it immediately stops communicating with
-   * peers.  This forces the VM's membership manager to throw a ForcedDisconnectException by
-   * forcibly terminating the JGroups protocol stack with a fake EXIT event.<p>
-   * 
-   * NOTE: if you use this method be sure that you clean up the VM before the end of your
-   * test with disconnectFromDS() or disconnectAllFromDS().
-   */
-  public boolean crashDistributedSystem(VM vm) {
-    return (Boolean)vm.invoke(new SerializableCallable("crash distributed system") {
-      public Object call() throws Exception {
-        DistributedSystem msys = InternalDistributedSystem.getAnyInstance();
-        crashDistributedSystem(msys);
-        return true;
-      }
-    });
-  }
-  
-  /**
-   * Crash the cache in the given VM in such a way that it immediately stops communicating with
-   * peers.  This forces the VM's membership manager to throw a ForcedDisconnectException by
-   * forcibly terminating the JGroups protocol stack with a fake EXIT event.<p>
-   * 
-   * NOTE: if you use this method be sure that you clean up the VM before the end of your
-   * test with disconnectFromDS() or disconnectAllFromDS().
-   */
-  public void crashDistributedSystem(final DistributedSystem msys) {
-    MembershipManagerHelper.crashDistributedSystem(msys);
-    MembershipManagerHelper.inhibitForcedDisconnectLogging(false);
-    WaitCriterion wc = new WaitCriterion() {
-      public boolean done() {
-        return !msys.isConnected();
-      }
-      public String description() {
-        return "waiting for distributed system to finish disconnecting: " + msys;
-      }
-    };
-//    try {
-      waitForCriterion(wc, 10000, 1000, true);
-//    } finally {
-//      dumpMyThreads(getLogWriter());
-//    }
-  }
-
-  private String getDefaultDiskStoreName() {
-    String vmid = System.getProperty("vmid");
-    return "DiskStore-"  + vmid + "-"+ getTestClass().getCanonicalName() + "." + getTestName();
-  }
-
-  /**
-   * Returns this VM's connection to the distributed system.  If
-   * necessary, the connection will be lazily created using the
-   * <code>Properties</code> returned by {@link
-   * #getDistributedSystemProperties}.
-   *
-   * @see #getSystem(Properties)
-   *
-   * @since 3.0
-   */
-  public final InternalDistributedSystem getSystem() {
-    return getSystem(this.getDistributedSystemProperties());
-  }
-
-  /**
-   * Returns a loner distributed system that isn't connected to other
-   * vms
-   * 
-   * @since 6.5
-   */
-  public final InternalDistributedSystem getLonerSystem() {
-    Properties props = this.getDistributedSystemProperties();
-    props.put(DistributionConfig.MCAST_PORT_NAME, "0");
-    props.put(DistributionConfig.LOCATORS_NAME, "");
-    return getSystem(props);
-  }
-  
-  /**
-   * Returns a loner distributed system in combination with enforceUniqueHost
-   * and redundancyZone properties.
-   * Added specifically to test scenario of defect #47181.
-   */
-  public final InternalDistributedSystem getLonerSystemWithEnforceUniqueHost() {
-    Properties props = this.getDistributedSystemProperties();
-    props.put(DistributionConfig.MCAST_PORT_NAME, "0");
-    props.put(DistributionConfig.LOCATORS_NAME, "");
-    props.put(DistributionConfig.ENFORCE_UNIQUE_HOST_NAME, "true");
-    props.put(DistributionConfig.REDUNDANCY_ZONE_NAME, "zone1");
-    return getSystem(props);
-  }
-
-  /**
-   * Returns whether or this VM is connected to a {@link
-   * DistributedSystem}.
-   */
-  public final boolean isConnectedToDS() {
-    return system != null && system.isConnected();
-  }
-
-  /**
-   * Returns a <code>Properties</code> object used to configure a
-   * connection to a {@link
-   * com.gemstone.gemfire.distributed.DistributedSystem}.
-   * Unless overridden, this method will return an empty
-   * <code>Properties</code> object.
-   *
-   * @since 3.0
-   */
-  public Properties getDistributedSystemProperties() {
-    return new Properties();
-  }
-
-  /**
-   * Sets up the test (noop).
-   */
-  @Override
-  public void setUp() throws Exception {
-    logTestHistory();
-    setUpCreationStackGenerator();
-    testName = getName();
-    System.setProperty(HoplogConfig.ALLOW_LOCAL_HDFS_PROP, "true");
-    
-    if (testName != null) {
-      GemFireCacheImpl.setDefaultDiskStoreName(getDefaultDiskStoreName());
-      String baseDefaultDiskStoreName = getTestClass().getCanonicalName() + "." + getTestName();
-      for (int h = 0; h < Host.getHostCount(); h++) {
-        Host host = Host.getHost(h);
-        for (int v = 0; v < host.getVMCount(); v++) {
-          VM vm = host.getVM(v);
-          String vmDefaultDiskStoreName = "DiskStore-" + h + "-" + v + "-" + baseDefaultDiskStoreName;
-          vm.invoke(DistributedTestCase.class, "perVMSetUp", new Object[] {testName, vmDefaultDiskStoreName});
-        }
-      }
-    }
-    System.out.println("\n\n[setup] START TEST " + getClass().getSimpleName()+"."+testName+"\n\n");
-  }
-
-  /**
-   * Write a message to the log about what tests have ran previously. This
-   * makes it easier to figure out if a previous test may have caused problems
-   */
-  private void logTestHistory() {
-    String classname = getClass().getSimpleName();
-    testHistory.add(classname);
-    System.out.println("Previously run tests: " + testHistory);
-  }
-
-  public static void perVMSetUp(String name, String defaultDiskStoreName) {
-    setTestName(name);
-    GemFireCacheImpl.setDefaultDiskStoreName(defaultDiskStoreName);
-    System.setProperty(HoplogConfig.ALLOW_LOCAL_HDFS_PROP, "true");    
-  }
-  public static void setTestName(String name) {
-    testName = name;
-  }
-  
-  public static String getTestName() {
-    return testName;
-  }
-
-  /**
-   * For logPerTest to work, we have to disconnect from the DS, but all
-   * subclasses do not call super.tearDown(). To prevent this scenario
-   * this method has been declared final. Subclasses must now override
-   * {@link #tearDown2()} instead.
-   * @throws Exception
-   */
-  @Override
-  public final void tearDown() throws Exception {
-    tearDownCreationStackGenerator();
-    tearDown2();
-    realTearDown();
-    tearDownAfter();
-  }
-
-  /**
-   * Tears down the test. This method is called by the final {@link #tearDown()} method and should be overridden to
-   * perform actual test cleanup and release resources used by the test.  The tasks executed by this method are
-   * performed before the DUnit test framework using Hydra cleans up the client VMs.
-   * <p/>
-   * @throws Exception if the tear down process and test cleanup fails.
-   * @see #tearDown
-   * @see #tearDownAfter()
-   */
-  // TODO rename this method to tearDownBefore and change the access modifier to protected!
-  public void tearDown2() throws Exception {
-  }
-
-  protected void realTearDown() throws Exception {
-    if (logPerTest) {
-      disconnectFromDS();
-      invokeInEveryVM(DistributedTestCase.class, "disconnectFromDS");
-    }
-    cleanupAllVms();
-  }
-  
-  /**
-   * Tears down the test.  Performs additional tear down tasks after the DUnit tests framework using Hydra cleans up
-   * the client VMs.  This method is called by the final {@link #tearDown()} method and should be overridden to perform
-   * post tear down activities.
-   * <p/>
-   * @throws Exception if the test tear down process fails.
-   * @see #tearDown()
-   * @see #tearDown2()
-   */
-  protected void tearDownAfter() throws Exception {
-  }
-
-  public static void cleanupAllVms()
-  {
-    cleanupThisVM();
-    invokeInEveryVM(DistributedTestCase.class, "cleanupThisVM");
-    invokeInLocator(new SerializableRunnable() {
-      public void run() {
-        DistributionMessageObserver.setInstance(null);
-        unregisterInstantiatorsInThisVM();
-      }
-    });
-    DUnitLauncher.closeAndCheckForSuspects();
-  }
-
-
-  private static void cleanupThisVM() {
-    closeCache();
-    
-    SocketCreator.resolve_dns = true;
-    CacheCreation.clearThreadLocals();
-    System.getProperties().remove("gemfire.log-level");
-    System.getProperties().remove("jgroups.resolve_dns");
-    InitialImageOperation.slowImageProcessing = 0;
-    DistributionMessageObserver.setInstance(null);
-    QueryTestUtils.setCache(null);
-    CacheServerTestUtil.clearCacheReference();
-    RegionTestCase.preSnapshotRegion = null;
-    GlobalLockingDUnitTest.region_testBug32356 = null;
-    LogWrapper.close();
-    ClientProxyMembershipID.system = null;
-    MultiVMRegionTestCase.CCRegion = null;
-    InternalClientMembership.unregisterAllListeners();
-    ClientStatsManager.cleanupForTests();
-    ClientServerTestCase.AUTO_LOAD_BALANCE = false;
-    unregisterInstantiatorsInThisVM();
-    DistributionMessageObserver.setInstance(null);
-    QueryObserverHolder.reset();
-    DiskStoreObserver.setInstance(null);
-    System.getProperties().remove("gemfire.log-level");
-    System.getProperties().remove("jgroups.resolve_dns");
-    
-    if (InternalDistributedSystem.systemAttemptingReconnect != null) {
-      InternalDistributedSystem.systemAttemptingReconnect.stopReconnecting();
-    }
-    ExpectedException ex;
-    while((ex = expectedExceptions.poll()) != null) {
-      ex.remove();
-    }
-  }
-
-  private static void closeCache() {
-    GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
-    if(cache != null && !cache.isClosed()) {
-      destroyRegions(cache);
-      cache.close();
-    }
-  }
-  
-  protected static final void destroyRegions(Cache cache)
-      throws InternalGemFireError, Error, VirtualMachineError {
-    if (cache != null && !cache.isClosed()) {
-      //try to destroy the root regions first so that
-      //we clean up any persistent files.
-      for (Iterator itr = cache.rootRegions().iterator(); itr.hasNext();) {
-        Region root = (Region)itr.next();
-        //for colocated regions you can't locally destroy a partitioned
-        //region.
-        if(root.isDestroyed() || root instanceof HARegion || root instanceof PartitionedRegion) {
-          continue;
-        }
-        try {
-          root.localDestroyRegion("teardown");
-        }
-        catch (VirtualMachineError e) {
-          SystemFailure.initiateFailure(e);
-          throw e;
-        }
-        catch (Throwable t) {
-          getLogWriter().error(t);
-        }
-      }
-    }
-  }
-  
-  
-  public static void unregisterAllDataSerializersFromAllVms()
-  {
-    unregisterDataSerializerInThisVM();
-    invokeInEveryVM(new SerializableRunnable() {
-      public void run() {
-        unregisterDataSerializerInThisVM();
-      }
-    });
-    invokeInLocator(new SerializableRunnable() {
-      public void run() {
-        unregisterDataSerializerInThisVM();
-      }
-    });
-  }
-
-  public static void unregisterInstantiatorsInThisVM() {
-    // unregister all the instantiators
-    InternalInstantiator.reinitialize();
-    assertEquals(0, InternalInstantiator.getInstantiators().length);
-  }
-  
-  public static void unregisterDataSerializerInThisVM()
-  {
-    DataSerializerPropogationDUnitTest.successfullyLoadedTestDataSerializer = false;
-    // unregister all the Dataserializers
-    InternalDataSerializer.reinitialize();
-    // ensure that all are unregistered
-    assertEquals(0, InternalDataSerializer.getSerializers().length);
-  }
-
-
-  protected static void disconnectAllFromDS() {
-    disconnectFromDS();
-    invokeInEveryVM(DistributedTestCase.class,
-                    "disconnectFromDS");
-  }
-
-  /**
-   * Disconnects this VM from the distributed system
-   */
-  public static void disconnectFromDS() {
-    testName = null;
-    GemFireCacheImpl.testCacheXml = null;
-    if (system != null) {
-      system.disconnect();
-      system = null;
-    }
-    
-    for (;;) {
-      DistributedSystem ds = InternalDistributedSystem.getConnectedInstance();
-      if (ds == null) {
-        break;
-      }
-      try {
-        ds.disconnect();
-      }
-      catch (Exception e) {
-        // ignore
-      }
-    }
-    
-    {
-      AdminDistributedSystemImpl ads = 
-          AdminDistributedSystemImpl.getConnectedInstance();
-      if (ads != null) {// && ads.isConnected()) {
-        ads.disconnect();
-      }
-    }
-  }
-
-  /**
-   * Strip the package off and gives just the class name.
-   * Needed because of Windows file name limits.
-   */
-  private String getShortClassName() {
-    String result = this.getClass().getName();
-    int idx = result.lastIndexOf('.');
-    if (idx != -1) {
-      result = result.substring(idx+1);
-    }
-    return result;
-  }
-  
-  /** get the host name to use for a server cache in client/server dunit
-   * testing
-   * @param host
-   * @return the host name
-   */
-  public static String getServerHostName(Host host) {
-    return System.getProperty("gemfire.server-bind-address") != null?
-        System.getProperty("gemfire.server-bind-address")
-        : host.getHostName();
-  }
-
-  /** get the IP literal name for the current host, use this instead of  
-   * "localhost" to avoid IPv6 name resolution bugs in the JDK/machine config.
-   * @return an ip literal, this method honors java.net.preferIPvAddresses
-   */
-  public static String getIPLiteral() {
-    try {
-      return SocketCreator.getLocalHost().getHostAddress();
-    } catch (UnknownHostException e) {
-      throw new Error("problem determining host IP address", e);
-    }
-  }
- 
- 
-  /**
-   * Get the port that the standard dunit locator is listening on.
-   * @return
-   */
-  public static int getDUnitLocatorPort() {
-    return DUnitEnv.get().getLocatorPort();
-  }
-    
-  
-  /**
-   * Returns a unique name for this test method.  It is based on the
-   * name of the class as well as the name of the method.
-   */
-  public String getUniqueName() {
-    return getShortClassName() + "_" + this.getName();
-  }
-
-  /**
-   * Returns a <code>LogWriter</code> for logging information
-   * @deprecated Use a static logger from the log4j2 LogService.getLogger instead.
-   */
-  @Deprecated
-  public static InternalLogWriter getLogWriter() {
-    return oldLogger;
-  }
-
-  /**
-   * Helper method that causes this test to fail because of the given
-   * exception.
-   */
-  public static void fail(String message, Throwable ex) {
-    StringWriter sw = new StringWriter();
-    PrintWriter pw = new PrintWriter(sw, true);
-    pw.print(message);
-    pw.print(": ");
-    ex.printStackTrace(pw);
-    fail(sw.toString());
-  }
-
-  // utility methods
-
-  /** pause for a default interval */
-  protected void pause() {
-    pause(250);
-  }
-
-  /**
-   * Use of this function indicates a place in the tests tree where t
-   * he use of Thread.sleep() is
-   * highly questionable.
-   * <p>
-   * Some places in the system, especially those that test expirations and other
-   * timeouts, have a very good reason to call {@link Thread#sleep(long)}.  The
-   * <em>other</em> places are marked by the use of this method.
-   * 
-   * @param ms
-   */
-  static public final void staticPause(int ms) {
-//    getLogWriter().info("FIXME: Pausing for " + ms + " ms..."/*, new Exception()*/);
-    final long target = System.currentTimeMillis() + ms;
-    try {
-      for (;;) {
-        long msLeft = target - System.currentTimeMillis();
-        if (msLeft <= 0) {
-          break;
-        }
-        Thread.sleep(msLeft);
-      }
-    }
-    catch (InterruptedException e) {
-      fail("interrupted", e);
-    }
-    
-  }
-  
-  /**
-   * Blocks until the clock used for expiration moves forward.
-   * @return the last time stamp observed
-   */
-  public static final long waitForExpiryClockToChange(LocalRegion lr) {
-    return waitForExpiryClockToChange(lr, lr.cacheTimeMillis());
-  }
-  /**
-   * Blocks until the clock used for expiration moves forward.
-   * @param baseTime the timestamp that the clock must exceed
-   * @return the last time stamp observed
-   */
-  public static final long waitForExpiryClockToChange(LocalRegion lr, final long baseTime) {
-    long nowTime;
-    do {
-      Thread.yield();
-      nowTime = lr.cacheTimeMillis();
-    } while ((nowTime - baseTime) <= 0L);
-    return nowTime;
-  }
-  
-  /** pause for specified ms interval
-   * Make sure system clock has advanced by the specified number of millis before
-   * returning.
-   */
-  public static final void pause(int ms) {
-    LogWriter log = getLogWriter();
-    if (ms >= 1000 || log.fineEnabled()) { // check for fine but log at info
-      getLogWriter().info("Pausing for " + ms + " ms..."/*, new Exception()*/);
-    }
-    final long target = System.currentTimeMillis() + ms;
-    try {
-      for (;;) {
-        long msLeft = target - System.currentTimeMillis();
-        if (msLeft <= 0) {
-          break;
-        }
-        Thread.sleep(msLeft);
-      }
-    }
-    catch (InterruptedException e) {
-      fail("interrupted", e);
-    }
-  }
-  
-  public interface WaitCriterion {
-    public boolean done();
-    public String description();
-  }
-  
-  public interface WaitCriterion2 extends WaitCriterion {
-    /**
-     * If this method returns true then quit waiting even if we are not done.
-     * This allows a wait to fail early.
-     */
-    public boolean stopWaiting();
-  }
-
-  /**
-   * If true, we randomize the amount of time we wait before polling a
-   * {@link WaitCriterion}.
-   */
-  static private final boolean USE_JITTER = true;
-  static private final Random jitter = new Random();
-  
-  /**
-   * Return a jittered interval up to a maximum of <code>ms</code>
-   * milliseconds, inclusive.
-   * 
-   * The result is bounded by 50 ms as a minimum and 5000 ms as a maximum.
-   * 
-   * @param ms total amount of time to wait
-   * @return randomized interval we should wait
-   */
-  private static int jitterInterval(long ms) {
-    final int minLegal = 50;
-    final int maxLegal = 5000;
-    if (ms <= minLegal) {
-      return (int)ms; // Don't ever jitter anything below this.
-    }
-
-    int maxReturn = maxLegal;
-    if (ms < maxLegal) {
-      maxReturn = (int)ms;
-    }
-
-    return minLegal + jitter.nextInt(maxReturn - minLegal + 1);
-  }
-  
-  /**
-   * Wait until given criterion is met
-   * @param ev criterion to wait on
-   * @param ms total time to wait, in milliseconds
-   * @param interval pause interval between waits
-   * @param throwOnTimeout if false, don't generate an error
-   */
-  static public void waitForCriterion(WaitCriterion ev, long ms, 
-      long interval, boolean throwOnTimeout) {
-    long waitThisTime;
-    if (USE_JITTER) {
-      waitThisTime = jitterInterval(interval);
-    }
-    else {
-      waitThisTime = interval;
-    }
-    final long tilt = System.currentTimeMillis() + ms;
-    for (;;) {
-//      getLogWriter().info("Testing to see if event has occurred: " + ev.description());
-      if (ev.done()) {
-        return; // success
-      }
-      if (ev instanceof WaitCriterion2) {
-        WaitCriterion2 ev2 = (WaitCriterion2)ev;
-        if (ev2.stopWaiting()) {
-          if (throwOnTimeout) {
-            fail("stopWaiting returned true: " + ev.description());
-          }
-          return;
-        }
-      }
-
-      // Calculate time left
-      long timeLeft = tilt - System.currentTimeMillis();
-      if (timeLeft <= 0) {
-        if (!throwOnTimeout) {
-          return; // not an error, but we're done
-        }
-        fail("Event never occurred after " + ms + " ms: " + ev.description());
-      }
-      
-      if (waitThisTime > timeLeft) {
-        waitThisTime = timeLeft;
-      }
-      
-      // Wait a little bit
-      Thread.yield();
-      try {
-//        getLogWriter().info("waiting " + waitThisTime + "ms for " + ev.description());
-        Thread.sleep(waitThisTime);
-      } catch (InterruptedException e) {
-        fail("interrupted");
-      }
-    }
-  }
-
-  /**
-   * Wait on a mutex.  This is done in a loop in order to address the
-   * "spurious wakeup" "feature" in Java.
-   * @param ev condition to test
-   * @param mutex object to lock and wait on
-   * @param ms total amount of time to wait
-   * @param interval interval to pause for the wait
-   * @param throwOnTimeout if false, no error is thrown.
-   */
-  static public void waitMutex(WaitCriterion ev, Object mutex, long ms, 
-      long interval, boolean throwOnTimeout) {
-    final long tilt = System.currentTimeMillis() + ms;
-    long waitThisTime;
-    if (USE_JITTER) {
-      waitThisTime = jitterInterval(interval);
-    }
-    else {
-      waitThisTime = interval;
-    }
-    synchronized (mutex) {
-      for (;;) {
-        if (ev.done()) {
-          break;
-        }
-        
-        long timeLeft = tilt - System.currentTimeMillis();
-        if (timeLeft <= 0) {
-          if (!throwOnTimeout) {
-            return; // not an error, but we're done
-          }
-          fail("Event never occurred after " + ms + " ms: " + ev.description());
-        }
-        
-        if (waitThisTime > timeLeft) {
-          waitThisTime = timeLeft;
-        }
-        
-        try {
-          mutex.wait(waitThisTime);
-        } catch (InterruptedException e) {
-          fail("interrupted");
-        }
-      } // for
-    } // synchronized
-  }
-
-  /**
-   * Wait for a thread to join
-   * @param t thread to wait on
-   * @param ms maximum time to wait
-   * @throws AssertionFailure if the thread does not terminate
-   */
-  static public void join(Thread t, long ms, LogWriter logger) {
-    final long tilt = System.currentTimeMillis() + ms;
-    final long incrementalWait;
-    if (USE_JITTER) {
-      incrementalWait = jitterInterval(ms);
-    }
-    else {
-      incrementalWait = ms; // wait entire time, no looping.
-    }
-    final long start = System.currentTimeMillis();
-    for (;;) {
-      // I really do *not* understand why this check is necessary
-      // but it is, at least with JDK 1.6.  According to the source code
-      // and the javadocs, one would think that join() would exit immediately
-      // if the thread is dead.  However, I can tell you from experimentation
-      // that this is not the case. :-(  djp 2008-12-08
-      if (!t.isAlive()) {
-        break;
-      }
-      try {
-        t.join(incrementalWait);
-      } catch (InterruptedException e) {
-        fail("interrupted");
-      }
-      if (System.currentTimeMillis() >= tilt) {
-        break;
-      }
-    } // for
-    if (logger == null) {
-      logger = new LocalLogWriter(LogWriterImpl.INFO_LEVEL, System.out);
-    }
-    if (t.isAlive()) {
-      logger.info("HUNG THREAD");
-      dumpStackTrace(t, t.getStackTrace(), logger);
-      dumpMyThreads(logger);
-      t.interrupt(); // We're in trouble!
-      fail("Thread did not terminate after " + ms + " ms: " + t);
-//      getLogWriter().warning("Thread did not terminate" 
-//          /* , new Exception()*/
-//          );
-    }
-    long elapsedMs = (System.currentTimeMillis() - start);
-    if (elapsedMs > 0) {
-      String msg = "Thread " + t + " took " 
-        + elapsedMs
-        + " ms to exit.";
-      logger.info(msg);
-    }
-  }
-
-  public static void dumpStackTrace(Thread t, StackTraceElement[] stack, LogWriter logger) {
-    StringBuilder msg = new StringBuilder();
-    msg.append("Thread=<")
-      .append(t)
-      .append("> stackDump:\n");
-    for (int i=0; i < stack.length; i++) {
-      msg.append("\t")
-        .append(stack[i])
-        .append("\n");
-    }
-    logger.info(msg.toString());
-  }
-  /**
-   * Dump all thread stacks
-   */
-  public static void dumpMyThreads(LogWriter logger) {
-    OSProcess.printStacks(0, false);
-  }
-  
-  /**
-   * A class that represents an currently logged expected exception, which
-   * should be removed
-   * 
-   * @author Mitch Thomas
-   * @since 5.7bugfix
-   */
-  public static class ExpectedException implements Serializable {
-    private static final long serialVersionUID = 1L;
-
-    final String ex;
-
-    final transient VM v;
-
-    public ExpectedException(String exception) {
-      this.ex = exception;
-      this.v = null;
-    }
-
-    ExpectedException(String exception, VM vm) {
-      this.ex = exception;
-      this.v = vm;
-    }
-
-    public String getRemoveString() {
-      return "<ExpectedException action=remove>" + ex + "</ExpectedException>";
-    }
-
-    public String getAddString() {
-      return "<ExpectedException action=add>" + ex + "</ExpectedException>";
-    }
-
-    public void remove() {
-      SerializableRunnable removeRunnable = new SerializableRunnable(
-          "removeExpectedExceptions") {
-        public void run() {
-          final String remove = getRemoveString();
-          final InternalDistributedSystem sys = InternalDistributedSystem
-              .getConnectedInstance();
-          if (sys != null) {
-            sys.getLogWriter().info(remove);
-          }
-          try {
-            getLogWriter().info(remove);
-          } catch (Exception noHydraLogger) {
-          }
-
-          logger.info(remove);
-        }
-      };
-
-      if (this.v != null) {
-        v.invoke(removeRunnable);
-      }
-      else {
-        invokeInEveryVM(removeRunnable);
-      }
-      String s = getRemoveString();
-      LogManager.getLogger(LogService.BASE_LOGGER_NAME).info(s);
-      // log it locally
-      final InternalDistributedSystem sys = InternalDistributedSystem
-          .getConnectedInstance();
-      if (sys != null) { // avoid creating a system
-        sys.getLogWriter().info(s);
-      }
-      getLogWriter().info(s);
-    }
-  }
-
-  /**
-   * Log in all VMs, in both the test logger and the GemFire logger the
-   * expected exception string to prevent grep logs from complaining. The
-   * expected string is used by the GrepLogs utility and so can contain
-   * regular expression characters.
-   * 
-   * If you do not remove the expected exception, it will be removed at the
-   * end of your test case automatically.
-   * 
-   * @since 5.7bugfix
-   * @param exception
-   *          the exception string to expect
-   * @return an ExpectedException instance for removal
-   */
-  public static ExpectedException addExpectedException(final String exception) {
-    return addExpectedException(exception, null);
-  }
-
-  /**
-   * Log in all VMs, in both the test logger and the GemFire logger the
-   * expected exception string to prevent grep logs from complaining. The
-   * expected string is used by the GrepLogs utility and so can contain
-   * regular expression characters.
-   * 
-   * @since 5.7bugfix
-   * @param exception
-   *          the exception string to expect
-   * @param v
-   *          the VM on which to log the expected exception or null for all VMs
-   * @return an ExpectedException instance for removal purposes
-   */
-  public static ExpectedException addExpectedException(final String exception,
-      VM v) {
-    final ExpectedException ret;
-    if (v != null) {
-      ret = new ExpectedException(exception, v);
-    }
-    else {
-      ret = new ExpectedException(exception);
-    }
-    // define the add and remove expected exceptions
-    final String add = ret.getAddString();
-    SerializableRunnable addRunnable = new SerializableRunnable(
-        "addExpectedExceptions") {
-      public void run() {
-        final InternalDistributedSystem sys = InternalDistributedSystem
-            .getConnectedInstance();
-        if (sys != null) {
-          sys.getLogWriter().info(add);
-        }
-        try {
-          getLogWriter().info(add);
-        } catch (Exception noHydraLogger) {
-        }
- 
-        logger.info(add);
-      }
-    };
-    if (v != null) {
-      v.invoke(addRunnable);
-    }
-    else {
-      invokeInEveryVM(addRunnable);
-    }
-    
-    LogManager.getLogger(LogService.BASE_LOGGER_NAME).info(add);
-    // Log it locally too
-    final InternalDistributedSystem sys = InternalDistributedSystem
-        .getConnectedInstance();
-    if (sys != null) { // avoid creating a cache
-      sys.getLogWriter().info(add);
-    }
-    getLogWriter().info(add);
-    expectedExceptions.add(ret);
-    return ret;
-  }
-
-  /** 
-   * delete locator state files.  Use this after getting a random port
-   * to ensure that an old locator state file isn't picked up by the
-   * new locator you're starting.
-   * @param ports
-   */
-  public void deleteLocatorStateFile(int... ports) {
-    for (int i=0; i<ports.length; i++) {
-      File stateFile = new File("locator"+ports[i]+"view.dat");
-      if (stateFile.exists()) {
-        stateFile.delete();
-      }
-    }
-  }
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/Host.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/Host.java b/gemfire-core/src/test/java/dunit/Host.java
deleted file mode 100644
index 0c69783..0000000
--- a/gemfire-core/src/test/java/dunit/Host.java
+++ /dev/null
@@ -1,210 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.util.*;
-
-import com.gemstone.gemfire.test.dunit.standalone.RemoteDUnitVMIF;
-
-/**
- * <P>This class represents a host on which a remote method may be
- * invoked.  It provides access to the VMs and GemFire systems that
- * run on that host.</P>
- *
- * <P>Additionally, it provides access to the Java RMI registry that
- * runs on the host.  By default, an RMI registry is only started on
- * the host on which Hydra's Master VM runs.  RMI registries may be
- * started on other hosts via additional Hydra configuration.</P>
- *
- * @author David Whitlock
- *
- */
-public abstract class Host implements java.io.Serializable {
-
-  /** The available hosts */
-  protected static List hosts = new ArrayList();
-
-  private static VM locator;
-
-  /** Indicates an unstarted RMI registry */
-  protected static int NO_REGISTRY = -1;
-
-  ////////////////////  Instance Fields  ////////////////////
-
-  /** The name of this host machine */
-  private String hostName;
-
-  /** The VMs that run on this host */
-  private List vms;
-
-  /** The GemFire systems that are available on this host */
-  private List systems;
-  
-  /** Key is system name, value is GemFireSystem instance */
-  private HashMap systemNames;
-  
-  ////////////////////  Static Methods  /////////////////////
-
-  /**
-   * Returns the number of known hosts
-   */
-  public static int getHostCount() {
-    return hosts.size();
-  }
-
-  /**
-   * Makes note of a new <code>Host</code>
-   */
-  protected static void addHost(Host host) {
-    hosts.add(host);
-  }
-
-  /**
-   * Returns a given host
-   *
-   * @param n
-   *        A zero-based identifier of the host
-   *
-   * @throws IllegalArgumentException
-   *         <code>n</code> is more than the number of hosts
-   */
-  public static Host getHost(int n) {
-    int size = hosts.size();
-    if (n >= size) {
-      String s = "Cannot request host " + n + ".  There are only " +
-        size + " hosts.";
-      throw new IllegalArgumentException(s);
-
-    } else {
-      return (Host) hosts.get(n);
-    }
-  }
-
-  /////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>Host</code> with the given name
-   */
-  protected Host(String hostName) {
-    if (hostName == null) {
-      String s = "Cannot create a Host with a null name";
-      throw new NullPointerException(s);
-    }
-
-    this.hostName = hostName;
-    this.vms = new ArrayList();
-    this.systems = new ArrayList();
-    this.systemNames = new HashMap();
-  }
-
-  ////////////////////  Instance Methods  ////////////////////
-
-  /**
-   * Returns the machine name of this host
-   */
-  public String getHostName() {
-    return this.hostName;
-  }
-
-  /**
-   * Returns the number of VMs that run on this host
-   */
-  public int getVMCount() {
-    return this.vms.size();
-  }
-
-  /**
-   * Returns a VM that runs on this host
-   *
-   * @param n
-   *        A zero-based identifier of the VM
-   *
-   * @throws IllegalArgumentException
-   *         <code>n</code> is more than the number of VMs
-   */
-  public VM getVM(int n) {
-    int size = vms.size();
-    if (n >= size) {
-      String s = "Cannot request VM " + n + ".  There are only " +
-        size + " VMs on " + this;
-      throw new IllegalArgumentException(s);
-
-    } else {
-      return (VM) vms.get(n);
-    }
-  }
-
-  /**
-   * Adds a VM to this <code>Host</code> with the given process id and client record.
-   */
-  protected void addVM(int pid, RemoteDUnitVMIF client) {
-    VM vm = new VM(this, pid, client);
-    this.vms.add(vm);
-  }
-
-  public static VM getLocator() {
-    return locator;
-  }
-  
-  private static void setLocator(VM l) {
-    locator = l;
-  }
-  
-  protected void addLocator(int pid, RemoteDUnitVMIF client) {
-    setLocator(new VM(this, pid, client));
-  }
-
-  /**
-   * Returns the number of GemFire systems that run on this host
-   */
-  public int getSystemCount() {
-    return this.systems.size();
-  }
-
-  ////////////////////  Utility Methods  ////////////////////
-
-  public String toString() {
-    StringBuffer sb = new StringBuffer("Host ");
-    sb.append(this.getHostName());
-    sb.append(" with ");
-    sb.append(getVMCount());
-    sb.append(" VMs");
-    return sb.toString();
-  }
-
-  /**
-   * Two <code>Host</code>s are considered equal if they have the same
-   * name.
-   */
-  public boolean equals(Object o) {
-    if (o instanceof Host) {
-      return ((Host) o).getHostName().equals(this.getHostName());
-
-    } else {
-      return false;
-    }
-  }
-
-  /**
-   * A <code>Host</code>'s hash code is based on the hash code of its
-   * name. 
-   */
-  public int hashCode() {
-    return this.getHostName().hashCode();
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/RMIException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/RMIException.java b/gemfire-core/src/test/java/dunit/RMIException.java
deleted file mode 100644
index 19541be..0000000
--- a/gemfire-core/src/test/java/dunit/RMIException.java
+++ /dev/null
@@ -1,170 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import com.gemstone.gemfire.GemFireException;
-
-/**
- * This exception is thrown when an exception occurs during a remote
- * method invocation.  This {@link RuntimeException} wraps the actual
- * exception.  It allows distributed unit tests to verify that an
- * exception was thrown in a different VM.
- *
- * <PRE>
- *     VM vm0 = host0.getVM(0);
- *     try {
- *       vm.invoke(this.getClass(), "getUnknownObject");
- *
- *     } catch (RMIException ex) {
- *       assertEquals(ex.getCause() instanceof ObjectException);
- *     }
- * </PRE>
- *
- * Note that special steps are taken so that the stack trace of the
- * cause exception reflects the call stack on the remote machine.
- * The stack trace of the exception returned by {@link #getCause()}
- * may not be available.
- *
- * @see hydra.RemoteTestModuleIF
- *
- * @author David Whitlock
- *
- */
-public class RMIException extends GemFireException {
-
-  /** SHADOWED FIELD that holds the cause exception (as opposed to the
-   * HokeyException */
-  private Throwable cause;
-
-  /** The name of the method being invoked */
-  private String methodName;
-
-  /** The name of the class (or class of the object type) whose method
-   * was being invoked */
-  private String className;
-
-  /** The type of exception that was thrown in the remote VM */
-  private String exceptionClassName;
-
-  /** Stack trace for the exception that was thrown in the remote VM */
-  private String stackTrace;
-
-  /** The VM in which the method was executing */
-  private VM vm;
-
-  ////////////////////////  Constructors  ////////////////////////
-
-  /**
-   * Creates a new <code>RMIException</code> that was caused by a
-   * given <code>Throwable</code> while invoking a given method.
-   */
-  public RMIException(VM vm, String className, String methodName,
-                      Throwable cause) {
-    super("While invoking " + className + "." + methodName + " in " +
-          vm, cause);
-    this.cause = cause;
-    this.className = className;
-    this.methodName = methodName;
-    this.vm = vm;
-  }
-
-  /**
-   * Creates a new <code>RMIException</code> to indicate that an
-   * exception of a given type was thrown while invoking a given
-   * method. 
-   *
-   * @param vm
-   *        The VM in which the method was executing
-   * @param className
-   *        The name of the class whose method was being invoked
-   *        remotely 
-   * @param methodName
-   *        The name of the method that was being invoked remotely
-   * @param cause
-   *        The type of exception that was thrown in the remote VM
-   * @param stackTrace
-   *        The stack trace of the exception from the remote VM
-   */
-  public RMIException(VM vm, String className, String methodName, 
-                      Throwable cause, String stackTrace) {
-    super("While invoking " + className + "." + methodName + " in " +
-          vm, new HokeyException(cause, stackTrace));
-    this.vm = vm;
-    this.cause = cause;
-    this.className = className;
-    this.methodName = methodName;
-//    this.exceptionClassName = exceptionClassName; assignment has no effect
-    this.stackTrace = stackTrace;
-  }
-
-  /**
-   * Returns the class name of the exception that was thrown in a
-   * remote method invocation.
-   */
-  public String getExceptionClassName() {
-    return this.exceptionClassName;
-  }
-
-//   /**
-//    * Returns the stack trace for the exception that was thrown in a
-//    * remote method invocation.
-//    */
-//   public String getStackTrace() {
-//     return this.stackTrace;
-//   }
-
-  /**
-   * Returns the cause of this exception.  Note that this is not
-   * necessarily the exception that gets printed out with the stack
-   * trace.
-   */
-  public Throwable getCause() {
-    return this.cause;
-  }
-
-  /**
-   * Returns the VM in which the remote method was invoked
-   */
-  public VM getVM() {
-    return this.vm;
-  }
-
-  //////////////////////  Inner Classes  //////////////////////
-
-  /**
-   * A hokey exception class that makes it looks like we have a real
-   * cause exception.
-   */
-  private static class HokeyException extends Throwable {
-    private String stackTrace;
-    private String toString;
-
-    HokeyException(Throwable cause, String stackTrace) {
-      this.toString = cause.toString();
-      this.stackTrace = stackTrace;
-    }
-
-    public void printStackTrace(java.io.PrintWriter pw) {
-      pw.print(this.stackTrace);
-      pw.flush();
-    }
-
-    public String toString() {
-      return this.toString;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/RepeatableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/RepeatableRunnable.java b/gemfire-core/src/test/java/dunit/RepeatableRunnable.java
deleted file mode 100644
index 4df6415..0000000
--- a/gemfire-core/src/test/java/dunit/RepeatableRunnable.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-/**
- * A RepeatableRunnable is an object that implements a method that
- * can be invoked repeatably without causing any side affects.
- *
- * @author  dmonnie
- */
-public interface RepeatableRunnable {
-  
-  public void runRepeatingIfNecessary(long repeatTimeoutMs);
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/SerializableCallable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/SerializableCallable.java b/gemfire-core/src/test/java/dunit/SerializableCallable.java
deleted file mode 100644
index 4b295fa..0000000
--- a/gemfire-core/src/test/java/dunit/SerializableCallable.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.io.Serializable;
-import java.util.concurrent.Callable;
-
-/**
- * This interface provides both {@link Serializable} and {@link
- * Callable}.  It is often used in conjunction with {@link
- * VM#invoke(Callable)}.
- *
- * <PRE>
- * public void testRepilcatedRegionPut() {
- *   final Host host = Host.getHost(0);
- *   VM vm0 = host.getVM(0);
- *   VM vm1 = host.getVM(1);
- *   final String name = this.getUniqueName();
- *   final Object value = new Integer(42);
- *
- *   SerializableCallable putMethod = new SerializableCallable("Replicated put") {
- *       public Object call() throws Exception {
- *         ...// get replicated test region //...
- *         return region.put(name, value);
- *       }
- *      });
- *   assertNull(vm0.invoke(putMethod));
- *   assertEquals(value, vm1.invoke(putMethod));
- *  }
- * </PRE>
- * 
- * @author Mitch Thomas
- */
-public abstract class SerializableCallable<T> implements Callable<T>, Serializable {
-  
-  private static final long serialVersionUID = -5914706166172952484L;
-  
-  private String name;
-
-  public SerializableCallable() {
-    this.name = null;
-  }
-
-  public SerializableCallable(String name) {
-    this.name = name;
-  }
-
-  public String toString() {
-    if (this.name != null) {
-      return "\"" + this.name + "\"";
-
-    } else {
-      return super.toString();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/SerializableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/SerializableRunnable.java b/gemfire-core/src/test/java/dunit/SerializableRunnable.java
deleted file mode 100644
index f28ecdc..0000000
--- a/gemfire-core/src/test/java/dunit/SerializableRunnable.java
+++ /dev/null
@@ -1,92 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.io.Serializable;
-
-/**
- * This interface provides both {@link Serializable} and {@link
- * Runnable}.  It is often used in conjunction with {@link
- * VM#invoke(Runnable)}.
- *
- * <PRE>
- * public void testRegionPutGet() {
- *   final Host host = Host.getHost(0);
- *   VM vm0 = host.getVM(0);
- *   VM vm1 = host.getVM(1);
- *   final String name = this.getUniqueName();
- *   final Object value = new Integer(42);
- *
- *   vm0.invoke(new SerializableRunnable("Put value") {
- *       public void run() {
- *         ...// get the region //...
- *         region.put(name, value);
- *       }
- *      });
- *   vm1.invoke(new SerializableRunnable("Get value") {
- *       public void run() {
- *         ...// get the region //...
- *         assertEquals(value, region.get(name));
- *       }
- *     });
- *  }
- * </PRE>
- */
-public abstract class SerializableRunnable
-  implements Serializable, Runnable {
-
-  private static final long serialVersionUID = 7584289978241650456L;
-  
-  private String name;
-
-  public SerializableRunnable() {
-    this.name = null;
-  }
-
-  /**
-   * This constructor lets you do the following:
-   *
-   * <PRE>
-   * vm.invoke(new SerializableRunnable("Do some work") {
-   *     public void run() {
-   *       // ...
-   *     }
-   *   });
-   * </PRE>
-   */
-  public SerializableRunnable(String name) {
-    this.name = name;
-  }
-  
-  public void setName(String newName) {
-    this.name = newName;
-  }
-  
-  public String getName() {
-    return this.name;
-  }
-
-  public String toString() {
-    if (this.name != null) {
-      return "\"" + this.name + "\"";
-
-    } else {
-      return super.toString();
-    }
-  }
-
-}


[20/52] [abbrv] incubator-geode git commit: GEODE-832: Modifying the dunit framework to allow lambda expressions

Posted by ds...@apache.org.
GEODE-832: Modifying the dunit framework to allow lambda expressions

Lambdas can now be used for VM.invoke and VM.invokeAsync. For example

vm.invoke(() -> {System.out.println("Hello from remote VM")})
String value = vm.invoke(() -> {return "Hello from remote VM")

This theoretically could be more efficient than using anonymous
classes, because they do not capture (and Serialize) a reference to
the enclosing test class unless they reference state of that class.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/93deadc4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/93deadc4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/93deadc4

Branch: refs/heads/feature/GEODE-831
Commit: 93deadc41ace6b9b05bc3dd7e27006563fb4b11c
Parents: f03ae07
Author: Dan Smith <up...@apache.org>
Authored: Thu Jan 21 10:39:50 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Mon Jan 25 11:47:12 2016 -0800

----------------------------------------------------------------------
 .../internal/LocatorLoadBalancingDUnitTest.java |   7 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |   3 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |   3 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |  15 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java | 986 +++++++++----------
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |  13 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |   9 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |  27 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |  12 +-
 .../test/dunit/SerializableCallable.java        |   2 +-
 .../test/dunit/SerializableCallableIF.java      |  24 +
 .../test/dunit/SerializableRunnable.java        |   2 +-
 .../test/dunit/SerializableRunnableIF.java      |  23 +
 .../com/gemstone/gemfire/test/dunit/VM.java     |  10 +-
 .../test/dunit/tests/BasicDUnitTest.java        |  27 +-
 .../gemfire/test/dunit/tests/VMDUnitTest.java   |   3 +-
 .../src/test/java/hydra/MethExecutor.java       |   2 +-
 17 files changed, 623 insertions(+), 545 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
index 2d1b75f..1c8e9eb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/LocatorLoadBalancingDUnitTest.java
@@ -25,7 +25,7 @@ import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.client.PoolManager;
@@ -33,10 +33,10 @@ import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionReques
 import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionResponse;
 import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionRequest;
 import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionResponse;
+import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache.server.ServerLoad;
 import com.gemstone.gemfire.cache.server.ServerLoadProbeAdapter;
 import com.gemstone.gemfire.cache.server.ServerMetrics;
-import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.InternalLocator;
 import com.gemstone.gemfire.distributed.internal.ServerLocation;
@@ -50,6 +50,7 @@ import com.gemstone.gemfire.internal.logging.LocalLogWriter;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
 
 /**
@@ -246,7 +247,7 @@ public class LocatorLoadBalancingDUnitTest extends LocatorTestBase {
   }
 
   private void checkConnectionCount(VM vm, final int count) {
-    Runnable checkConnectionCount = new SerializableRunnable("checkConnectionCount") {
+    SerializableRunnableIF checkConnectionCount = new SerializableRunnable("checkConnectionCount") {
       public void run() {
         Cache cache = (Cache) remoteObjects.get(CACHE_KEY);
         final CacheServerImpl server = (CacheServerImpl)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
index d0b0c30..5faba97 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest.java
@@ -45,6 +45,7 @@ import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 
 /**
  * This test is similar to {@link ConcurrentIndexUpdateWithoutWLDUnitTest} except
@@ -158,7 +159,7 @@ public class ConcurrentIndexUpdateWithInplaceObjectModFalseDUnitTest extends
   }
   
 
-  private Runnable getCacheSerializableRunnableForIndexValidation(
+  private SerializableRunnableIF getCacheSerializableRunnableForIndexValidation(
       final String regionName, final String indexName) {
     return new CacheSerializableRunnable("Index Validate") {
       @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
index 5f52042..fbead52 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/ConcurrentIndexUpdateWithoutWLDUnitTest.java
@@ -46,6 +46,7 @@ import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 
 /**
  * 
@@ -174,7 +175,7 @@ public class ConcurrentIndexUpdateWithoutWLDUnitTest extends
     
   }
 
-  private Runnable getCacheSerializableRunnableForIndexValidation(
+  private SerializableRunnableIF getCacheSerializableRunnableForIndexValidation(
       final String regionName, final String indexName) {
     return new CacheSerializableRunnable("Index Validate") {
       @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
index 331a05f..333cb07 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
@@ -31,9 +31,6 @@ import java.util.Random;
 import java.util.Set;
 import java.util.concurrent.CountDownLatch;
 
-import parReg.query.unittest.NewPortfolio;
-import util.TestException;
-
 import com.gemstone.gemfire.CancelException;
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.cache.AttributesFactory;
@@ -87,8 +84,12 @@ import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.util.test.TestUtil;
 
+import parReg.query.unittest.NewPortfolio;
+import util.TestException;
+
 /**
  * This is a helper class for the various Partitioned Query DUnit Test Cases
  * 
@@ -2502,7 +2503,7 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
     return prRemoveIndex;
   }
 
-  public Runnable getCacheSerializableRunnableForPRColocatedDataSetQueryAndCompareResults(
+  public SerializableRunnableIF getCacheSerializableRunnableForPRColocatedDataSetQueryAndCompareResults(
       final String name, final String coloName, final String localName,
       final String coloLocalName) {
 
@@ -2631,7 +2632,7 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
 
   }
 
-  public Runnable getCacheSerializableRunnableForPRAndRRQueryAndCompareResults(
+  public SerializableRunnableIF getCacheSerializableRunnableForPRAndRRQueryAndCompareResults(
       final String name, final String coloName, final String localName,
       final String coloLocalName) {
 
@@ -2761,7 +2762,7 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
   }
 
 
-  public Runnable getCacheSerializableRunnableForPRAndRRQueryWithCompactAndRangeIndexAndCompareResults(
+  public SerializableRunnableIF getCacheSerializableRunnableForPRAndRRQueryWithCompactAndRangeIndexAndCompareResults(
       final String name, final String coloName, final String localName,
       final String coloLocalName) {
 
@@ -2891,7 +2892,7 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
   }
 
 
-  public Runnable getCacheSerializableRunnableForRRAndPRQueryAndCompareResults(
+  public SerializableRunnableIF getCacheSerializableRunnableForRRAndPRQueryAndCompareResults(
       final String name, final String coloName, final String localName,
       final String coloLocalName) {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
index ac58ed2..a733753 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
@@ -14,501 +14,499 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import java.io.IOException;
-import java.util.LinkedList;
-import java.util.List;
-import java.util.Map;
-import java.util.concurrent.Callable;
-
-import com.gemstone.gemfire.LogWriter;
-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.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+package com.gemstone.gemfire.internal.cache;
+
+import java.io.IOException;
+import java.util.LinkedList;
+import java.util.List;
+import java.util.Map;
+
+import com.gemstone.gemfire.LogWriter;
+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.Host;
 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;
-
-/**
- * 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.
- * @author bruces
- *
- */
-public class ClientServerInvalidAndDestroyedEntryDUnitTest extends CacheTestCase {
-  
-  public ClientServerInvalidAndDestroyedEntryDUnitTest(String name) {
-    super(name);
-  }
-  
-  public void setUp() throws Exception {
-    super.setUp();
-    disconnectAllFromDS();
-  }
-  
-  public void testClientGetsInvalidEntry() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsInvalidEntry(regionName, false, false);
-  }
-  
-  public void testClientGetsInvalidEntryPR() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsInvalidEntry(regionName, true, false);
-  }
-
-  public void testClientGetsTombstone() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsTombstone(regionName, false, false);
-  }
-  
-  public void testClientGetsTombstonePR() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsTombstone(regionName, true, false);
-  }
-  
-
-  
-  // same tests but with transactions...
-  
-  
-
-  public void testClientGetsInvalidEntryTX() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsInvalidEntry(regionName, false, true);
-  }
-  
-  public void testClientGetsInvalidEntryPRTX() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsInvalidEntry(regionName, true, true);
-  }
-
-  public void testClientGetsTombstoneTX() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsTombstone(regionName, false, true);
-  }
-
-  public void testClientGetsTombstonePRTX() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestClientGetsTombstone(regionName, true, true);
-  }
-  
-  
-  // tests for bug #46780, tombstones left in client after RI
-  
-  public void testRegisterInterestRemovesOldEntry() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestRegisterInterestRemovesOldEntry(regionName, false);
-  }
-  
-  public void testRegisterInterestRemovesOldEntryPR() throws Exception {
-    final String regionName = getUniqueName()+"Region";
-    doTestRegisterInterestRemovesOldEntry(regionName, true);
-  }
-
-  /* this method creates a server cache and is used by all of the tests in this class */
-  private Callable getCreateServerCallable(final String regionName, final boolean usePR) {
-    return new SerializableCallable("create server and entries") {
-      public Object call() {
-        Cache cache = getCache();
-        List<CacheServer> servers = cache.getCacheServers();
-        CacheServer server;
-        if (servers.size() > 0) {
-          server = servers.get(0);
-        } else {
-          server = cache.addCacheServer();
-          int port = AvailablePortHelper.getRandomAvailableTCPPort();
-          server.setPort(port);
-          server.setHostnameForClients("localhost");
-          try {
-            server.start();
-          }
-          catch (IOException e) {
-            fail("Failed to start server ", e);
-          }
-        }
-        if (usePR) {
-          RegionFactory factory = cache.createRegionFactory(RegionShortcut.PARTITION);
-          PartitionAttributesFactory pf = new PartitionAttributesFactory();
-          pf.setTotalNumBuckets(2);
-          factory.setPartitionAttributes(pf.create());
-          factory.create(regionName);
-        } else {
-          cache.createRegionFactory(RegionShortcut.REPLICATE).create(regionName);
-        }
-        return server.getPort();
-      }
-    };
-  }
-  
-
-  /**
-   * Bug #43407 - when a client does a get(k) and the entry is invalid in the server
-   * we want the client to end up with an entry that is invalid.
-   */
-  private void doTestClientGetsInvalidEntry(final String regionName, final boolean usePR,
-      boolean useTX) throws Exception {
-    VM vm1 = Host.getHost(0).getVM(1);
-    VM vm2 = Host.getHost(0).getVM(2);
-    
-    // here are the keys that will be used to validate behavior.  Keys must be
-    // colocated if using both a partitioned region in the server and transactions
-    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
-    // except Object11 and IDoNotExist1
-    final String notAffectedKey = "Object1";
-    final String nonexistantKey = (usePR && useTX)? "IDoNotExist2" : "IDoNotExist1";
-    final String key1 = "Object10";
-    final String key2 = (usePR && useTX) ? "Object12" : "Object11";
-
-    Callable createServer = getCreateServerCallable(regionName, usePR);
-    int serverPort = (Integer)vm1.invoke(createServer);
-    vm2.invoke(createServer);
-    vm1.invoke(new SerializableRunnable("populate server and create invalid entry") {
-      public void run() {
-        Region myRegion =  getCache().getRegion(regionName);
-        for (int i=1; i<=20; i++) {
-          myRegion.put("Object"+i, "Value"+i);
-        }
-        myRegion.invalidate(key1);
-        myRegion.invalidate(key2);
-      }
-    });
-    getLogWriter().info("creating client cache");
-    ClientCache c = new ClientCacheFactory()
-                    .addPoolServer("localhost", serverPort)
-                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
-                    .create();
-    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
-    if (useTX) {
-      c.getCacheTransactionManager().begin();
-    }
-    
-    // get of a valid entry should work
-    assertNotNull(myRegion.get(notAffectedKey));
-    
-    // get of an invalid entry should return null and create the entry in an invalid state
-    getLogWriter().info("getting "+key1+" - should reach this cache and be INVALID");
-    assertNull(myRegion.get(key1));
-    assertTrue(myRegion.containsKey(key1));
-    
-    // since this might be a PR we also check the next key to force PR Get messaging
-    assertNull(myRegion.get(key2));
-    assertTrue(myRegion.containsKey(key2));
-    
-    // now try a key that doesn't exist anywhere
-    assertNull(myRegion.get(nonexistantKey));
-    assertFalse(myRegion.containsKey(nonexistantKey));
-
-    if (useTX) {
-      c.getCacheTransactionManager().commit();
-      
-      // test that the commit correctly created the entries in the region
-      assertNotNull(myRegion.get(notAffectedKey));
-      assertNull(myRegion.get(key1));
-      assertTrue(myRegion.containsKey(key1));
-      assertNull(myRegion.get(key2));
-      assertTrue(myRegion.containsKey(key2));
-    }
-
-    myRegion.localDestroy(notAffectedKey);
-    myRegion.localDestroy(key1);
-    myRegion.localDestroy(key2);
-    
-    if (useTX) {
-      c.getCacheTransactionManager().begin();
-    }
-
-    // check that getAll returns invalidated entries
-    List keys = new LinkedList();
-    keys.add(notAffectedKey); keys.add(key1); keys.add(key2);
-    Map result = myRegion.getAll(keys);
-    
-    assertNotNull(result.get(notAffectedKey));
-    assertNull(result.get(key1));
-    assertNull(result.get(key2));
-    assertTrue(result.containsKey(key1));
-    assertTrue(result.containsKey(key2));
-    assertTrue(myRegion.containsKey(key1));
-    assertTrue(myRegion.containsKey(key2));
-    
-    if (useTX) {
-      c.getCacheTransactionManager().commit();
-      // test that the commit correctly created the entries in the region
-      assertNotNull(myRegion.get(notAffectedKey));
-      assertNull(myRegion.get(key1));
-      assertTrue(myRegion.containsKey(key1));
-      assertNull(myRegion.get(key2));
-      assertTrue(myRegion.containsKey(key2));
-    }
-    
-    // test that a listener is not invoked when there is already an invalidated
-    // entry in the client cache
-    UpdateListener listener = new UpdateListener();
-    listener.log = getLogWriter();
-    myRegion.getAttributesMutator().addCacheListener(listener);
-    myRegion.get(key1);
-    assertEquals("expected no cache listener invocations",
-        0, listener.updateCount, listener.updateCount);
-    
-    myRegion.localDestroy(notAffectedKey);
-    myRegion.getAll(keys);
-    assertTrue("expected to find " + notAffectedKey, myRegion.containsKey(notAffectedKey));
-    assertEquals("expected only one listener invocation for " + notAffectedKey, 1, listener.updateCount);
-  }
-  
-  
-  
-  /**
-   * Similar to bug #43407 but not reported in a ticket, we want a client that
-   * does a get() on a destroyed entry to end up with a tombstone for that entry.
-   * This was already the case but there were no unit tests covering this for
-   * different server configurations and with/without transactions. 
-   */
-  private void doTestClientGetsTombstone(final String regionName, final boolean usePR,
-      boolean useTX) throws Exception {
-    VM vm1 = Host.getHost(0).getVM(1);
-    VM vm2 = Host.getHost(0).getVM(2);
-    
-    // here are the keys that will be used to validate behavior.  Keys must be
-    // colocated if using both a partitioned region in the server and transactions
-    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
-    // except Object11 and IDoNotExist1
-    final String notAffectedKey = "Object1";
-    final String nonexistantKey = (usePR && useTX)? "IDoNotExist2" : "IDoNotExist1";
-    final String key1 = "Object10";
-    final String key2 = (usePR && useTX) ? "Object12" : "Object11";
-
-    Callable createServer = getCreateServerCallable(regionName, usePR);
-    int serverPort = (Integer)vm1.invoke(createServer);
-    vm2.invoke(createServer);
-    vm1.invoke(new SerializableRunnable("populate server and create invalid entry") {
-      public void run() {
-        Region myRegion =  getCache().getRegion(regionName);
-        for (int i=1; i<=20; i++) {
-          myRegion.put("Object"+i, "Value"+i);
-        }
-        myRegion.destroy(key1);
-        myRegion.destroy(key2);
-      }
-    });
-    getLogWriter().info("creating client cache");
-    ClientCache c = new ClientCacheFactory()
-                    .addPoolServer("localhost", serverPort)
-                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
-                    .create();
-    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
-    if (useTX) {
-      c.getCacheTransactionManager().begin();
-    }
-    // get of a valid entry should work
-    assertNotNull(myRegion.get(notAffectedKey));
-    // get of an invalid entry should return null and create the entry in an invalid state
-    getLogWriter().info("getting "+key1+" - should reach this cache and be a TOMBSTONE");
-    assertNull(myRegion.get(key1));
-    assertFalse(myRegion.containsKey(key1));
-    RegionEntry entry;
-    if (!useTX) {
-      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-    }
-    
-    // since this might be a PR we also check the next key to force PR Get messaging
-    assertNull(myRegion.get(key2));
-    assertFalse(myRegion.containsKey(key2));
-    if (!useTX) {
-      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-    }
-
-    
-    // now try a key that doesn't exist anywhere
-    assertNull(myRegion.get(nonexistantKey));
-    assertFalse(myRegion.containsKey(nonexistantKey));
-
-    if (useTX) {
-      c.getCacheTransactionManager().commit();
-      
-      // test that the commit correctly created the entries in the region
-      assertNotNull(myRegion.get(notAffectedKey));
-      assertNull(myRegion.get(key1));
-      assertFalse(myRegion.containsKey(key1));
-      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-
-      assertNull(myRegion.get(key2));
-      assertFalse(myRegion.containsKey(key2));
-      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-    }
-
-    myRegion.localDestroy(notAffectedKey);
-    
-    if (useTX) {
-      c.getCacheTransactionManager().begin();
-    }
-
-    // check that getAll returns invalidated entries
-    List keys = new LinkedList();
-    keys.add(notAffectedKey); keys.add(key1); keys.add(key2);
-    Map result = myRegion.getAll(keys);
-    
-    getLogWriter().info("result of getAll = " + result);
-    assertNotNull(result.get(notAffectedKey));
-    assertNull(result.get(key1));
-    assertNull(result.get(key2));
-    assertFalse(myRegion.containsKey(key1));
-    assertFalse(myRegion.containsKey(key2));
-    if (!useTX) {
-      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-     
-      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-    } else { // useTX
-      c.getCacheTransactionManager().commit();
-      // test that the commit correctly created the entries in the region
-      assertNotNull(myRegion.get(notAffectedKey));
-      
-      assertNull(myRegion.get(key1));
-      assertFalse(myRegion.containsKey(key1));
-      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-
-      assertNull(myRegion.get(key2));
-      assertFalse(myRegion.containsKey(key2));
-      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
-      assertNotNull(entry); // it should be there
-      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
-    }
-    
-  }
-  
-  
-  private void doTestRegisterInterestRemovesOldEntry(final String regionName, final boolean usePR) throws Exception {
-    VM vm1 = Host.getHost(0).getVM(1);
-    VM vm2 = Host.getHost(0).getVM(2);
-    
-    // here are the keys that will be used to validate behavior.  Keys must be
-    // colocated if using both a partitioned region in the server and transactions
-    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
-    // except Object11 and IDoNotExist1
-    final String key10 = "Object10";
-    final String interestPattern = "Object.*";
-
-    Callable createServer = getCreateServerCallable(regionName, usePR);
-    int serverPort = (Integer)vm1.invoke(createServer);
-    vm2.invoke(createServer);
-    vm1.invoke(new SerializableRunnable("populate server") {
-      public void run() {
-        Region myRegion =  getCache().getRegion(regionName);
-        for (int i=1; i<=20; i++) {
-          myRegion.put("Object"+i, "Value"+i);
-        }
-      }
-    });
-    getLogWriter().info("creating client cache");
-    ClientCache c = new ClientCacheFactory()
-                    .addPoolServer("localhost", serverPort)
-                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
-                    .setPoolSubscriptionEnabled(true)
-                    .create();
-    
-    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
-
-    myRegion.registerInterestRegex(interestPattern);
-    
-    // make sure key1 is in the client because we're going to mess with it
-    assertNotNull(myRegion.get(key10));
-
-    // remove the entry for key1 on the servers and then simulate interest recovery
-    // to show that the entry for key1 is no longer there in the client when recovery
-    // finishes
-    SerializableRunnable destroyKey10 = new SerializableRunnable("locally destroy " + key10 + " in the servers") {
-      public void run() {
-        Region myRegion = getCache().getRegion(regionName);
-        EntryEventImpl event = ((LocalRegion)myRegion).generateEvictDestroyEvent(key10);
-        event.setOperation(Operation.LOCAL_DESTROY);
-        if (usePR) {
-          BucketRegion bucket = ((PartitionedRegion)myRegion).getBucketRegion(key10);
-          if (bucket != null) {
-            event.setRegion(bucket);
-            getLogWriter().info("performing local destroy in " + bucket + " ccEnabled="+bucket.concurrencyChecksEnabled + " rvv="+bucket.getVersionVector());
-            bucket.concurrencyChecksEnabled = false; // turn off cc so entry is removed
-            bucket.mapDestroy(event, false, false, null);
-            bucket.concurrencyChecksEnabled = true;
-          }
-        } else {
-          ((LocalRegion)myRegion).concurrencyChecksEnabled = false; // turn off cc so entry is removed
-          ((LocalRegion)myRegion).mapDestroy(event, false, false, null);
-          ((LocalRegion)myRegion).concurrencyChecksEnabled = true;
-        }
-      }
-    };
-    
-    vm1.invoke(destroyKey10);
-    vm2.invoke(destroyKey10);
-    
-    myRegion.getCache().getLogger().info("clearing keys of interest");
-    ((LocalRegion)myRegion).clearKeysOfInterest(interestPattern,
-        InterestType.REGULAR_EXPRESSION, InterestResultPolicy.KEYS_VALUES);
-    myRegion.getCache().getLogger().info("done clearing keys of interest");
-
-    assertTrue("expected region to be empty but it has " + myRegion.size() + " entries",
-        myRegion.size() == 0);
-    
-    RegionEntry entry;
-    entry = ((LocalRegion)myRegion).getRegionEntry(key10);
-    assertNull(entry); // it should have been removed
-
-    // now register interest.  At the end, finishRegisterInterest should clear
-    // out the entry for key1 because it was stored in image-state as a
-    // destroyed RI entry in clearKeysOfInterest
-    myRegion.registerInterestRegex(interestPattern);
-
-    entry = ((LocalRegion)myRegion).getRegionEntry(key10);
-    assertNull(entry); // it should not be there
-  }
-
-  static class UpdateListener extends CacheListenerAdapter {
-    int updateCount;
-    LogWriter log;
-    
-    @Override
-    public void afterUpdate(EntryEvent event) {
-//      log.info("UpdateListener.afterUpdate invoked for " + event, new Exception("stack trace"));
-      this.updateCount++;
-    }
-    @Override
-    public void afterCreate(EntryEvent event) {
-//      log.info("UpdateListener.afterCreate invoked for " + event, new Exception("stack trace"));
-      this.updateCount++;
-    }
-  }
-
-}
+import com.gemstone.gemfire.test.dunit.VM;
+
+/**
+ * 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.
+ * @author bruces
+ *
+ */
+public class ClientServerInvalidAndDestroyedEntryDUnitTest extends CacheTestCase {
+  
+  public ClientServerInvalidAndDestroyedEntryDUnitTest(String name) {
+    super(name);
+  }
+  
+  public void setUp() throws Exception {
+    super.setUp();
+    disconnectAllFromDS();
+  }
+  
+  public void testClientGetsInvalidEntry() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsInvalidEntry(regionName, false, false);
+  }
+  
+  public void testClientGetsInvalidEntryPR() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsInvalidEntry(regionName, true, false);
+  }
+
+  public void testClientGetsTombstone() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsTombstone(regionName, false, false);
+  }
+  
+  public void testClientGetsTombstonePR() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsTombstone(regionName, true, false);
+  }
+  
+
+  
+  // same tests but with transactions...
+  
+  
+
+  public void testClientGetsInvalidEntryTX() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsInvalidEntry(regionName, false, true);
+  }
+  
+  public void testClientGetsInvalidEntryPRTX() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsInvalidEntry(regionName, true, true);
+  }
+
+  public void testClientGetsTombstoneTX() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsTombstone(regionName, false, true);
+  }
+
+  public void testClientGetsTombstonePRTX() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestClientGetsTombstone(regionName, true, true);
+  }
+  
+  
+  // tests for bug #46780, tombstones left in client after RI
+  
+  public void testRegisterInterestRemovesOldEntry() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestRegisterInterestRemovesOldEntry(regionName, false);
+  }
+  
+  public void testRegisterInterestRemovesOldEntryPR() throws Exception {
+    final String regionName = getUniqueName()+"Region";
+    doTestRegisterInterestRemovesOldEntry(regionName, true);
+  }
+
+  /* this method creates a server cache and is used by all of the tests in this class */
+  private SerializableCallableIF getCreateServerCallable(final String regionName, final boolean usePR) {
+    return new SerializableCallable("create server and entries") {
+      public Object call() {
+        Cache cache = getCache();
+        List<CacheServer> servers = cache.getCacheServers();
+        CacheServer server;
+        if (servers.size() > 0) {
+          server = servers.get(0);
+        } else {
+          server = cache.addCacheServer();
+          int port = AvailablePortHelper.getRandomAvailableTCPPort();
+          server.setPort(port);
+          server.setHostnameForClients("localhost");
+          try {
+            server.start();
+          }
+          catch (IOException e) {
+            fail("Failed to start server ", e);
+          }
+        }
+        if (usePR) {
+          RegionFactory factory = cache.createRegionFactory(RegionShortcut.PARTITION);
+          PartitionAttributesFactory pf = new PartitionAttributesFactory();
+          pf.setTotalNumBuckets(2);
+          factory.setPartitionAttributes(pf.create());
+          factory.create(regionName);
+        } else {
+          cache.createRegionFactory(RegionShortcut.REPLICATE).create(regionName);
+        }
+        return server.getPort();
+      }
+    };
+  }
+  
+
+  /**
+   * Bug #43407 - when a client does a get(k) and the entry is invalid in the server
+   * we want the client to end up with an entry that is invalid.
+   */
+  private void doTestClientGetsInvalidEntry(final String regionName, final boolean usePR,
+      boolean useTX) throws Exception {
+    VM vm1 = Host.getHost(0).getVM(1);
+    VM vm2 = Host.getHost(0).getVM(2);
+    
+    // here are the keys that will be used to validate behavior.  Keys must be
+    // colocated if using both a partitioned region in the server and transactions
+    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
+    // except Object11 and IDoNotExist1
+    final String notAffectedKey = "Object1";
+    final String nonexistantKey = (usePR && useTX)? "IDoNotExist2" : "IDoNotExist1";
+    final String key1 = "Object10";
+    final String key2 = (usePR && useTX) ? "Object12" : "Object11";
+
+    SerializableCallableIF createServer = getCreateServerCallable(regionName, usePR);
+    int serverPort = (Integer)vm1.invoke(createServer);
+    vm2.invoke(createServer);
+    vm1.invoke(new SerializableRunnable("populate server and create invalid entry") {
+      public void run() {
+        Region myRegion =  getCache().getRegion(regionName);
+        for (int i=1; i<=20; i++) {
+          myRegion.put("Object"+i, "Value"+i);
+        }
+        myRegion.invalidate(key1);
+        myRegion.invalidate(key2);
+      }
+    });
+    getLogWriter().info("creating client cache");
+    ClientCache c = new ClientCacheFactory()
+                    .addPoolServer("localhost", serverPort)
+                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
+                    .create();
+    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
+    if (useTX) {
+      c.getCacheTransactionManager().begin();
+    }
+    
+    // get of a valid entry should work
+    assertNotNull(myRegion.get(notAffectedKey));
+    
+    // get of an invalid entry should return null and create the entry in an invalid state
+    getLogWriter().info("getting "+key1+" - should reach this cache and be INVALID");
+    assertNull(myRegion.get(key1));
+    assertTrue(myRegion.containsKey(key1));
+    
+    // since this might be a PR we also check the next key to force PR Get messaging
+    assertNull(myRegion.get(key2));
+    assertTrue(myRegion.containsKey(key2));
+    
+    // now try a key that doesn't exist anywhere
+    assertNull(myRegion.get(nonexistantKey));
+    assertFalse(myRegion.containsKey(nonexistantKey));
+
+    if (useTX) {
+      c.getCacheTransactionManager().commit();
+      
+      // test that the commit correctly created the entries in the region
+      assertNotNull(myRegion.get(notAffectedKey));
+      assertNull(myRegion.get(key1));
+      assertTrue(myRegion.containsKey(key1));
+      assertNull(myRegion.get(key2));
+      assertTrue(myRegion.containsKey(key2));
+    }
+
+    myRegion.localDestroy(notAffectedKey);
+    myRegion.localDestroy(key1);
+    myRegion.localDestroy(key2);
+    
+    if (useTX) {
+      c.getCacheTransactionManager().begin();
+    }
+
+    // check that getAll returns invalidated entries
+    List keys = new LinkedList();
+    keys.add(notAffectedKey); keys.add(key1); keys.add(key2);
+    Map result = myRegion.getAll(keys);
+    
+    assertNotNull(result.get(notAffectedKey));
+    assertNull(result.get(key1));
+    assertNull(result.get(key2));
+    assertTrue(result.containsKey(key1));
+    assertTrue(result.containsKey(key2));
+    assertTrue(myRegion.containsKey(key1));
+    assertTrue(myRegion.containsKey(key2));
+    
+    if (useTX) {
+      c.getCacheTransactionManager().commit();
+      // test that the commit correctly created the entries in the region
+      assertNotNull(myRegion.get(notAffectedKey));
+      assertNull(myRegion.get(key1));
+      assertTrue(myRegion.containsKey(key1));
+      assertNull(myRegion.get(key2));
+      assertTrue(myRegion.containsKey(key2));
+    }
+    
+    // test that a listener is not invoked when there is already an invalidated
+    // entry in the client cache
+    UpdateListener listener = new UpdateListener();
+    listener.log = getLogWriter();
+    myRegion.getAttributesMutator().addCacheListener(listener);
+    myRegion.get(key1);
+    assertEquals("expected no cache listener invocations",
+        0, listener.updateCount, listener.updateCount);
+    
+    myRegion.localDestroy(notAffectedKey);
+    myRegion.getAll(keys);
+    assertTrue("expected to find " + notAffectedKey, myRegion.containsKey(notAffectedKey));
+    assertEquals("expected only one listener invocation for " + notAffectedKey, 1, listener.updateCount);
+  }
+  
+  
+  
+  /**
+   * Similar to bug #43407 but not reported in a ticket, we want a client that
+   * does a get() on a destroyed entry to end up with a tombstone for that entry.
+   * This was already the case but there were no unit tests covering this for
+   * different server configurations and with/without transactions. 
+   */
+  private void doTestClientGetsTombstone(final String regionName, final boolean usePR,
+      boolean useTX) throws Exception {
+    VM vm1 = Host.getHost(0).getVM(1);
+    VM vm2 = Host.getHost(0).getVM(2);
+    
+    // here are the keys that will be used to validate behavior.  Keys must be
+    // colocated if using both a partitioned region in the server and transactions
+    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
+    // except Object11 and IDoNotExist1
+    final String notAffectedKey = "Object1";
+    final String nonexistantKey = (usePR && useTX)? "IDoNotExist2" : "IDoNotExist1";
+    final String key1 = "Object10";
+    final String key2 = (usePR && useTX) ? "Object12" : "Object11";
+
+    SerializableCallableIF createServer = getCreateServerCallable(regionName, usePR);
+    int serverPort = (Integer)vm1.invoke(createServer);
+    vm2.invoke(createServer);
+    vm1.invoke(new SerializableRunnable("populate server and create invalid entry") {
+      public void run() {
+        Region myRegion =  getCache().getRegion(regionName);
+        for (int i=1; i<=20; i++) {
+          myRegion.put("Object"+i, "Value"+i);
+        }
+        myRegion.destroy(key1);
+        myRegion.destroy(key2);
+      }
+    });
+    getLogWriter().info("creating client cache");
+    ClientCache c = new ClientCacheFactory()
+                    .addPoolServer("localhost", serverPort)
+                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
+                    .create();
+    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
+    if (useTX) {
+      c.getCacheTransactionManager().begin();
+    }
+    // get of a valid entry should work
+    assertNotNull(myRegion.get(notAffectedKey));
+    // get of an invalid entry should return null and create the entry in an invalid state
+    getLogWriter().info("getting "+key1+" - should reach this cache and be a TOMBSTONE");
+    assertNull(myRegion.get(key1));
+    assertFalse(myRegion.containsKey(key1));
+    RegionEntry entry;
+    if (!useTX) {
+      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+    }
+    
+    // since this might be a PR we also check the next key to force PR Get messaging
+    assertNull(myRegion.get(key2));
+    assertFalse(myRegion.containsKey(key2));
+    if (!useTX) {
+      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+    }
+
+    
+    // now try a key that doesn't exist anywhere
+    assertNull(myRegion.get(nonexistantKey));
+    assertFalse(myRegion.containsKey(nonexistantKey));
+
+    if (useTX) {
+      c.getCacheTransactionManager().commit();
+      
+      // test that the commit correctly created the entries in the region
+      assertNotNull(myRegion.get(notAffectedKey));
+      assertNull(myRegion.get(key1));
+      assertFalse(myRegion.containsKey(key1));
+      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+
+      assertNull(myRegion.get(key2));
+      assertFalse(myRegion.containsKey(key2));
+      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+    }
+
+    myRegion.localDestroy(notAffectedKey);
+    
+    if (useTX) {
+      c.getCacheTransactionManager().begin();
+    }
+
+    // check that getAll returns invalidated entries
+    List keys = new LinkedList();
+    keys.add(notAffectedKey); keys.add(key1); keys.add(key2);
+    Map result = myRegion.getAll(keys);
+    
+    getLogWriter().info("result of getAll = " + result);
+    assertNotNull(result.get(notAffectedKey));
+    assertNull(result.get(key1));
+    assertNull(result.get(key2));
+    assertFalse(myRegion.containsKey(key1));
+    assertFalse(myRegion.containsKey(key2));
+    if (!useTX) {
+      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+     
+      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+    } else { // useTX
+      c.getCacheTransactionManager().commit();
+      // test that the commit correctly created the entries in the region
+      assertNotNull(myRegion.get(notAffectedKey));
+      
+      assertNull(myRegion.get(key1));
+      assertFalse(myRegion.containsKey(key1));
+      entry = ((LocalRegion)myRegion).getRegionEntry(key1);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+
+      assertNull(myRegion.get(key2));
+      assertFalse(myRegion.containsKey(key2));
+      entry = ((LocalRegion)myRegion).getRegionEntry(key2);
+      assertNotNull(entry); // it should be there
+      assertTrue(entry.isTombstone()); // it should be a destroyed entry with Token.TOMBSTONE
+    }
+    
+  }
+  
+  
+  private void doTestRegisterInterestRemovesOldEntry(final String regionName, final boolean usePR) throws Exception {
+    VM vm1 = Host.getHost(0).getVM(1);
+    VM vm2 = Host.getHost(0).getVM(2);
+    
+    // here are the keys that will be used to validate behavior.  Keys must be
+    // colocated if using both a partitioned region in the server and transactions
+    // in the client.  All of these keys hash to bucket 0 in a two-bucket PR
+    // except Object11 and IDoNotExist1
+    final String key10 = "Object10";
+    final String interestPattern = "Object.*";
+
+    SerializableCallableIF createServer = getCreateServerCallable(regionName, usePR);
+    int serverPort = (Integer)vm1.invoke(createServer);
+    vm2.invoke(createServer);
+    vm1.invoke(new SerializableRunnable("populate server") {
+      public void run() {
+        Region myRegion =  getCache().getRegion(regionName);
+        for (int i=1; i<=20; i++) {
+          myRegion.put("Object"+i, "Value"+i);
+        }
+      }
+    });
+    getLogWriter().info("creating client cache");
+    ClientCache c = new ClientCacheFactory()
+                    .addPoolServer("localhost", serverPort)
+                    .set(DistributionConfig.LOG_LEVEL_NAME, getDUnitLogLevel())
+                    .setPoolSubscriptionEnabled(true)
+                    .create();
+    
+    Region myRegion = c.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);;
+
+    myRegion.registerInterestRegex(interestPattern);
+    
+    // make sure key1 is in the client because we're going to mess with it
+    assertNotNull(myRegion.get(key10));
+
+    // remove the entry for key1 on the servers and then simulate interest recovery
+    // to show that the entry for key1 is no longer there in the client when recovery
+    // finishes
+    SerializableRunnable destroyKey10 = new SerializableRunnable("locally destroy " + key10 + " in the servers") {
+      public void run() {
+        Region myRegion = getCache().getRegion(regionName);
+        EntryEventImpl event = ((LocalRegion)myRegion).generateEvictDestroyEvent(key10);
+        event.setOperation(Operation.LOCAL_DESTROY);
+        if (usePR) {
+          BucketRegion bucket = ((PartitionedRegion)myRegion).getBucketRegion(key10);
+          if (bucket != null) {
+            event.setRegion(bucket);
+            getLogWriter().info("performing local destroy in " + bucket + " ccEnabled="+bucket.concurrencyChecksEnabled + " rvv="+bucket.getVersionVector());
+            bucket.concurrencyChecksEnabled = false; // turn off cc so entry is removed
+            bucket.mapDestroy(event, false, false, null);
+            bucket.concurrencyChecksEnabled = true;
+          }
+        } else {
+          ((LocalRegion)myRegion).concurrencyChecksEnabled = false; // turn off cc so entry is removed
+          ((LocalRegion)myRegion).mapDestroy(event, false, false, null);
+          ((LocalRegion)myRegion).concurrencyChecksEnabled = true;
+        }
+      }
+    };
+    
+    vm1.invoke(destroyKey10);
+    vm2.invoke(destroyKey10);
+    
+    myRegion.getCache().getLogger().info("clearing keys of interest");
+    ((LocalRegion)myRegion).clearKeysOfInterest(interestPattern,
+        InterestType.REGULAR_EXPRESSION, InterestResultPolicy.KEYS_VALUES);
+    myRegion.getCache().getLogger().info("done clearing keys of interest");
+
+    assertTrue("expected region to be empty but it has " + myRegion.size() + " entries",
+        myRegion.size() == 0);
+    
+    RegionEntry entry;
+    entry = ((LocalRegion)myRegion).getRegionEntry(key10);
+    assertNull(entry); // it should have been removed
+
+    // now register interest.  At the end, finishRegisterInterest should clear
+    // out the entry for key1 because it was stored in image-state as a
+    // destroyed RI entry in clearKeysOfInterest
+    myRegion.registerInterestRegex(interestPattern);
+
+    entry = ((LocalRegion)myRegion).getRegionEntry(key10);
+    assertNull(entry); // it should not be there
+  }
+
+  static class UpdateListener extends CacheListenerAdapter {
+    int updateCount;
+    LogWriter log;
+    
+    @Override
+    public void afterUpdate(EntryEvent event) {
+//      log.info("UpdateListener.afterUpdate invoked for " + event, new Exception("stack trace"));
+      this.updateCount++;
+    }
+    @Override
+    public void afterCreate(EntryEvent event) {
+//      log.info("UpdateListener.afterCreate invoked for " + event, new Exception("stack trace"));
+      this.updateCount++;
+    }
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
index 96cf859..f092196 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
@@ -16,6 +16,11 @@
  */
 package com.gemstone.gemfire.management.internal.cli.commands;
 
+import java.io.Serializable;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheLoader;
 import com.gemstone.gemfire.cache.CacheLoaderException;
@@ -37,13 +42,9 @@ import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
 
-import java.io.Serializable;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Properties;
-
 /**
  * The GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest class is test suite of test cases testing the Gfsh
  * 'get' data command when a cache miss occurs on data in a Region with a CacheLoader defined.
@@ -280,7 +281,7 @@ public class GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest extends C
       return vm;
     }
 
-    public void run(final Runnable runnable) {
+    public void run(final SerializableRunnableIF runnable) {
       if (getVm() == null) {
         runnable.run();
       } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
index 1d1d491..acb7759 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
@@ -16,6 +16,9 @@
  */
 package com.gemstone.gemfire.management.internal.cli.commands;
 
+import java.io.Serializable;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.DiskStore;
@@ -27,11 +30,9 @@ import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
 
-import java.io.Serializable;
-import java.util.Properties;
-
 /**
  * The ListAndDescribeDiskStoreCommandsDUnitTest class is a test suite of functional tests cases testing the proper
  * functioning of the 'list disk-store' and 'describe disk-store' commands. </p>
@@ -186,7 +187,7 @@ public class ListAndDescribeDiskStoreCommandsDUnitTest extends CliCommandTestBas
       return vm;
     }
 
-    public void run(final Runnable runnable) {
+    public void run(final SerializableRunnableIF runnable) {
       if (getVm() == null) {
         runnable.run();
       } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
index 1a611ec..399e89c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
@@ -16,6 +16,18 @@
  */
 package com.gemstone.gemfire.management.internal.cli.commands;
 
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Properties;
+import java.util.Random;
+import java.util.Set;
+import java.util.concurrent.atomic.AtomicLong;
+
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Region;
@@ -34,20 +46,9 @@ import com.gemstone.gemfire.management.internal.cli.domain.IndexDetails;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
 
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.HashSet;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Properties;
-import java.util.Random;
-import java.util.Set;
-import java.util.concurrent.atomic.AtomicLong;
-
 /**
  * The ListIndexCommandDUnitTest class is distributed test suite of test cases for testing the index-based GemFire shell
  * (Gfsh) commands. </p>
@@ -360,7 +361,7 @@ public class ListIndexCommandDUnitTest extends CliCommandTestBase {
       return (regionDefinitions != null && regions.removeAll(Arrays.asList(regionDefinitions)));
     }
 
-    public void run(final Runnable runnable) {
+    public void run(final SerializableRunnableIF runnable) {
       if (getVm() == null) {
         runnable.run();
       } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
index f6cc88f..6735fe5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
@@ -49,7 +49,7 @@ import com.gemstone.gemfire.SystemFailure;
  *
  * @see VM#invokeAsync(Class, String)
  */
-public class AsyncInvocation extends Thread {
+public class AsyncInvocation<T> extends Thread {
   
   private static final ThreadLocal returnValue = new ThreadLocal();
 
@@ -69,7 +69,7 @@ public class AsyncInvocation extends Thread {
   private String methodName;
   
   /** The returned object if any */
-  public volatile Object returnedObj = null;
+  public volatile T returnedObj = null;
 
   //////////////////////  Constructors  //////////////////////
 
@@ -176,7 +176,7 @@ public class AsyncInvocation extends Thread {
     }
   }
   
-  public Object getResult() throws Throwable {
+  public T getResult() throws Throwable {
     join();
     if(this.exceptionOccurred()) {
       throw new Exception("An exception occured during async invocation", this.exception);
@@ -184,7 +184,7 @@ public class AsyncInvocation extends Thread {
     return this.returnedObj;
   }
   
-  public Object getResult(long waitTime) throws Throwable {
+  public T getResult(long waitTime) throws Throwable {
     join(waitTime);
     if(this.isAlive()) {
       throw new TimeoutException();
@@ -195,7 +195,7 @@ public class AsyncInvocation extends Thread {
     return this.returnedObj;
   }
 
-  public Object getReturnValue() {
+  public T getReturnValue() {
     if (this.isAlive()) {
       throw new InternalGemFireError("Return value not available while thread is alive.");
     }
@@ -205,7 +205,7 @@ public class AsyncInvocation extends Thread {
   public void run()
   {
     super.run();
-    this.returnedObj = returnValue.get();
+    this.returnedObj = (T) returnValue.get();
     returnValue.set(null);
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
index cee0d85..60c20e3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallable.java
@@ -45,7 +45,7 @@ import java.util.concurrent.Callable;
  * 
  * @author Mitch Thomas
  */
-public abstract class SerializableCallable<T> implements Callable<T>, Serializable {
+public abstract class SerializableCallable<T> implements SerializableCallableIF<T> {
   
   private static final long serialVersionUID = -5914706166172952484L;
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallableIF.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallableIF.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallableIF.java
new file mode 100644
index 0000000..c3d3ae7
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableCallableIF.java
@@ -0,0 +1,24 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.Serializable;
+import java.util.concurrent.Callable;
+
+public interface SerializableCallableIF<T> extends Serializable, Callable<T> {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
index 85ae738..5798861 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnable.java
@@ -47,7 +47,7 @@ import java.io.Serializable;
  * </PRE>
  */
 public abstract class SerializableRunnable
-  implements Serializable, Runnable {
+  implements SerializableRunnableIF {
 
   private static final long serialVersionUID = 7584289978241650456L;
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnableIF.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnableIF.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnableIF.java
new file mode 100644
index 0000000..648e4f8
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/SerializableRunnableIF.java
@@ -0,0 +1,23 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.Serializable;
+
+public interface SerializableRunnableIF extends Serializable, Runnable {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
index ddc653b..7abd20f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
@@ -236,7 +236,7 @@ public class VM implements java.io.Serializable {
    *
    * @see SerializableRunnable
    */
-  public AsyncInvocation invokeAsync(Runnable r) {
+  public AsyncInvocation invokeAsync(SerializableRunnableIF r) {
     return invokeAsync(r, "run", new Object[0]);
   }
   
@@ -249,7 +249,7 @@ public class VM implements java.io.Serializable {
    *
    * @see SerializableCallable
    */
-  public AsyncInvocation invokeAsync(Callable c) {
+  public <T> AsyncInvocation<T> invokeAsync(SerializableCallableIF<T> c) {
     return invokeAsync(c, "call", new Object[0]);
   }
 
@@ -263,7 +263,7 @@ public class VM implements java.io.Serializable {
    *
    * @see SerializableRunnable
    */
-  public void invoke(Runnable r) {
+  public void invoke(SerializableRunnableIF r) {
     invoke(r, "run");
   }
   
@@ -277,8 +277,8 @@ public class VM implements java.io.Serializable {
    *
    * @see SerializableCallable
    */
-  public Object invoke(Callable c) {
-    return invoke(c, "call");
+  public <T>  T invoke(SerializableCallableIF<T> c) {
+    return (T) invoke(c, "call");
   }
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
index 2947f4b..18e5f72 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
@@ -19,6 +19,7 @@ package com.gemstone.gemfire.test.dunit.tests;
 import java.util.Properties;
 
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DUnitEnv;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.RMIException;
@@ -55,7 +56,31 @@ public class BasicDUnitTest extends DistributedTestCase {
     } catch (RMIException ex) {
       assertTrue(ex.getCause() instanceof BasicTestException);
     }
-  } 
+  }
+  
+  public void testInvokeWithLambda() {
+    Host host = Host.getHost(0);
+    VM vm0 = host.getVM(0);
+    VM vm1 = host.getVM(1);
+    
+    int vm0Num = vm0.invoke(() -> DUnitEnv.get().getVMID());
+    int vm1Num = vm1.invoke(() -> DUnitEnv.get().getVMID());
+    
+    assertEquals(0, vm0Num);
+    assertEquals(1, vm1Num);
+    
+  }
+  
+  public void testInvokeLambdaAsync() throws Throwable {
+    Host host = Host.getHost(0);
+    VM vm0 = host.getVM(0);
+    
+    AsyncInvocation<Integer> async0 = vm0.invokeAsync(() -> DUnitEnv.get().getVMID());
+    int vm0num = async0.getResult();
+    
+    assertEquals(0, vm0num);
+    
+  }
 
   static class BasicTestException extends RuntimeException {
     BasicTestException() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
index 78f7196..b9cce7f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
@@ -23,6 +23,7 @@ import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.SerializableRunnableIF;
 import com.gemstone.gemfire.test.dunit.VM;
 
 /**
@@ -149,7 +150,7 @@ public class VMDUnitTest extends DistributedTestCase {
   }
 
   protected static class InvokeRunnable
-    implements Serializable, Runnable {
+    implements SerializableRunnableIF {
 
     public void run() {
       throw new BasicDUnitTest.BasicTestException();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/93deadc4/gemfire-core/src/test/java/hydra/MethExecutor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/hydra/MethExecutor.java b/gemfire-core/src/test/java/hydra/MethExecutor.java
index 8eef85d..c38a803 100644
--- a/gemfire-core/src/test/java/hydra/MethExecutor.java
+++ b/gemfire-core/src/test/java/hydra/MethExecutor.java
@@ -240,7 +240,7 @@ public class MethExecutor {
                                            Object[] args) {
     try {
       // get the class
-      Class receiverClass = Class.forName(target.getClass().getName());
+      Class receiverClass = target.getClass();
 
       // invoke the method
       Object res = null;


[36/52] [abbrv] incubator-geode git commit: cleaned up test code

Posted by ds...@apache.org.
cleaned up test code


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/0fdf64f5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/0fdf64f5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/0fdf64f5

Branch: refs/heads/feature/GEODE-831
Commit: 0fdf64f56faf1e0db54817bd0722f17324212f79
Parents: 3dd04f2
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Wed Jan 27 11:01:23 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Wed Jan 27 11:01:23 2016 -0800

----------------------------------------------------------------------
 .../gemstone/gemfire/internal/offheap/FreeListManagerTest.java  | 5 ++---
 1 file changed, 2 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/0fdf64f5/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
index e90fa11..4667ac5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
@@ -1,9 +1,9 @@
 package com.gemstone.gemfire.internal.offheap;
 
-//import static org.junit.Assert.*;
+import static org.junit.Assert.*;
 import static org.mockito.Mockito.*;
 import static com.googlecode.catchexception.CatchException.*;
-import static org.assertj.core.api.Assertions.*;
+import static org.assertj.core.api.Assertions.assertThat;
 
 import java.util.ArrayList;
 
@@ -293,7 +293,6 @@ public class FreeListManagerTest {
 
     catchException(this.freeListManager).allocate(DEFAULT_SLAB_SIZE-7);
 
-    assertThat((Exception)caughtException()).isInstanceOf(OutOfOffHeapMemoryException.class);
     verify(ooohml).outOfOffHeapMemory(caughtException());
   }
   


[28/52] [abbrv] incubator-geode git commit: GEODE-819: Fix dunit imports in WAN and CQ tests

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
index 13fd228..4cb03ae 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPropogationDUnitTest.java
@@ -40,11 +40,10 @@ import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
 import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.ExpectedException;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.ExpectedException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 public class ReplicatedRegion_ParallelWANPropogationDUnitTest extends WANTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/SenderWithTransportFilterDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/SenderWithTransportFilterDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/SenderWithTransportFilterDUnitTest.java
index 03b1354..3fdc672 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/SenderWithTransportFilterDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/SenderWithTransportFilterDUnitTest.java
@@ -41,8 +41,7 @@ import com.gemstone.gemfire.internal.cache.wan.CompressionOutputStream;
 import com.gemstone.gemfire.internal.cache.wan.InternalGatewaySenderFactory;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase.MyLocatorCallback;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class SenderWithTransportFilterDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ShutdownAllPersistentGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ShutdownAllPersistentGatewaySenderDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ShutdownAllPersistentGatewaySenderDUnitTest.java
index 53243eb..647dded 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ShutdownAllPersistentGatewaySenderDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ShutdownAllPersistentGatewaySenderDUnitTest.java
@@ -27,11 +27,10 @@ import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
 import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ShutdownAllPersistentGatewaySenderDUnitTest extends WANTestBase {
   private static final long MAX_WAIT = 70000;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANLocatorServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANLocatorServerDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANLocatorServerDUnitTest.java
index 9f003b4..50bb4b9 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANLocatorServerDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANLocatorServerDUnitTest.java
@@ -35,8 +35,7 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.Host;
 
 public class WANLocatorServerDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANSSLDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANSSLDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANSSLDUnitTest.java
index 7f582f3..c80a447 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANSSLDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WANSSLDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.internal.cache.wan.misc;
 
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class WANSSLDUnitTest extends WANTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
index 848bf4f..19e42c1 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/WanAutoDiscoveryDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.GemFireConfigException;
 import com.gemstone.gemfire.IncompatibleSystemException;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
 
 public class WanAutoDiscoveryDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
index 871e6d1..19f6c4b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
@@ -22,11 +22,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.GatewaySenderException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.RMIException;
-import dunit.DistributedTestCase.ExpectedException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.ExpectedException;
 
 /**
  * DUnit test for operations on ParallelGatewaySender

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
index 8c8233a..cb64868 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueueOverflowDUnitTest.java
@@ -38,8 +38,7 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * DUnit for ParallelSenderQueue overflow operations.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
index 48786a7..2d200bf 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPersistenceEnabledGatewaySenderDUnitTest.java
@@ -26,9 +26,8 @@ import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
 import com.gemstone.gemfire.internal.cache.ColocationHelper;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase.ExpectedException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.ExpectedException;
 
 public class ParallelWANPersistenceEnabledGatewaySenderDUnitTest extends
     WANTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationClientServerDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationClientServerDUnitTest.java
index aa83f68..7286403 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationClientServerDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationClientServerDUnitTest.java
@@ -17,8 +17,7 @@
 package com.gemstone.gemfire.internal.cache.wan.parallel;
 
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationConcurrentOpsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationConcurrentOpsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationConcurrentOpsDUnitTest.java
index e1c315a..674de6a 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationConcurrentOpsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationConcurrentOpsDUnitTest.java
@@ -21,8 +21,7 @@ import java.util.HashMap;
 import java.util.List;
 
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class ParallelWANPropagationConcurrentOpsDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
index a43f4ba..5b93bc2 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANPropagationDUnitTest.java
@@ -30,8 +30,7 @@ import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.BatchException70;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase.MyGatewayEventFilter;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class ParallelWANPropagationDUnitTest extends WANTestBase {
   private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
index c846254..4da0868 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
@@ -22,8 +22,7 @@ import java.util.Map;
 
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase.MyGatewayEventFilter;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class ParallelWANStatsDUnitTest extends WANTestBase{
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderDistributedDeadlockDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderDistributedDeadlockDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderDistributedDeadlockDUnitTest.java
index 54a641c..fd0b753 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderDistributedDeadlockDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderDistributedDeadlockDUnitTest.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.execute.*;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 //The tests here are to validate changes introduced because a distributed deadlock
 //was found that caused issues for a production customer. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
index d0251e8..82bbce0 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderEventListenerDUnitTest.java
@@ -28,8 +28,7 @@ import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.MyGatewaySenderEventListener;
 import com.gemstone.gemfire.internal.cache.wan.MyGatewaySenderEventListener2;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
index b9e4f7f..d30289b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderOperationsDUnitTest.java
@@ -25,9 +25,8 @@ import com.gemstone.gemfire.cache.wan.GatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.GatewaySenderException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.RMIException;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderQueueDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderQueueDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderQueueDUnitTest.java
index 3995d65..eec1341 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderQueueDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialGatewaySenderQueueDUnitTest.java
@@ -41,8 +41,7 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 public class SerialGatewaySenderQueueDUnitTest extends WANTestBase{

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPersistenceEnabledGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPersistenceEnabledGatewaySenderDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPersistenceEnabledGatewaySenderDUnitTest.java
index a95e9e4..ede5e09 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPersistenceEnabledGatewaySenderDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPersistenceEnabledGatewaySenderDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.internal.cache.wan.serial;
 
 
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogationDUnitTest.java
index 81a66ac..c33d7aa 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogationDUnitTest.java
@@ -25,8 +25,7 @@ import com.gemstone.gemfire.cache.client.ServerOperationException;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.wan.BatchException70;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class SerialWANPropogationDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogation_PartitionedRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogation_PartitionedRegionDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogation_PartitionedRegionDUnitTest.java
index 5356ffb..9ae58cc 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogation_PartitionedRegionDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANPropogation_PartitionedRegionDUnitTest.java
@@ -21,8 +21,7 @@ import com.gemstone.gemfire.CancelException;
 import com.gemstone.gemfire.cache.CacheClosedException;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class SerialWANPropogation_PartitionedRegionDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
index 39f4d34..979439b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
@@ -22,8 +22,7 @@ import java.util.Map;
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase.MyGatewayEventFilter;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class SerialWANStatsDUnitTest extends WANTestBase {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WANCommandTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WANCommandTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WANCommandTestBase.java
index bebf631..d0ea193 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WANCommandTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WANCommandTestBase.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.internal.cli.commands.CliCommandTestBase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class WANCommandTestBase extends CliCommandTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandCreateGatewayReceiverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandCreateGatewayReceiverDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandCreateGatewayReceiverDUnitTest.java
index 5be0c45..a06b32e 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandCreateGatewayReceiverDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandCreateGatewayReceiverDUnitTest.java
@@ -29,9 +29,8 @@ import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * DUnit tests for 'create gateway-receiver' command.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStartDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStartDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStartDUnitTest.java
index 1314eda..f38f5b9 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStartDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStartDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class WanCommandGatewayReceiverStartDUnitTest extends WANCommandTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStopDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStopDUnitTest.java
index 5c44015..439a74b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStopDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/wancommand/WanCommandGatewayReceiverStopDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class WanCommandGatewayReceiverStopDUnitTest extends WANCommandTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/management/WANManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/WANManagementDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/WANManagementDUnitTest.java
index 3fd4a88..08f6cac 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/WANManagementDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/WANManagementDUnitTest.java
@@ -27,10 +27,9 @@ import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests for WAN artifacts like Sender and Receiver. The purpose of this test is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/configuration/ClusterConfigurationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/configuration/ClusterConfigurationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/configuration/ClusterConfigurationDUnitTest.java
index b35f230..79d5aa2 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/configuration/ClusterConfigurationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/configuration/ClusterConfigurationDUnitTest.java
@@ -53,10 +53,11 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
 import com.gemstone.gemfire.management.internal.configuration.domain.XmlEntity;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
+
 import org.apache.commons.io.FileUtils;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestRemoteClusterDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestRemoteClusterDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestRemoteClusterDUnitTest.java
index 908fa65..46e2d3f 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestRemoteClusterDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestRemoteClusterDUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.management.ManagementTestBase;
 import com.gemstone.gemfire.management.RegionMXBean;
 
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing remote Cluster


[08/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionExecution_ExceptionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionExecution_ExceptionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionExecution_ExceptionDUnitTest.java
index f5211df..78d3827 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionExecution_ExceptionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionExecution_ExceptionDUnitTest.java
@@ -35,11 +35,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 public class FunctionExecution_ExceptionDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
index bc28b7b..3c36a60 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStatsDUnitTest.java
@@ -52,12 +52,11 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /*
  * This is DUnite Test to test the Function Execution stats under various

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
index 580ceb3..5dfb429 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetDUnitTest.java
@@ -44,12 +44,11 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.LocalDataSetFunction;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class LocalDataSetDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
index a3b6f56..8b0d4ba 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalDataSetIndexingDUnitTest.java
@@ -67,9 +67,8 @@ import com.gemstone.gemfire.internal.cache.LocalDataSet;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.LocalDataSetFunction;
 import com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
index 94b6b48..f58d349 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/LocalFunctionExecutionDUnitTest.java
@@ -34,11 +34,10 @@ import com.gemstone.gemfire.cache.execute.ResultCollector;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class LocalFunctionExecutionDUnitTest extends DistributedTestCase{
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
index 4b8f009..9508726 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MemberFunctionExecutionDUnitTest.java
@@ -48,11 +48,10 @@ import com.gemstone.gemfire.i18n.LogWriterI18n;
 import com.gemstone.gemfire.internal.ClassBuilder;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 public class MemberFunctionExecutionDUnitTest extends CacheTestCase {
   private static final String TEST_FUNCTION6 = TestFunction.TEST_FUNCTION6;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
index f4af8af..b9f0dc2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/MultiRegionFunctionExecutionDUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.Assert;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings("serial")
 public class MultiRegionFunctionExecutionDUnitTest extends CacheTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
index 6cb1ffd..fd5b1a4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/OnGroupsFunctionExecutionDUnitTest.java
@@ -43,11 +43,10 @@ import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
index 2e7736b..72780f1 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionDUnitTest.java
@@ -56,10 +56,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class PRClientServerRegionFunctionExecutionDUnitTest extends PRClientServerTestBase {
   private static final String TEST_FUNCTION7 = TestFunction.TEST_FUNCTION7;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
index 48cb646..5ee1472 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionFailoverDUnitTest.java
@@ -44,12 +44,11 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRClientServerRegionFunctionExecutionFailoverDUnitTest extends
     PRClientServerTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
index 75b047d..0344a55 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest.java
@@ -47,9 +47,8 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class PRClientServerRegionFunctionExecutionNoSingleHopDUnitTest extends
     PRClientServerTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
index cae1482..cf97932 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest.java
@@ -47,9 +47,8 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class PRClientServerRegionFunctionExecutionSelectorNoSingleHopDUnitTest extends
     PRClientServerTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
index ec29d91..d6f2fd8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerRegionFunctionExecutionSingleHopDUnitTest.java
@@ -47,9 +47,8 @@ import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
   public class PRClientServerRegionFunctionExecutionSingleHopDUnitTest extends PRClientServerTestBase {
     private static final String TEST_FUNCTION7 = TestFunction.TEST_FUNCTION7;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
index c86a941..7026ead 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRClientServerTestBase.java
@@ -51,12 +51,11 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 public class PRClientServerTestBase extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRColocationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRColocationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRColocationDUnitTest.java
index 95bd7f5..63b2334 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRColocationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRColocationDUnitTest.java
@@ -60,13 +60,11 @@ import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.Shipment;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 /**
  * This is the test for the custom and colocated partitioning of
  * PartitionedRegion

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
index a6b7170..302edd7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
@@ -51,10 +51,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore.BucketVisitor;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRCustomPartitioningDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionDUnitTest.java
index c12b556..7424088 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionDUnitTest.java
@@ -66,13 +66,12 @@ import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class PRFunctionExecutionDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionTimeOutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionTimeOutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionTimeOutDUnitTest.java
index a0f2789..6ded986 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionTimeOutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionTimeOutDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRFunctionExecutionTimeOutDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionWithResultSenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionWithResultSenderDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionWithResultSenderDUnitTest.java
index 4d6f5ae..1a4d040 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionWithResultSenderDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRFunctionExecutionWithResultSenderDUnitTest.java
@@ -47,10 +47,9 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRFunctionExecutionWithResultSenderDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRPerformanceTestDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRPerformanceTestDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRPerformanceTestDUnitTest.java
index 3b82948..8f99059 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRPerformanceTestDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRPerformanceTestDUnitTest.java
@@ -52,10 +52,9 @@ import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDUnitTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PRPerformanceTestDUnitTest extends
     PartitionedRegionDUnitTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
index 0cce82b..75a9f20 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRTransactionDUnitTest.java
@@ -43,8 +43,7 @@ import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.data.Shipment;
 import com.gemstone.gemfire.internal.cache.execute.data.ShipmentId;
-
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 /**
  * Test for co-located PR transactions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/SingleHopGetAllPutAllDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/SingleHopGetAllPutAllDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/SingleHopGetAllPutAllDUnitTest.java
index b6cb1ac..5ed07ab 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/SingleHopGetAllPutAllDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/SingleHopGetAllPutAllDUnitTest.java
@@ -31,8 +31,7 @@ import com.gemstone.gemfire.cache.client.internal.ClientPartitionAdvisor;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class SingleHopGetAllPutAllDUnitTest extends PRClientServerTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/DistributedRegionFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/DistributedRegionFunction.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/DistributedRegionFunction.java
index 823b04f..030980d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/DistributedRegionFunction.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/DistributedRegionFunction.java
@@ -24,9 +24,8 @@ import com.gemstone.gemfire.cache.execute.FunctionContext;
 import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.Assert;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 @SuppressWarnings("serial")
 public class DistributedRegionFunction extends FunctionAdapter {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/TestFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/TestFunction.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/TestFunction.java
index 02ad57f..95a9da9 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/TestFunction.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/functions/TestFunction.java
@@ -41,9 +41,8 @@ import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTar
 import com.gemstone.gemfire.internal.cache.execute.MyFunctionExecutionException;
 import com.gemstone.gemfire.internal.cache.execute.RegionFunctionContextImpl;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 import java.io.Serializable;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
index c59cb9d..04f7f60 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARQAddOperationJUnitTest.java
@@ -31,10 +31,9 @@ import org.junit.experimental.categories.Category;
 import com.gemstone.gemfire.cache.CacheException;
 import com.gemstone.gemfire.internal.cache.Conflatable;
 import com.gemstone.gemfire.internal.cache.EventID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Test runs all tests of HARQAddOperationJUnitTest using BlockingHARegionQueue
  * instead of HARegionQueue

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionJUnitTest.java
index 5f16d15..e7b5314 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/BlockingHARegionJUnitTest.java
@@ -32,11 +32,10 @@ import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 @Category(IntegrationTest.class)
 public class BlockingHARegionJUnitTest
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug36853EventsExpiryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug36853EventsExpiryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug36853EventsExpiryDUnitTest.java
index 1b68cb2..63b2ea8 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug36853EventsExpiryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug36853EventsExpiryDUnitTest.java
@@ -35,9 +35,8 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is a bug test for 36853 (Expiry logic in HA is used to expire early data

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48571DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48571DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48571DUnitTest.java
index a372385..6278d9e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48571DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48571DUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class Bug48571DUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48879DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48879DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48879DUnitTest.java
index 7f263fc..0457ce1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48879DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/Bug48879DUnitTest.java
@@ -32,10 +32,9 @@ import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings("serial")
 public class Bug48879DUnitTest extends DistributedTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/EventIdOptimizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/EventIdOptimizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/EventIdOptimizationDUnitTest.java
index 4ec4a87..fe1edb0 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/EventIdOptimizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/EventIdOptimizationDUnitTest.java
@@ -41,14 +41,13 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
 import com.gemstone.gemfire.cache.client.internal.Connection;
 import com.gemstone.gemfire.cache.client.internal.QueueStateImpl.SequenceIdAndExpirationObject;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This test verifies that eventId, while being sent across the network ( client
  * to server, server to client and peer to peer) , goes as optimized byte-array.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/FailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/FailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/FailoverDUnitTest.java
index 66eca22..fa07821 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/FailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/FailoverDUnitTest.java
@@ -39,13 +39,12 @@ import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  *
  *  Dunit test to verify HA feature. Have 2 nodes S1 & S2. Client is connected to S1 & S2 with S1 as the primary end point.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HABugInPutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HABugInPutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HABugInPutDUnitTest.java
index 7bf8c2f..c356816 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HABugInPutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HABugInPutDUnitTest.java
@@ -34,10 +34,9 @@ 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.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This Dunit test is to verify the bug in put() operation. When the put is invoked on the server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAClearDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAClearDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAClearDUnitTest.java
index 532c439..2528b2b 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAClearDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAClearDUnitTest.java
@@ -37,12 +37,11 @@ import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
 import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.Region;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This is the Dunit test to verify clear and destroyRegion operation in
  * Client-Server configuration.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAConflationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAConflationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAConflationDUnitTest.java
index b144a04..a86b50a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAConflationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAConflationDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
-
-import dunit.Host;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * This is Targetted conflation Dunit test.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
index f585d65..b4fd1ac 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADuplicateDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is the Dunit test to verify the duplicates after the fail over

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
index a04852a..ae3a4dc 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAEventIdPropagationDUnitTest.java
@@ -46,10 +46,9 @@ import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.RegionEventImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAExpiryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAExpiryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAExpiryDUnitTest.java
index 94de722..3d3eb0a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAExpiryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAExpiryDUnitTest.java
@@ -34,11 +34,10 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.HARegion;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test checks Expiration of events in the regionqueue.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
index c5d9607..1c151e7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIBugDUnitTest.java
@@ -37,12 +37,11 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.HARegion;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test points out the bug when GII of HARegion Queue is happening and at the same time it is receiving puts from peer to peer.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIDUnitTest.java
index 9e47f7a..93cd77e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HAGIIDUnitTest.java
@@ -47,11 +47,10 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientTombstoneMessage;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
 import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Client is connected to S1 which has a slow dispatcher. Puts are made on S1.  Then S2 is started

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
index 71f3cd3..205ba4a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQAddOperationJUnitTest.java
@@ -47,10 +47,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.Conflatable;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.logging.LogService;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Test to verify Add operation to HARegion Queue with and without conflation.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
index 7516d5d..84c2f05 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARQueueNewImplDUnitTest.java
@@ -52,10 +52,9 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessage;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
 import com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import util.TestException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionDUnitTest.java
index 066abe6..59780ef 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionDUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.HARegion;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to verify :

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
index dffa01f..fc15226 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueDUnitTest.java
@@ -43,10 +43,9 @@ 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.HARegion;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueJUnitTest.java
index 6f2fc7b..55df641 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HARegionQueueJUnitTest.java
@@ -54,10 +54,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.Conflatable;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * This is a test for the APIs of a HARegionQueue and verifies that the head,
  * tail and size counters are updated properly.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HASlowReceiverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HASlowReceiverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HASlowReceiverDUnitTest.java
index 9d10c56..90fc817 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HASlowReceiverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/HASlowReceiverDUnitTest.java
@@ -37,9 +37,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class HASlowReceiverDUnitTest extends DistributedTestCase {
   protected static Cache cache = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/OperationsPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/OperationsPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/OperationsPropagationDUnitTest.java
index 4738a72..de0979e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/OperationsPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/OperationsPropagationDUnitTest.java
@@ -33,10 +33,9 @@ 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.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/PutAllDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/PutAllDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/PutAllDUnitTest.java
index 4140133..ef82f7a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/PutAllDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/PutAllDUnitTest.java
@@ -42,10 +42,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/StatsBugDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/StatsBugDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/StatsBugDUnitTest.java
index 3d09f80..f246a8a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/StatsBugDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ha/StatsBugDUnitTest.java
@@ -34,12 +34,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This is Dunit test for bug 36109. This test has a cache-client having a primary
  * and a secondary cache-server as its endpoint. Primary does some operations

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/locks/TXLockServiceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/locks/TXLockServiceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/locks/TXLockServiceDUnitTest.java
index bc6fad1..6d60816 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/locks/TXLockServiceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/locks/TXLockServiceDUnitTest.java
@@ -16,15 +16,28 @@
  */
 package com.gemstone.gemfire.internal.cache.locks;
 
-import com.gemstone.gemfire.internal.cache.TXRegionLockRequestImpl;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.locks.*;
-import dunit.*;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Properties;
+import java.util.Set;
 
-import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.cache.CommitConflictException;
+import com.gemstone.gemfire.distributed.DistributedLockService;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.distributed.internal.DM;
+import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import com.gemstone.gemfire.distributed.internal.locks.DLockRecoverGrantorProcessor;
+import com.gemstone.gemfire.distributed.internal.locks.DLockService;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.internal.cache.TXRegionLockRequestImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * This class tests distributed ownership via the DistributedLockService api.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug39356DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug39356DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug39356DUnitTest.java
index f933c85..13adb98 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug39356DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug39356DUnitTest.java
@@ -40,11 +40,10 @@ import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
 import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug43684DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug43684DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug43684DUnitTest.java
index 85344ee..8410030 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug43684DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug43684DUnitTest.java
@@ -35,10 +35,9 @@ 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.i18n.LocalizedStrings;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * TODO This doesn't really test the optimised RI behaviour but only that RI

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug47388DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug47388DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug47388DUnitTest.java
index 30ddba2..3512385 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug47388DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug47388DUnitTest.java
@@ -41,10 +41,9 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueueStats;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * The test creates two datastores with a partitioned region, and also running a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
index e19d728..9234db4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/Bug51400DUnitTest.java
@@ -35,11 +35,10 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxyStats;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ElidedPutAllDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ElidedPutAllDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ElidedPutAllDUnitTest.java
index 4eded5b..681d0d9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ElidedPutAllDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ElidedPutAllDUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.internal.cache.RegionEntry;
 import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
 import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
index 14542cd..e35b014 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionResolverDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Customer;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.Serializable;
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionLoaderWriterDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionLoaderWriterDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionLoaderWriterDUnitTest.java
index 39d0cd3..2678621 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionLoaderWriterDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionLoaderWriterDUnitTest.java
@@ -32,8 +32,8 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PartitionedRegionLoaderWriterDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionMetaDataCleanupDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionMetaDataCleanupDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionMetaDataCleanupDUnitTest.java
index 00ac788..825774d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionMetaDataCleanupDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PartitionedRegionMetaDataCleanupDUnitTest.java
@@ -21,11 +21,10 @@ import com.gemstone.gemfire.cache.RegionFactory;
 import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-
-import dunit.Host;
-import dunit.RMIException;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistPRKRFDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistPRKRFDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistPRKRFDUnitTest.java
index 92fcf51..c0a0149 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistPRKRFDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistPRKRFDUnitTest.java
@@ -27,11 +27,10 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.DiskStoreImpl;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the basic use cases for PR persistence.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentColocatedPartitionedRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentColocatedPartitionedRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentColocatedPartitionedRegionDUnitTest.java
index 8437664..dc89894 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentColocatedPartitionedRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentColocatedPartitionedRegionDUnitTest.java
@@ -43,12 +43,11 @@ import com.gemstone.gemfire.internal.cache.InitialImageOperation.RequestImageMes
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserver;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
index d043df8..794d418 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
@@ -74,14 +74,13 @@ import com.gemstone.gemfire.internal.cache.InitialImageOperation.RequestImageMes
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage.ManageBucketReplyMessage;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the basic use cases for PR persistence.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
index 057be81..267136a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionTestBase.java
@@ -56,11 +56,10 @@ import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserver;
 import com.gemstone.gemfire.internal.cache.persistence.PersistenceAdvisor;
 import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionWithTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionWithTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionWithTransactionDUnitTest.java
index f55c446..845a14c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionWithTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/PersistentPartitionedRegionWithTransactionDUnitTest.java
@@ -21,11 +21,10 @@ import com.gemstone.gemfire.cache.CacheTransactionManager;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.internal.cache.DiskStoreImpl;
 import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the basic use cases for PR persistence.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ShutdownAllDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ShutdownAllDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ShutdownAllDUnitTest.java
index 5ac547e..97ff82d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ShutdownAllDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/ShutdownAllDUnitTest.java
@@ -55,14 +55,13 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserver;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the basic use cases for PR persistence.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationManyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationManyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationManyDUnitTest.java
index ffdcb49..abc088a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationManyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationManyDUnitTest.java
@@ -19,18 +19,33 @@
 //
 package com.gemstone.gemfire.internal.cache.partitioned;
 
-import java.util.*;
-import dunit.*;
-
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
+
 import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.PartitionAttributes;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.cache30.CacheTestCase;
+import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.ReplyException;
+import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache30.*;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class StreamingPartitionOperationManyDUnitTest extends CacheTestCase {
 



[34/52] [abbrv] incubator-geode git commit: GEODE-852: do not rename the GemFireVersion.properties file

Posted by ds...@apache.org.
GEODE-852: do not rename the GemFireVersion.properties file

* closes #80 (committed by klund)


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/49a984c2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/49a984c2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/49a984c2

Branch: refs/heads/feature/GEODE-831
Commit: 49a984c23918eabfd6f573aac0b66c51e731490e
Parents: 4e211e2
Author: Jinmei Liao <ji...@pivotal.io>
Authored: Wed Jan 27 09:18:35 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Wed Jan 27 10:12:40 2016 -0800

----------------------------------------------------------------------
 gemfire-pulse/build.gradle                      | 55 +++-----------------
 .../pulse/internal/data/PulseConstants.java     |  4 +-
 .../gemfire/tools/pulse/tests/PulseTest.java    | 32 +++++-------
 3 files changed, 22 insertions(+), 69 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/49a984c2/gemfire-pulse/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-pulse/build.gradle b/gemfire-pulse/build.gradle
index 4c1135d..78043cd 100755
--- a/gemfire-pulse/build.gradle
+++ b/gemfire-pulse/build.gradle
@@ -78,60 +78,17 @@ def generatedResources = "$buildDir/generated-resources/main"
 
 sourceSets {
   main {
-    output.dir(generatedResources, builtBy: 'createPulsePropFile')
+    output.dir(generatedResources, builtBy: 'copyGemFireVersionFile')
   }
 }
 
-// Creates the version properties file and writes it to the resources dir
-task createPulsePropFile {
-  description 'Creates a new Pule properties file with build/ version information'
-  def propertiesFile = file(generatedResources + "/pulseversion.properties");
-  outputs.file propertiesFile
-  inputs.dir compileJava.destinationDir
-
-  doLast {
-    try {
-      def grgit = org.ajoberstar.grgit.Grgit.open()
-      ext.branch = grgit.branch.getCurrent().name
-      ext.commitId = grgit.head().id
-      ext.sourceDate = grgit.head().getDate().format('yyyy-MM-dd HH:mm:ss Z')
-      grgit.close()
-    } catch (Exception e) {
-      logger.warn('***** Unable to find Git workspace. Using default version information *****')
-      ext.branch = 'UNKNOWN'
-      ext.commitId = 'UNKNOWN'
-      ext.sourceDate = 'UNKNOWN'
-    }
-    // Build machine & java information - for screen output only
-    ext.osArch = System.getProperty('os.arch')
-    ext.osName = System.getProperty('os.name')
-    ext.osVersion = System.getProperty('os.version')
-    ext.jdkVersion = System.getProperty('java.version')
-
-    ext.buildDate = new Date().format('yyyy-MM-dd HH:mm:ss Z')
-    ext.buildNumber = new Date().format('MMddyy')
-
-    def props = [
-            "pulse.version"     : version,
-            "Build-Id"          : ext.buildNumber,
-            "Build-Date"        : ext.buildDate,
-            "Source-Date"       : ext.sourceDate,
-            "Source-Revision"   : ext.commitId,
-            "Source-Repository" : ext.branch
-    ] as Properties
-
-    propertiesFile.getParentFile().mkdirs();
-    new FileOutputStream(propertiesFile).withStream { fos ->
-      props.store(fos, '')
-    }
-  }
+task copyGemFireVersionFile(type: Copy) {
+  from project(':gemfire-core').buildDir.absolutePath + "/generated-resources/main/com/gemstone/gemfire/internal/GemFireVersion.properties"
+  into generatedResources
 }
 
 jar {
   from sourceSets.main.output
-  doFirst {
-    project.createPulsePropFile
-  }
 }
 
 eclipse.classpath.file {
@@ -150,9 +107,9 @@ artifacts {
   archives war
 }
 
-def pulseWarFile = "gemfire-pulse-"+version+".war"
-
 war {
   classpath configurations.runtime
   classpath project(':gemfire-core').webJar.archivePath
 }
+
+uiTest.dependsOn war

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/49a984c2/gemfire-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
----------------------------------------------------------------------
diff --git a/gemfire-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java b/gemfire-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
index 9c22a03..9c5732e 100644
--- a/gemfire-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
+++ b/gemfire-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
@@ -37,8 +37,8 @@ public class PulseConstants {
   public static final String APPLICATION_COUNTRY = "US";
 
   // Pulse version details properties from properties file
-  public static final String PULSE_VERSION_PROPERTIES_FILE = "pulseversion.properties";
-  public static final String PROPERTY_PULSE_VERSION = "pulse.version";
+  public static final String PULSE_VERSION_PROPERTIES_FILE = "GemFireVersion.properties";
+  public static final String PROPERTY_PULSE_VERSION = "Product-Version";
   public static final String PROPERTY_BUILD_ID = "Build-Id";
   public static final String PROPERTY_BUILD_DATE = "Build-Date";
   public static final String PROPERTY_SOURCE_DATE = "Source-Date";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/49a984c2/gemfire-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTest.java
----------------------------------------------------------------------
diff --git a/gemfire-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTest.java b/gemfire-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTest.java
index d30c14c..ec06085 100644
--- a/gemfire-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTest.java
+++ b/gemfire-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTest.java
@@ -18,23 +18,10 @@
  */
 package com.vmware.gemfire.tools.pulse.tests;
 
-import java.io.*;
-import java.text.DecimalFormat;
-import java.util.List;
-import java.util.Properties;
-import java.util.concurrent.TimeUnit;
-
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import com.gemstone.gemfire.test.junit.categories.UITest;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
 import junit.framework.Assert;
-
 import org.apache.catalina.startup.Tomcat;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-import org.junit.FixMethodOrder;
-import org.junit.Ignore;
-import org.junit.Test;
+import org.junit.*;
 import org.junit.experimental.categories.Category;
 import org.junit.runners.MethodSorters;
 import org.openqa.selenium.By;
@@ -47,6 +34,15 @@ import org.openqa.selenium.support.ui.ExpectedCondition;
 import org.openqa.selenium.support.ui.ExpectedConditions;
 import org.openqa.selenium.support.ui.WebDriverWait;
 
+import java.io.BufferedReader;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.InputStream;
+import java.text.DecimalFormat;
+import java.util.List;
+import java.util.Properties;
+import java.util.concurrent.TimeUnit;
+
 @Category(UITest.class)
 @FixMethodOrder(MethodSorters.JVM)
 public class PulseTest {
@@ -181,13 +177,13 @@ public class PulseTest {
         String warPath = null;
         ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
         InputStream inputStream = classLoader
-                .getResourceAsStream("pulseversion.properties");
+                .getResourceAsStream("GemFireVersion.properties");
         Properties properties = new Properties();
         properties.load(inputStream);
-        String version = properties.getProperty("pulse.version");
+        String version = properties.getProperty("Product-Version");
         warPath = "gemfire-pulse-"+version+".war";
-        String propFilePath = classLoader.getResource("pulseversion.properties").getPath();
-        warPath = propFilePath.substring(0, propFilePath.indexOf("resources"))+"libs/"+warPath;
+        String propFilePath = classLoader.getResource("GemFireVersion.properties").getPath();
+        warPath = propFilePath.substring(0, propFilePath.indexOf("generated-resources"))+"libs/"+warPath;
         return warPath;
     }
 


[39/52] [abbrv] incubator-geode git commit: added AddressableMemoryChunk interface and factory

Posted by ds...@apache.org.
added AddressableMemoryChunk interface and factory


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/3ca7b3e2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/3ca7b3e2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/3ca7b3e2

Branch: refs/heads/feature/GEODE-831
Commit: 3ca7b3e2f15da237b50636b96e50a36fbb6d97b4
Parents: 0fdf64f
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Wed Jan 27 17:21:08 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Wed Jan 27 17:21:08 2016 -0800

----------------------------------------------------------------------
 .../offheap/AddressableMemoryChunk.java         | 29 +++++++++
 .../offheap/AddressableMemoryChunkFactory.java  | 27 +++++++++
 .../gemfire/internal/offheap/Fragment.java      |  5 ++
 .../internal/offheap/FreeListManager.java       | 26 ++++----
 .../offheap/SimpleMemoryAllocatorImpl.java      | 14 ++---
 .../internal/offheap/UnsafeMemoryChunk.java     | 16 ++---
 .../internal/offheap/FreeListManagerTest.java   | 62 ++++++++++++++++++++
 .../offheap/SimpleMemoryAllocatorJUnitTest.java | 13 ++--
 .../offheap/UnsafeMemoryChunkJUnitTest.java     |  2 +-
 9 files changed, 155 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunk.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunk.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunk.java
new file mode 100644
index 0000000..7916e1f
--- /dev/null
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunk.java
@@ -0,0 +1,29 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.internal.offheap;
+
+/**
+ * A memory chunk that also has an address of its memory.
+ */
+public interface AddressableMemoryChunk extends MemoryChunk {
+
+  /**
+   * Return the address of the memory of this chunk.
+   */
+  public long getMemoryAddress();
+
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunkFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunkFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunkFactory.java
new file mode 100644
index 0000000..fa2dd78
--- /dev/null
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/AddressableMemoryChunkFactory.java
@@ -0,0 +1,27 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.internal.offheap;
+
+/**
+ * Used to create AddressableMemoryChunk instances.
+ */
+public interface AddressableMemoryChunkFactory {
+  /** Create and return an AddressableMemoryChunk.
+   * @throws OutOfMemoryError if the create fails
+   */
+  public AddressableMemoryChunk create(int size);
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/Fragment.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/Fragment.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/Fragment.java
index eda864c..d178198 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/Fragment.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/Fragment.java
@@ -131,4 +131,9 @@ public class Fragment implements MemoryBlock {
     long value = this.getMemoryAddress();
     return (int)(value ^ (value >>> 32));
   }
+  @Override
+  public String toString() {
+    return "Fragment [baseAddr=" + baseAddr + ", size=" + size + ", freeIdx=" + freeIdx + "]";
+  }
+
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
index 9d759f5..586689f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
@@ -40,7 +40,7 @@ public class FreeListManager {
   /** The MemoryChunks that this allocator is managing by allocating smaller chunks of them.
    * The contents of this array never change.
    */
-  private final UnsafeMemoryChunk[] slabs;
+  private final AddressableMemoryChunk[] slabs;
   private final long totalSlabSize;
   
   final private AtomicReferenceArray<SyncChunkStack> tinyFreeLists = new AtomicReferenceArray<SyncChunkStack>(TINY_FREE_LIST_COUNT);
@@ -58,7 +58,7 @@ public class FreeListManager {
     }
     return result;
   }
-  private void getLiveChunks(UnsafeMemoryChunk slab, List<Chunk> result) {
+  private void getLiveChunks(AddressableMemoryChunk slab, List<Chunk> result) {
     long addr = slab.getMemoryAddress();
     while (addr <= (slab.getMemoryAddress() + slab.getSize() - Chunk.MIN_CHUNK_SIZE)) {
       Fragment f = isAddrInFragmentFreeSpace(addr);
@@ -126,7 +126,7 @@ public class FreeListManager {
   private final CopyOnWriteArrayList<Fragment> fragmentList;
   private final SimpleMemoryAllocatorImpl ma;
 
-  public FreeListManager(SimpleMemoryAllocatorImpl ma, final UnsafeMemoryChunk[] slabs) {
+  public FreeListManager(SimpleMemoryAllocatorImpl ma, final AddressableMemoryChunk[] slabs) {
     this.ma = ma;
     this.slabs = slabs;
     long total = 0;
@@ -479,6 +479,9 @@ public class FreeListManager {
     collectFreeHugeChunks(l);
     collectFreeTinyChunks(l);
   }
+  List<Fragment> getFragmentList() {
+    return this.fragmentList;
+  }
   private void collectFreeFragmentChunks(List<SyncChunkStack> l) {
     if (this.fragmentList.size() == 0) return;
     SyncChunkStack result = new SyncChunkStack();
@@ -490,14 +493,11 @@ public class FreeListManager {
         diff = f.getSize() - offset;
       } while (diff >= Chunk.MIN_CHUNK_SIZE && !f.allocate(offset, offset+diff));
       if (diff < Chunk.MIN_CHUNK_SIZE) {
-        if (diff > 0) {
-          SimpleMemoryAllocatorImpl.logger.debug("Lost memory of size {}", diff);
-        }
-        // fragment is too small to turn into a chunk
-        // TODO we need to make sure this never happens
-        // by keeping sizes rounded. I think I did this
-        // by introducing MIN_CHUNK_SIZE and by rounding
-        // the size of huge allocations.
+        // If diff > 0 then that memory will be lost during compaction.
+        // This should never happen since we keep the sizes rounded
+        // based on MIN_CHUNK_SIZE.
+        assert diff == 0;
+        // The current fragment is completely allocated so just skip it.
         continue;
       }
       long chunkAddr = f.getMemoryAddress()+offset;
@@ -861,7 +861,7 @@ public class FreeListManager {
    * be used. Note that this code does not bother
    * comparing the contents of the arrays.
    */
-  boolean okToReuse(UnsafeMemoryChunk[] newSlabs) {
+  boolean okToReuse(AddressableMemoryChunk[] newSlabs) {
     return newSlabs == null || newSlabs == this.slabs;
   }
   
@@ -870,7 +870,7 @@ public class FreeListManager {
   }
   int findSlab(long addr) {
     for (int i=0; i < this.slabs.length; i++) {
-      UnsafeMemoryChunk slab = this.slabs[i];
+      AddressableMemoryChunk slab = this.slabs[i];
       long slabAddr = slab.getMemoryAddress();
       if (addr >= slabAddr) {
         if (addr < slabAddr + slab.getSize()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
index 122b23c..6b3a730 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorImpl.java
@@ -90,9 +90,9 @@ public class SimpleMemoryAllocatorImpl implements MemoryAllocator {
   public static MemoryAllocator create(OutOfOffHeapMemoryListener ooohml, OffHeapMemoryStats stats, LogWriter lw, 
       int slabCount, long offHeapMemorySize, long maxSlabSize) {
     return create(ooohml, stats, lw, slabCount, offHeapMemorySize, maxSlabSize,
-        null, new UnsafeMemoryChunk.Factory() {
+        null, new AddressableMemoryChunkFactory() {
       @Override
-      public UnsafeMemoryChunk create(int size) {
+      public AddressableMemoryChunk create(int size) {
         return new UnsafeMemoryChunk(size);
       }
     });
@@ -100,7 +100,7 @@ public class SimpleMemoryAllocatorImpl implements MemoryAllocator {
 
   private static SimpleMemoryAllocatorImpl create(OutOfOffHeapMemoryListener ooohml, OffHeapMemoryStats stats, LogWriter lw, 
       int slabCount, long offHeapMemorySize, long maxSlabSize, 
-      UnsafeMemoryChunk[] slabs, UnsafeMemoryChunk.Factory memChunkFactory) {
+      AddressableMemoryChunk[] slabs, AddressableMemoryChunkFactory memChunkFactory) {
     SimpleMemoryAllocatorImpl result = singleton;
     boolean created = false;
     try {
@@ -163,11 +163,11 @@ public class SimpleMemoryAllocatorImpl implements MemoryAllocator {
     return result;
   }
   static SimpleMemoryAllocatorImpl createForUnitTest(OutOfOffHeapMemoryListener ooohml, OffHeapMemoryStats stats, LogWriter lw, 
-      int slabCount, long offHeapMemorySize, long maxSlabSize, UnsafeMemoryChunk.Factory memChunkFactory) {
+      int slabCount, long offHeapMemorySize, long maxSlabSize, AddressableMemoryChunkFactory memChunkFactory) {
     return create(ooohml, stats, lw, slabCount, offHeapMemorySize, maxSlabSize, 
         null, memChunkFactory);
   }
-  public static SimpleMemoryAllocatorImpl createForUnitTest(OutOfOffHeapMemoryListener oooml, OffHeapMemoryStats stats, UnsafeMemoryChunk[] slabs) {
+  public static SimpleMemoryAllocatorImpl createForUnitTest(OutOfOffHeapMemoryListener oooml, OffHeapMemoryStats stats, AddressableMemoryChunk[] slabs) {
     int slabCount = 0;
     long offHeapMemorySize = 0;
     long maxSlabSize = 0;
@@ -185,7 +185,7 @@ public class SimpleMemoryAllocatorImpl implements MemoryAllocator {
   }
   
   
-  private void reuse(OutOfOffHeapMemoryListener oooml, LogWriter lw, OffHeapMemoryStats newStats, long offHeapMemorySize, UnsafeMemoryChunk[] slabs) {
+  private void reuse(OutOfOffHeapMemoryListener oooml, LogWriter lw, OffHeapMemoryStats newStats, long offHeapMemorySize, AddressableMemoryChunk[] slabs) {
     if (isClosed()) {
       throw new IllegalStateException("Can not reuse a closed off-heap memory manager.");
     }
@@ -205,7 +205,7 @@ public class SimpleMemoryAllocatorImpl implements MemoryAllocator {
     this.stats = newStats;
   }
 
-  private SimpleMemoryAllocatorImpl(final OutOfOffHeapMemoryListener oooml, final OffHeapMemoryStats stats, final UnsafeMemoryChunk[] slabs) {
+  private SimpleMemoryAllocatorImpl(final OutOfOffHeapMemoryListener oooml, final OffHeapMemoryStats stats, final AddressableMemoryChunk[] slabs) {
     if (oooml == null) {
       throw new IllegalArgumentException("OutOfOffHeapMemoryListener is null");
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunk.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunk.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunk.java
index ed1c843..aebc459 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunk.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunk.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.pdx.internal.unsafe.UnsafeWrapper;
  * 
  * @since 9.0
  */
-public class UnsafeMemoryChunk implements MemoryChunk {
+public class UnsafeMemoryChunk implements AddressableMemoryChunk {
   private static final UnsafeWrapper unsafe;
   private static final int ARRAY_BYTE_BASE_OFFSET;
   private static String reason;
@@ -70,6 +70,10 @@ public class UnsafeMemoryChunk implements MemoryChunk {
     return (int)this.size;
   }
   
+  /* (non-Javadoc)
+   * @see com.gemstone.gemfire.internal.offheap.AddressableMemoryChunk#getMemoryAddress()
+   */
+  @Override
   public long getMemoryAddress() {
     return this.data;
   }
@@ -210,14 +214,4 @@ public class UnsafeMemoryChunk implements MemoryChunk {
     sb.append("}");
     return sb.toString();
   }
-  
-  /**
-   * Used to create UnsafeMemoryChunk instances.
-   */
-  public interface Factory {
-    /** Create and return an UnsafeMemoryChunk.
-     * @throws OutOfMemoryError if the create fails
-     */
-    public UnsafeMemoryChunk create(int size);
-  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
index 4667ac5..73b0e37 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
@@ -272,9 +272,71 @@ public class FreeListManagerTest {
     }
     
     assertThat(this.freeListManager.compact(DEFAULT_SLAB_SIZE)).isTrue();
+    assertThat(this.freeListManager.getFragmentList()).hasSize(4);
   }
   
   @Test
+  public void compactWithLiveChunks() {
+    int SMALL_SLAB = 16;
+    int MEDIUM_SLAB = 128;
+    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+        new UnsafeMemoryChunk(SMALL_SLAB), 
+        new UnsafeMemoryChunk(SMALL_SLAB), 
+        new UnsafeMemoryChunk(MEDIUM_SLAB), 
+        slab});
+    ArrayList<Chunk> chunks = new ArrayList<>();
+    chunks.add(this.freeListManager.allocate(SMALL_SLAB-8+1));
+    this.freeListManager.allocate(DEFAULT_SLAB_SIZE/2-8);
+    chunks.add(this.freeListManager.allocate(DEFAULT_SLAB_SIZE/2-8));
+    this.freeListManager.allocate(SMALL_SLAB-8+1);
+    for (Chunk c: chunks) {
+      Chunk.release(c.getMemoryAddress(), this.freeListManager);
+    }
+    
+    assertThat(this.freeListManager.compact(DEFAULT_SLAB_SIZE/2)).isTrue();
+  }
+  
+  @Test
+  public void compactAfterAllocatingAll() {
+    setUpSingleSlabManager();
+    Chunk c = freeListManager.allocate(DEFAULT_SLAB_SIZE-8);
+    
+    assertThat(this.freeListManager.compact(1)).isFalse();
+    // call compact twice for extra code coverage
+    assertThat(this.freeListManager.compact(1)).isFalse();
+    assertThat(this.freeListManager.getFragmentList()).isEmpty();
+  }
+  
+  @Test
+  public void compactWithEmptyTinyFreeList() {
+    setUpSingleSlabManager();
+    Fragment originalFragment = this.freeListManager.getFragmentList().get(0);
+    Chunk c = freeListManager.allocate(16);
+    Chunk.release(c.getMemoryAddress(), this.freeListManager);
+    c = freeListManager.allocate(16);
+    
+    assertThat(this.freeListManager.compact(1)).isTrue();
+    assertThat(this.freeListManager.getFragmentList()).hasSize(1);
+    Fragment compactedFragment = this.freeListManager.getFragmentList().get(0);
+    assertThat(compactedFragment.getSize()).isEqualTo(originalFragment.getSize()-(16+8));
+    assertThat(compactedFragment.getMemoryAddress()).isEqualTo(originalFragment.getMemoryAddress()+(16+8));
+  }
+  
+  @Test
+  public void allocationsThatLeaveLessThanMinChunkSizeFreeInAFragment() {
+    int SMALL_SLAB = 16;
+    int MEDIUM_SLAB = 128;
+    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+        new UnsafeMemoryChunk(SMALL_SLAB), 
+        new UnsafeMemoryChunk(SMALL_SLAB), 
+        new UnsafeMemoryChunk(MEDIUM_SLAB), 
+        slab});
+    this.freeListManager.allocate(DEFAULT_SLAB_SIZE-8-(Chunk.MIN_CHUNK_SIZE-1));
+    this.freeListManager.allocate(MEDIUM_SLAB-8-(Chunk.MIN_CHUNK_SIZE-1));
+    
+    assertThat(this.freeListManager.compact(SMALL_SLAB)).isTrue();
+  }
+ @Test
   public void maxAllocationUsesAllMemory() {
     setUpSingleSlabManager();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorJUnitTest.java
index 2a51c21..2f47509 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/SimpleMemoryAllocatorJUnitTest.java
@@ -32,7 +32,6 @@ import org.junit.experimental.categories.Category;
 import com.gemstone.gemfire.OutOfOffHeapMemoryException;
 import com.gemstone.gemfire.cache.CacheClosedException;
 import com.gemstone.gemfire.internal.logging.NullLogWriter;
-import com.gemstone.gemfire.internal.offheap.UnsafeMemoryChunk.Factory;
 import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
 @Category(UnitTest.class)
@@ -98,9 +97,9 @@ public class SimpleMemoryAllocatorJUnitTest {
       LastSevereLogger logger = new LastSevereLogger();
       try {
         SimpleMemoryAllocatorImpl.createForUnitTest(listener, stats, logger, 10, 950, 100,
-            new UnsafeMemoryChunk.Factory() {
+            new AddressableMemoryChunkFactory() {
           @Override
-          public UnsafeMemoryChunk create(int size) {
+          public AddressableMemoryChunk create(int size) {
             throw new OutOfMemoryError("expected");
           }
         });
@@ -117,10 +116,10 @@ public class SimpleMemoryAllocatorJUnitTest {
       LastSevereLogger logger = new LastSevereLogger();
       int MAX_SLAB_SIZE = 100;
       try {
-        Factory factory = new UnsafeMemoryChunk.Factory() {
+        AddressableMemoryChunkFactory factory = new AddressableMemoryChunkFactory() {
           private int createCount = 0;
           @Override
-          public UnsafeMemoryChunk create(int size) {
+          public AddressableMemoryChunk create(int size) {
             createCount++;
             if (createCount == 1) {
               return new UnsafeMemoryChunk(size);
@@ -140,9 +139,9 @@ public class SimpleMemoryAllocatorJUnitTest {
     {
       NullOutOfOffHeapMemoryListener listener = new NullOutOfOffHeapMemoryListener();
       NullOffHeapMemoryStats stats = new NullOffHeapMemoryStats();
-      Factory factory = new UnsafeMemoryChunk.Factory() {
+      AddressableMemoryChunkFactory factory = new AddressableMemoryChunkFactory() {
         @Override
-        public UnsafeMemoryChunk create(int size) {
+        public AddressableMemoryChunk create(int size) {
           return new UnsafeMemoryChunk(size);
         }
       };

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3ca7b3e2/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunkJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunkJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunkJUnitTest.java
index a98fa28..d7168a7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunkJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/UnsafeMemoryChunkJUnitTest.java
@@ -35,7 +35,7 @@ public class UnsafeMemoryChunkJUnitTest extends MemoryChunkJUnitTestBase {
   public void testGetAddress() {
     MemoryChunk mc = createChunk(1024);
     try {
-      UnsafeMemoryChunk umc = (UnsafeMemoryChunk) mc;
+      AddressableMemoryChunk umc = (AddressableMemoryChunk) mc;
       assertNotEquals(0, umc.getMemoryAddress());
     } finally {
       mc.release();


[44/52] [abbrv] incubator-geode git commit: GEODE-873: Allowing for possible retry in testParallelPregationHA

Posted by ds...@apache.org.
GEODE-873: Allowing for possible retry in testParallelPregationHA

It's possible a put could be retried due to the member shutdown in this
test. If there is a retry, the stats may get incremented by one more
event.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/441c29cd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/441c29cd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/441c29cd

Branch: refs/heads/feature/GEODE-831
Commit: 441c29cdb1df3a29b75dee6d1b99b6506cb80cde
Parents: 2260630
Author: Dan Smith <up...@apache.org>
Authored: Wed Jan 27 17:25:30 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Thu Jan 28 09:38:00 2016 -0800

----------------------------------------------------------------------
 .../cache/wan/parallel/ParallelWANStatsDUnitTest.java       | 9 ++++++---
 1 file changed, 6 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/441c29cd/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
index 4da0868..529e378 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANStatsDUnitTest.java
@@ -306,7 +306,7 @@ public class ParallelWANStatsDUnitTest extends WANTestBase{
     vm2.invoke(WANTestBase.class, "checkGatewayReceiverStats", new Object[] {100, 1000, 1000 });
     vm3.invoke(WANTestBase.class, "checkGatewayReceiverStats", new Object[] {100, 1000, 1000 });
   }
-
+  
   public void testParallelPropagationHA() throws Exception {
     Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
         "createFirstLocatorWithDSId", new Object[] { 1 });
@@ -365,8 +365,11 @@ public class ParallelWANStatsDUnitTest extends WANTestBase{
         WANTestBase.class, "getSenderStats", new Object[] { "ln", 0});
     
     assertEquals(0, v5List.get(0) + v6List.get(0) + v7List.get(0) ); //queue size
-    assertEquals(30000, v5List.get(1) + v6List.get(1) + v7List.get(1)); //eventsReceived
-    assertEquals(30000, v5List.get(2) + v6List.get(2) + v7List.get(2)); //events queued
+    int receivedEvents = v5List.get(1) + v6List.get(1) + v7List.get(1);
+    //We may see a single retried event on all members due to the kill
+    assertTrue("Received " + receivedEvents, 30000 <= receivedEvents && 30003 >= receivedEvents); //eventsReceived
+    int queuedEvents = v5List.get(2) + v6List.get(2) + v7List.get(2);
+    assertTrue("Queued " + queuedEvents, 30000 <= queuedEvents && 30003 >= queuedEvents); //eventsQueued
     //assertTrue(10000 <= v5List.get(3) + v6List.get(3) + v7List.get(3)); //events distributed : its quite possible that vm4 has distributed some of the events
     //assertTrue(v5List.get(4) + v6List.get(4) + v7List.get(4) > 1000); //batches distributed : its quite possible that vm4 has distributed some of the batches.
     assertEquals(0, v5List.get(5) + v6List.get(5) + v7List.get(5)); //batches redistributed


[05/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart3DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart3DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart3DUnitTest.java
index 1c2933d..9bce503 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart3DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart3DUnitTest.java
@@ -25,9 +25,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.logging.LogWriterImpl;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart4DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart4DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart4DUnitTest.java
index da12c6e..11c3afd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart4DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart4DUnitTest.java
@@ -24,9 +24,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.logging.LogWriterImpl;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/QueueCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/QueueCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/QueueCommandsDUnitTest.java
index e9a4666..78540ac 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/QueueCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/QueueCommandsDUnitTest.java
@@ -29,10 +29,10 @@ import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.FileOutputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/SharedConfigurationCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/SharedConfigurationCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/SharedConfigurationCommandsDUnitTest.java
index adf5b5f..b937fa9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/SharedConfigurationCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/SharedConfigurationCommandsDUnitTest.java
@@ -34,11 +34,12 @@ import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
 import com.gemstone.gemfire.management.internal.configuration.SharedConfigurationDUnitTest;
 import com.gemstone.gemfire.management.internal.configuration.domain.Configuration;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 org.apache.commons.io.FileUtils;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowDeadlockDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowDeadlockDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowDeadlockDUnitTest.java
index 2d67129..7a72865 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowDeadlockDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowDeadlockDUnitTest.java
@@ -32,10 +32,10 @@ import com.gemstone.gemfire.management.internal.cli.CliUtil;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandProcessor;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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 java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowMetricsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowMetricsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowMetricsDUnitTest.java
index a69c35a..d09e596 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowMetricsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowMetricsDUnitTest.java
@@ -35,10 +35,10 @@ import com.gemstone.gemfire.management.cli.Result.Status;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandProcessor;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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 javax.management.ObjectName;
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowStackTraceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowStackTraceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowStackTraceDUnitTest.java
index d1dc87f..b0f0495 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowStackTraceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ShowStackTraceDUnitTest.java
@@ -21,9 +21,9 @@ import com.gemstone.gemfire.management.cli.Result.Status;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/UserCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/UserCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/UserCommandsDUnitTest.java
index 3a8811d..dcbba2f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/UserCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/UserCommandsDUnitTest.java
@@ -23,8 +23,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.CommandManager;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+
 import org.junit.Test;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationDUnitTest.java
index bea79cf..894d2ec 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationDUnitTest.java
@@ -49,12 +49,11 @@ import com.gemstone.gemfire.management.internal.configuration.domain.XmlEntity.X
 import com.gemstone.gemfire.management.internal.configuration.handlers.ConfigurationRequestHandler;
 import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationRequest;
 import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationResponse;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /***
  * Tests the starting up of shared configuration, installation of {@link ConfigurationRequestHandler}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
index 65f3243..b096bd8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientIdsDUnitTest.java
@@ -37,13 +37,12 @@ import com.gemstone.gemfire.management.CacheServerMXBean;
 import com.gemstone.gemfire.management.MBeanUtil;
 import com.gemstone.gemfire.management.ManagementTestBase;
 import com.gemstone.gemfire.management.internal.cli.CliUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /**
  * This is for testing client IDs

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestFunctionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestFunctionsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestFunctionsDUnitTest.java
index c80a093..1ebbab7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestFunctionsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestFunctionsDUnitTest.java
@@ -24,8 +24,8 @@ import com.gemstone.gemfire.internal.cache.functions.TestFunction;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing running functions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestHeapDUnitTest.java
index f90d7dd..4a8783a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestHeapDUnitTest.java
@@ -19,8 +19,7 @@ package com.gemstone.gemfire.management.internal.pulse;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing heap size from Mbean  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
index 9ba0e2c..56fcbb1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestSubscriptionsDUnitTest.java
@@ -37,11 +37,11 @@ import com.gemstone.gemfire.management.DistributedRegionMXBean;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * This is for testing subscriptions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
index 9dc9faa..0704121 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/ClientsWithVersioningRetryDUnitTest.java
@@ -56,11 +56,10 @@ 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 dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
index da5f0c7..5a355ea 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/DistributedSystemIdDUnitTest.java
@@ -24,11 +24,10 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
index 68c3f1d..a8b4e8d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/JSONPdxClientServerDUnitTest.java
@@ -40,12 +40,10 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.Assert;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
-
 import com.gemstone.gemfire.pdx.internal.json.PdxToJSON;
+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.util.test.TestUtil;
 
 import org.json.JSONException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PDXAsyncEventQueueDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PDXAsyncEventQueueDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PDXAsyncEventQueueDUnitTest.java
index 860ab22..a4b81cb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PDXAsyncEventQueueDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PDXAsyncEventQueueDUnitTest.java
@@ -33,10 +33,9 @@ import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.HeapDataOutputStream;
 import com.gemstone.gemfire.internal.Version;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PDXAsyncEventQueueDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
index 219429b..98da0fc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxClientServerDUnitTest.java
@@ -41,11 +41,10 @@ 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 dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxDeserializationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxDeserializationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxDeserializationDUnitTest.java
index ee8251d..3310d95 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxDeserializationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxDeserializationDUnitTest.java
@@ -38,11 +38,10 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.pdx.PdxReader;
 import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxWriter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * A test to ensure that we do not deserialize PDX objects

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableDUnitTest.java
index 188caaa..51635f3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxSerializableDUnitTest.java
@@ -24,11 +24,10 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.pdx.internal.PeerTypeRegistration;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PdxSerializableDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxTypeExportDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxTypeExportDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxTypeExportDUnitTest.java
index fa38b7f..001aab4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxTypeExportDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/PdxTypeExportDUnitTest.java
@@ -35,9 +35,8 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.pdx.internal.EnumInfo;
 import com.gemstone.gemfire.pdx.internal.PdxType;
 import com.gemstone.gemfire.pdx.internal.TypeRegistry;
-
-import dunit.Host;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class PdxTypeExportDUnitTest extends CacheTestCase {
   public PdxTypeExportDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/VersionClassLoader.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/VersionClassLoader.java b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/VersionClassLoader.java
index 7f06843..be4d9c7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/VersionClassLoader.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/pdx/VersionClassLoader.java
@@ -20,26 +20,12 @@
  */
 package com.gemstone.gemfire.pdx;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.util.test.TestUtil;
-
-import dunit.*;
-
 import java.io.File;
-import java.io.IOException;
 import java.lang.reflect.Constructor;
-import java.lang.reflect.InvocationTargetException;
-import java.net.MalformedURLException;
 import java.net.URL;
 import java.net.URLClassLoader;
-import java.util.ArrayList;
-import java.util.List;
 
-import junit.framework.Assert;
-import util.TestException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class VersionClassLoader {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
index 477e0f9..28e2940 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/redis/RedisDistDUnitTest.java
@@ -23,12 +23,11 @@ import redis.clients.jedis.Jedis;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.SocketCreator;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class RedisDistDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/rest/internal/web/controllers/RestAPITestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/rest/internal/web/controllers/RestAPITestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/rest/internal/web/controllers/RestAPITestBase.java
index e9a546f..40acd62 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/rest/internal/web/controllers/RestAPITestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/rest/internal/web/controllers/RestAPITestBase.java
@@ -25,10 +25,9 @@ import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class RestAPITestBase extends DistributedTestCase {
   private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthenticationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthenticationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthenticationDUnitTest.java
index f3a6dd3..ccdf782 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthenticationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthenticationDUnitTest.java
@@ -30,10 +30,10 @@ import security.CredentialGenerator.ClassCode;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
 import security.DummyCredentialGenerator;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationDUnitTest.java
index b44ac33..c434a2a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationDUnitTest.java
@@ -33,10 +33,10 @@ import security.XmlAuthzCredentialGenerator;
 
 import com.gemstone.gemfire.cache.operations.OperationContext.OperationCode;
 import com.gemstone.gemfire.internal.AvailablePort;
-import templates.security.UserPasswordAuthInit;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.Host;
-import dunit.VM;
+import templates.security.UserPasswordAuthInit;
 
 /**
  * Tests for authorization from client to server. This tests for authorization

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTestBase.java
index e49f9ff..4796203 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTestBase.java
@@ -59,9 +59,9 @@ import com.gemstone.gemfire.internal.AvailablePort.Keeper;
 import com.gemstone.gemfire.internal.cache.AbstractRegionEntry;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.util.Callable;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.DistributedTestCase;
-import dunit.VM;
 import security.DummyCredentialGenerator;
 import security.XmlAuthzCredentialGenerator;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientMultiUserAuthzDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientMultiUserAuthzDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientMultiUserAuthzDUnitTest.java
index 627c415..9120a1f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientMultiUserAuthzDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/ClientMultiUserAuthzDUnitTest.java
@@ -34,8 +34,7 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.execute.PRClientServerTestBase;
 import com.gemstone.gemfire.internal.cache.functions.TestFunction;
-
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.Host;
 
 public class ClientMultiUserAuthzDUnitTest extends ClientAuthorizationTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientAuthorizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientAuthorizationDUnitTest.java
index 37b46cc..42fe897 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientAuthorizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientAuthorizationDUnitTest.java
@@ -32,8 +32,7 @@ import com.gemstone.gemfire.cache.client.NoAvailableServersException;
 import com.gemstone.gemfire.cache.client.ServerConnectivityException;
 import com.gemstone.gemfire.cache.operations.OperationContext.OperationCode;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionLocalMaxMemoryDUnitTest.TestObject1;
-
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.Host;
 
 /**
  * @since 6.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientPostAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientPostAuthorizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientPostAuthorizationDUnitTest.java
index 0a0a0b8..94b603e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientPostAuthorizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/DeltaClientPostAuthorizationDUnitTest.java
@@ -40,9 +40,8 @@ import com.gemstone.gemfire.cache.query.CqException;
 import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.util.Callable;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @since 6.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/P2PAuthenticationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/P2PAuthenticationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/P2PAuthenticationDUnitTest.java
index e4ce211..2ff0b2e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/P2PAuthenticationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/P2PAuthenticationDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
 import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManagerHelper;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests peer to peer authentication in Gemfire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtil.java b/gemfire-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtil.java
index 6cb515a..2ac470c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtil.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/security/SecurityTestUtil.java
@@ -78,8 +78,7 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.PureLogWriter;
 import com.gemstone.gemfire.internal.util.Callable;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 /**
  * Contains utility methods for setting up servers/clients for authentication

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
new file mode 100644
index 0000000..f6cc88f
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/AsyncInvocation.java
@@ -0,0 +1,215 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.util.concurrent.TimeoutException;
+
+import com.gemstone.gemfire.InternalGemFireError;
+import com.gemstone.gemfire.SystemFailure;
+
+// @todo davidw Add the ability to get a return value back from the
+// async method call.  (Use a static ThreadLocal field that is
+// accessible from the Runnable used in VM#invoke)
+/**
+ * <P>An <code>AsyncInvocation</code> represents the invocation of a
+ * remote invocation that executes asynchronously from its caller.  An
+ * instanceof <code>AsyncInvocation</code> provides information about
+ * the invocation such as any exception that it may have thrown.</P>
+ *
+ * <P>Because it is a <code>Thread</code>, an
+ * <code>AsyncInvocation</code> can be used as follows:</P>
+ *
+ * <PRE>
+ *   AsyncInvocation ai1 = vm.invokeAsync(Test.class, "method1");
+ *   AsyncInvocation ai2 = vm.invokeAsync(Test.class, "method2");
+ *
+ *   ai1.join();
+ *   ai2.join();
+ *
+ *   assertTrue("Exception occurred while invoking " + ai1,
+ *              !ai1.exceptionOccurred());
+ *   if (ai2.exceptionOccurred()) {
+ *     throw ai2.getException();
+ *   }
+ * </PRE>
+ *
+ * @see VM#invokeAsync(Class, String)
+ */
+public class AsyncInvocation extends Thread {
+  
+  private static final ThreadLocal returnValue = new ThreadLocal();
+
+  /** The singleton the thread group */
+  private static final ThreadGroup GROUP = new AsyncInvocationGroup();
+
+  ///////////////////// Instance Fields  /////////////////////
+
+  /** An exception thrown while this async invocation ran */
+  protected volatile Throwable exception;
+
+  /** The object (or class) that is the receiver of this asyn method
+   * invocation */
+  private Object receiver;
+
+  /** The name of the method being invoked */
+  private String methodName;
+  
+  /** The returned object if any */
+  public volatile Object returnedObj = null;
+
+  //////////////////////  Constructors  //////////////////////
+
+  /**
+   * Creates a new <code>AsyncInvocation</code>
+   *
+   * @param receiver
+   *        The object or {@link Class} on which the remote method was
+   *        invoked
+   * @param methodName
+   *        The name of the method being invoked
+   * @param work
+   *        The actual invocation of the method
+   */
+  public AsyncInvocation(Object receiver, String methodName, Runnable work) {
+    super(GROUP, work, getName(receiver, methodName));
+    this.receiver = receiver;
+    this.methodName = methodName;
+    this.exception = null;
+  }
+
+  //////////////////////  Static Methods  /////////////////////
+
+  /**
+   * Returns the name of a <code>AsyncInvocation</code> based on its
+   * receiver and method name.
+   */
+  private static String getName(Object receiver, String methodName) {
+    StringBuffer sb = new StringBuffer(methodName);
+    sb.append(" invoked on ");
+    if (receiver instanceof Class) {
+      sb.append("class ");
+      sb.append(((Class) receiver).getName());
+
+    } else {
+      sb.append("an instance of ");
+      sb.append(receiver.getClass().getName());
+    }
+
+    return sb.toString();
+  }
+
+  /////////////////////  Instance Methods  ////////////////////
+
+  /**
+   * Returns the receiver of this async method invocation
+   */
+  public Object getReceiver() {
+    return this.receiver;
+  }
+
+  /**
+   * Returns the name of the method being invoked remotely
+   */
+  public String getMethodName() {
+    return this.methodName;
+  }
+
+  /**
+   * Returns whether or not an exception occurred during this async
+   * method invocation.
+   */
+  public boolean exceptionOccurred() {
+    if (this.isAlive()) {
+      throw new InternalGemFireError("Exception status not available while thread is alive.");
+    }
+    return this.exception != null;
+  }
+
+  /**
+   * Returns the exception that was thrown during this async method
+   * invocation.
+   */
+  public Throwable getException() {
+    if (this.isAlive()) {
+      throw new InternalGemFireError("Exception status not available while thread is alive.");
+    }
+    if (this.exception instanceof RMIException) {
+      return ((RMIException) this.exception).getCause();
+
+    } else {
+      return this.exception;
+    }
+  }
+
+  //////////////////////  Inner Classes  //////////////////////
+
+  /**
+   * A <code>ThreadGroup</code> that notices when an exception occurrs
+   * during an <code>AsyncInvocation</code>.
+   */
+  private static class AsyncInvocationGroup extends ThreadGroup {
+    AsyncInvocationGroup() {
+      super("Async Invocations");
+    }
+
+    public void uncaughtException(Thread t, Throwable e) {
+      if (e instanceof VirtualMachineError) {
+        SystemFailure.setFailure((VirtualMachineError)e); // don't throw
+      }
+      if (t instanceof AsyncInvocation) {
+        ((AsyncInvocation) t).exception = e;
+      }
+    }
+  }
+  
+  public Object getResult() throws Throwable {
+    join();
+    if(this.exceptionOccurred()) {
+      throw new Exception("An exception occured during async invocation", this.exception);
+    }
+    return this.returnedObj;
+  }
+  
+  public Object getResult(long waitTime) throws Throwable {
+    join(waitTime);
+    if(this.isAlive()) {
+      throw new TimeoutException();
+    }
+    if(this.exceptionOccurred()) {
+      throw new Exception("An exception occured during async invocation", this.exception);
+    }
+    return this.returnedObj;
+  }
+
+  public Object getReturnValue() {
+    if (this.isAlive()) {
+      throw new InternalGemFireError("Return value not available while thread is alive.");
+    }
+    return this.returnedObj;
+  }
+  
+  public void run()
+  {
+    super.run();
+    this.returnedObj = returnValue.get();
+    returnValue.set(null);
+  }
+
+  static void setReturnValue(Object v) {
+    returnValue.set(v);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DUnitEnv.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DUnitEnv.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DUnitEnv.java
new file mode 100644
index 0000000..eea2d65
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/DUnitEnv.java
@@ -0,0 +1,79 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+/**
+ * 
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.File;
+import java.rmi.RemoteException;
+import java.util.Properties;
+
+import com.gemstone.gemfire.test.dunit.standalone.BounceResult;
+
+/**
+ * This class provides an abstraction over the environment
+ * that is used to run dunit. This will delegate to the hydra
+ * or to the standalone dunit launcher as needed.
+ * 
+ * Any dunit tests that rely on hydra configuration should go
+ * through here, so that we can separate them out from depending on hydra
+ * and run them on a different VM launching system.
+ *   
+ * @author dsmith
+ *
+ */
+public abstract class DUnitEnv {
+  
+  public static DUnitEnv instance = null;
+  
+  public static final DUnitEnv get() {
+    if (instance == null) {
+      try {
+        // for tests that are still being migrated to the open-source
+        // distributed unit test framework  we need to look for this
+        // old closed-source dunit environment
+        Class clazz = Class.forName("dunit.hydra.HydraDUnitEnv");
+        instance = (DUnitEnv)clazz.newInstance();
+      } catch (Exception e) {
+        throw new Error("Distributed unit test environment is not initialized");
+      }
+    }
+    return instance;
+  }
+  
+  public static void set(DUnitEnv dunitEnv) {
+    instance = dunitEnv;
+  }
+  
+  public abstract String getLocatorString();
+  
+  public abstract String getLocatorAddress();
+
+  public abstract int getLocatorPort();
+  
+  public abstract Properties getDistributedSystemProperties();
+
+  public abstract int getPid();
+
+  public abstract int getVMID();
+
+  public abstract BounceResult bounce(int pid) throws RemoteException;
+
+  public abstract File getWorkingDirectory(int pid);
+  
+}


[30/52] [abbrv] incubator-geode git commit: GEODE-864: Waiting for conflation thread in conflation tests

Posted by ds...@apache.org.
GEODE-864: Waiting for conflation thread in conflation tests

For parallel queues, there is a actually a separate conflation thread
that removes entries from the queue on conflation. The tests need to
wait for this thread to finish it's work.

As part of this change, I refactored the ParallelWANConflationDUnitTest
to remove a bunch of duplicate code, replaced the VM.invoke(String)
calls with lambdas, and scaled the test down to create fewer buckets and
do fewer puts so that it runs in 1/4 of the time.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/a7249514
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/a7249514
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/a7249514

Branch: refs/heads/feature/GEODE-831
Commit: a7249514eb2f09e5ca4920e7dc7aedfce4c2fe12
Parents: 27d965d
Author: Dan Smith <up...@apache.org>
Authored: Tue Jan 26 11:26:21 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 16:50:11 2016 -0800

----------------------------------------------------------------------
 .../gemfire/internal/cache/wan/WANTestBase.java |  149 ++-
 ...arallelGatewaySenderOperationsDUnitTest.java |    8 +-
 .../ParallelWANConflationDUnitTest.java         | 1017 ++++++------------
 .../wan/serial/SerialWANStatsDUnitTest.java     |    2 +-
 4 files changed, 424 insertions(+), 752 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a7249514/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index 230c8d8..5539eb1 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -39,6 +39,7 @@ import java.util.concurrent.ExecutorService;
 import java.util.concurrent.Executors;
 import java.util.concurrent.Future;
 import java.util.concurrent.ThreadFactory;
+import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicInteger;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
@@ -117,6 +118,7 @@ import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
+import com.jayway.awaitility.Awaitility;
 
 import junit.framework.Assert;
 
@@ -2160,6 +2162,8 @@ public class WANTestBase extends DistributedTestCase{
         }
       }
       sender.pause();
+      ((AbstractGatewaySender) sender).getEventProcessor().waitForDispatcherToPause();
+      
     }
     finally {
       exp.remove();
@@ -2167,27 +2171,6 @@ public class WANTestBase extends DistributedTestCase{
     }
   }
   
-  public static void pauseSenderAndWaitForDispatcherToPause(String senderId) {
-    final ExpectedException exln = addExpectedException("Could not connect");
-    ExpectedException exp = addExpectedException(ForceReattemptException.class
-        .getName());
-    try {
-      Set<GatewaySender> senders = cache.getGatewaySenders();
-      GatewaySender sender = null;
-      for (GatewaySender s : senders) {
-        if (s.getId().equals(senderId)) {
-          sender = s;
-          break;
-        }
-      }
-      sender.pause();
-      ((AbstractGatewaySender)sender).getEventProcessor().waitForDispatcherToPause();
-    } finally {
-      exp.remove();
-      exln.remove();
-    }    
-  }
-
   public static void resumeSender(String senderId) {
     final ExpectedException exln = addExpectedException("Could not connect");
     ExpectedException exp = addExpectedException(ForceReattemptException.class
@@ -3189,35 +3172,23 @@ public class WANTestBase extends DistributedTestCase{
   
   
   public static Map putCustomerPartitionedRegion(int numPuts) {
-    assertNotNull(cache);
-    assertNotNull(customerRegion);
-    Map custKeyValues = new HashMap();
-    for (int i = 1; i <= numPuts; i++) {
-      CustId custid = new CustId(i);
-      Customer customer = new Customer("name" + i, "Address" + i);
-      try {
-        customerRegion.put(custid, customer);
-        custKeyValues.put(custid, customer);
-        assertTrue(customerRegion.containsKey(custid));
-        assertEquals(customer,customerRegion.get(custid));
-      }
-      catch (Exception e) {
-        fail(
-            "putCustomerPartitionedRegion : failed while doing put operation in CustomerPartitionedRegion ",
-            e);
-      }
-      getLogWriter().info("Customer :- { " + custid + " : " + customer + " }");
-    }
-    return custKeyValues;
+    String valueSuffix = "";
+    return putCustomerPartitionedRegion(numPuts, valueSuffix);
   }
   
   public static Map updateCustomerPartitionedRegion(int numPuts) {
+    String valueSuffix = "_update";
+    return putCustomerPartitionedRegion(numPuts, valueSuffix);
+  }
+
+  protected static Map putCustomerPartitionedRegion(int numPuts,
+      String valueSuffix) {
     assertNotNull(cache);
     assertNotNull(customerRegion);
-    Map custKeyValues = new HashMap();    
+    Map custKeyValues = new HashMap();
     for (int i = 1; i <= numPuts; i++) {
       CustId custid = new CustId(i);
-      Customer customer = new Customer("name" + i, "Address" + i + "_update");
+      Customer customer = new Customer("name" + i, "Address" + i + valueSuffix);
       try {
         customerRegion.put(custid, customer);
         assertTrue(customerRegion.containsKey(custid));
@@ -3240,24 +3211,22 @@ public class WANTestBase extends DistributedTestCase{
     Map orderKeyValues = new HashMap();
     for (int i = 1; i <= numPuts; i++) {
       CustId custid = new CustId(i);
-      for (int j = 1; j <= 1; j++) {
-        int oid = (i * 1) + j;
-        OrderId orderId = new OrderId(oid, custid);
-        Order order = new Order("OREDR" + oid);
-        try {
-          orderRegion.put(orderId, order);
-          orderKeyValues.put(orderId, order);
-          assertTrue(orderRegion.containsKey(orderId));
-          assertEquals(order,orderRegion.get(orderId));
+      int oid = i + 1;
+      OrderId orderId = new OrderId(oid, custid);
+      Order order = new Order("OREDR" + oid);
+      try {
+        orderRegion.put(orderId, order);
+        orderKeyValues.put(orderId, order);
+        assertTrue(orderRegion.containsKey(orderId));
+        assertEquals(order,orderRegion.get(orderId));
 
-        }
-        catch (Exception e) {
-          fail(
-              "putOrderPartitionedRegion : failed while doing put operation in OrderPartitionedRegion ",
-              e);
-        }
-        getLogWriter().info("Order :- { " + orderId + " : " + order + " }");
       }
+      catch (Exception e) {
+        fail(
+            "putOrderPartitionedRegion : failed while doing put operation in OrderPartitionedRegion ",
+            e);
+      }
+      getLogWriter().info("Order :- { " + orderId + " : " + order + " }");
     }
     return orderKeyValues;
   }
@@ -3412,36 +3381,7 @@ public class WANTestBase extends DistributedTestCase{
     }
     return shipmentKeyValue;
   }
-
-  public static void doPutsPDXSerializable(String regionName, int numPuts) {
-    Region r = cache.getRegion(Region.SEPARATOR + regionName);
-    assertNotNull(r);
-    for (int i = 0; i < numPuts; i++) {
-      r.put("Key_" + i, new SimpleClass(i, (byte)i));
-    }
-  }
   
-  public static void doPutsPDXSerializable2(String regionName, int numPuts) {
-    Region r = cache.getRegion(Region.SEPARATOR + regionName);
-    assertNotNull(r);
-    for (int i = 0; i < numPuts; i++) {
-      r.put("Key_" + i, new SimpleClass1(false, (short) i, "" + i, i,"" +i ,""+ i,i, i));
-    }
-  }
-  
-  
-  public static void doTxPuts(String regionName, int numPuts) {
-    Region r = cache.getRegion(Region.SEPARATOR + regionName);
-    assertNotNull(r);
-    CacheTransactionManager mgr = cache.getCacheTransactionManager();
-
-    mgr.begin();
-    r.put(0, 0);
-    r.put(100, 100);
-    r.put(200, 200);
-    mgr.commit();
-  }
-    
   public static Map updateShipmentPartitionedRegion(int numPuts) {
     assertNotNull(cache);
     assertNotNull(shipmentRegion);
@@ -3495,7 +3435,36 @@ public class WANTestBase extends DistributedTestCase{
     }
     return shipmentKeyValue;
   }
+
+  public static void doPutsPDXSerializable(String regionName, int numPuts) {
+    Region r = cache.getRegion(Region.SEPARATOR + regionName);
+    assertNotNull(r);
+    for (int i = 0; i < numPuts; i++) {
+      r.put("Key_" + i, new SimpleClass(i, (byte)i));
+    }
+  }
+  
+  public static void doPutsPDXSerializable2(String regionName, int numPuts) {
+    Region r = cache.getRegion(Region.SEPARATOR + regionName);
+    assertNotNull(r);
+    for (int i = 0; i < numPuts; i++) {
+      r.put("Key_" + i, new SimpleClass1(false, (short) i, "" + i, i,"" +i ,""+ i,i, i));
+    }
+  }
   
+  
+  public static void doTxPuts(String regionName, int numPuts) {
+    Region r = cache.getRegion(Region.SEPARATOR + regionName);
+    assertNotNull(r);
+    CacheTransactionManager mgr = cache.getCacheTransactionManager();
+
+    mgr.begin();
+    r.put(0, 0);
+    r.put(100, 100);
+    r.put(200, 200);
+    mgr.commit();
+  }
+    
   public static void doNextPuts(String regionName, int start, int numPuts) {
     //waitForSitesToUpdate();
     ExpectedException exp = addExpectedException(CacheClosedException.class
@@ -3512,6 +3481,10 @@ public class WANTestBase extends DistributedTestCase{
   }
   
   public static void checkQueueSize(String senderId, int numQueueEntries) {
+    Awaitility.await().atMost(10, TimeUnit.SECONDS).until(() -> testQueueSize(senderId, numQueueEntries));
+  }
+  
+  public static void testQueueSize(String senderId, int numQueueEntries) {
     GatewaySender sender = null;
     for (GatewaySender s : cache.getGatewaySenders()) {
       if (s.getId().equals(senderId)) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a7249514/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
index 19f6c4b..3d0eb5b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderOperationsDUnitTest.java
@@ -210,10 +210,10 @@ public class ParallelGatewaySenderOperationsDUnitTest extends WANTestBase {
     vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR", 100 });
     
     //now, pause all of the senders
-    vm4.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
+    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
     
     //SECOND RUN: keep one thread doing puts to the region
     vm4.invokeAsync(WANTestBase.class, "doPuts", new Object[] { testName + "_PR", 1000 });

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a7249514/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
index 4acaaf4..763b9c4 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelWANConflationDUnitTest.java
@@ -40,92 +40,31 @@ public class ParallelWANConflationDUnitTest extends WANTestBase {
   }
 
   public void testParallelPropagationConflationDisabled() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, false, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, false, false, null, true  });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, false, false, null, true  });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, false, false, null, true  });
-
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);
-    
-    final Map keyValues = new HashMap();
-    final Map updateKeyValues = new HashMap();
-    for(int i=0; i< 1000; i++) {
-      keyValues.put(i, i);
-    }
-    
-    
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, keyValues });
+    initialSetUp();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() });
-    for(int i=0;i<500;i++) {
-      updateKeyValues.put(i, i+"_updated");
-    }
+    createSendersNoConflation();
+
+    createSenderPRs();
+
+    startPausedSenders();
+
+    createReceiverPrs();
+
+    final Map keyValues = putKeyValues();
+
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() ));
     
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    final Map updateKeyValues = updateKeyValues();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", (keyValues.size() + updateKeyValues.size()) });
+    vm4.invoke(() ->checkQueueSize( "ln", (keyValues.size() + updateKeyValues.size()) ));
 
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, 0 });
+    vm2.invoke(() ->validateRegionSize(
+        testName, 0 ));
 
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    resumeSenders();
 
     keyValues.putAll(updateKeyValues);
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, keyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName, keyValues.size() });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
+    validateReceiverRegionSize(keyValues);
     
   }
 
@@ -137,661 +76,421 @@ public class ParallelWANConflationDUnitTest extends WANTestBase {
    * @throws Exception
    */
   public void testParallelPropagationBatchConflation() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 50, false, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-      true, 100, 50, false, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-      true, 100, 50, false, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-    true, 100, 50, false, false, null, true });
+    initialSetUp();
+    
+    vm4.invoke(() ->createSender( "ln", 2,
+        true, 100, 50, false, false, null, true ));
+    vm5.invoke(() ->createSender( "ln", 2,
+      true, 100, 50, false, false, null, true ));
+    vm6.invoke(() ->createSender( "ln", 2,
+      true, 100, 50, false, false, null, true ));
+    vm7.invoke(() ->createSender( "ln", 2,
+    true, 100, 50, false, false, null, true ));
   
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
+    createSenderPRs();
     
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
+    startSenders();
     
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+    pauseSenders();
     
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
+    createReceiverPrs();
 
     final Map keyValues = new HashMap();
     
-    for (int i = 1; i <= 100; i++) {
+    for (int i = 1; i <= 10; i++) {
       for (int j = 1; j <= 10; j++) {
         keyValues.put(j, i) ;
       }
-      vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] {
-        testName, keyValues });
+      vm4.invoke(() ->putGivenKeyValue(
+        testName, keyValues ));
     }
     
-    vm4.invoke(WANTestBase.class, "enableConflation", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "enableConflation", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "enableConflation", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "enableConflation", new Object[] { "ln" });
+    vm4.invoke(() ->enableConflation( "ln" ));
+    vm5.invoke(() ->enableConflation( "ln" ));
+    vm6.invoke(() ->enableConflation( "ln" ));
+    vm7.invoke(() ->enableConflation( "ln" ));
     
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    resumeSenders();
     
-    pause(2000);
-    ArrayList<Integer> v4List = (ArrayList<Integer>)vm4.invoke(
-        WANTestBase.class, "getSenderStats", new Object[] { "ln", 0 });
-    ArrayList<Integer> v5List = (ArrayList<Integer>)vm5.invoke(
-        WANTestBase.class, "getSenderStats", new Object[] { "ln", 0 });
-    ArrayList<Integer> v6List = (ArrayList<Integer>)vm6.invoke(
-        WANTestBase.class, "getSenderStats", new Object[] { "ln", 0 });
-    ArrayList<Integer> v7List = (ArrayList<Integer>)vm7.invoke(
-        WANTestBase.class, "getSenderStats", new Object[] { "ln", 0 });
+    ArrayList<Integer> v4List = (ArrayList<Integer>)vm4.invoke(() -> 
+        WANTestBase.getSenderStats( "ln", 0 ));
+    ArrayList<Integer> v5List = (ArrayList<Integer>)vm5.invoke(() -> 
+        WANTestBase.getSenderStats( "ln", 0 ));
+    ArrayList<Integer> v6List = (ArrayList<Integer>)vm6.invoke(() -> 
+        WANTestBase.getSenderStats( "ln", 0 ));
+    ArrayList<Integer> v7List = (ArrayList<Integer>)vm7.invoke(() -> 
+        WANTestBase.getSenderStats( "ln", 0 ));
     
-    getLogWriter().info("KBKBKB: batch conflated events : vm4 : " + v4List.get(8));
-    getLogWriter().info("KBKBKB: batch conflated events : vm5 : " + v5List.get(8));
-    getLogWriter().info("KBKBKB: batch conflated events : vm6 : " + v6List.get(8));
-    getLogWriter().info("KBKBKB: batch conflated events : vm7 : " + v7List.get(8));
-    getLogWriter().info("KBKBKB: batch conflated events : " + (v4List.get(8) + v5List.get(8) + v6List.get(8) + v7List.get(8)));
     assertTrue("No events conflated in batch", (v4List.get(8) + v5List.get(8) + v6List.get(8) + v7List.get(8)) > 0);
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName, 10 });
+    vm2.invoke(() ->validateRegionSize(
+      testName, 10 ));
 
   }
   
   public void testParallelPropagationConflation() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);
-    
-    final Map keyValues = new HashMap();
-    final Map updateKeyValues = new HashMap();
-    for(int i=0; i< 1000; i++) {
-      keyValues.put(i, i);
-    }
-    
-    
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, keyValues });
+    doTestParallelPropagationConflation(0);
+  }
+  
+  public void testParallelPropagationConflationRedundancy2() throws Exception {
+    doTestParallelPropagationConflation(2);
+  }
+  
+  public void doTestParallelPropagationConflation(int redundancy) throws Exception {
+    initialSetUp();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() });
-    for(int i=0;i<500;i++) {
-      updateKeyValues.put(i, i+"_updated");
-    }
-    
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    createSendersWithConflation();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() + updateKeyValues.size() }); // creates aren't conflated
-    
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    createSenderPRs(redundancy);
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() + updateKeyValues.size() }); // creates aren't conflated
+    startPausedSenders();
 
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, 0 });
+    createReceiverPrs();
 
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    final Map keyValues = putKeyValues();
 
-    keyValues.putAll(updateKeyValues);
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, keyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName, keyValues.size() });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
-  }
-  
-
-  /**
-   * Reproduce the bug #47213.
-   * The test is same as above test, with the only difference that 
-   * redundancy is set to 1.
-   * @throws Exception
-   */
-  public void testParallelPropagationConflation_Bug47213() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 2, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 2, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 2, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 2, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);//give some time for all the senders to pause
-    
-    final Map keyValues = new HashMap();
-    final Map updateKeyValues = new HashMap();
-    for(int i=0; i< 1000; i++) {
-      keyValues.put(i, i);
-    }
-    
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, keyValues });
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() ));
+    final Map updateKeyValues = updateKeyValues();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() });
-    for(int i=0;i<500;i++) {
-      updateKeyValues.put(i, i+"_updated");
-    }
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() + updateKeyValues.size() )); // creates aren't conflated
     
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    vm4.invoke(() ->putGivenKeyValue( testName, updateKeyValues ));
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() + updateKeyValues.size() }); // creates aren't conflated
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() + updateKeyValues.size() )); // creates aren't conflated
 
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, 0 });
+    vm2.invoke(() ->validateRegionSize(
+        testName, 0 ));
 
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    resumeSenders();
 
     keyValues.putAll(updateKeyValues);
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, keyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName, keyValues.size() });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        testName, keyValues });
+    validateReceiverRegionSize(keyValues);
   }
   
   public void testParallelPropagationConflationOfRandomKeys() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, "ln", 0, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);
+    initialSetUp();
 
-    final Map keyValues = new HashMap();
-    final Map updateKeyValues = new HashMap();
-    for(int i=0; i< 1000; i++) {
-      keyValues.put(i, i);
-    }
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, keyValues });
+    createSendersWithConflation();
+
+    createSenderPRs();
+
+    startPausedSenders();
+
+    createReceiverPrs();
+
+    final Map keyValues = putKeyValues();
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() });
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() ));
     
-    while(updateKeyValues.size()!=500) {
+    final Map updateKeyValues = new HashMap();
+    while(updateKeyValues.size()!=10) {
       int key = (new Random()).nextInt(keyValues.size());
       updateKeyValues.put(key, key+"_updated");
     }
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    vm4.invoke(() ->putGivenKeyValue( testName, updateKeyValues ));
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() + updateKeyValues.size() });
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() + updateKeyValues.size() ));
 
-    vm4.invoke(WANTestBase.class, "putGivenKeyValue", new Object[] { testName, updateKeyValues });
+    vm4.invoke(() ->putGivenKeyValue( testName, updateKeyValues ));
 
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", keyValues.size() + updateKeyValues.size() });
+    vm4.invoke(() ->checkQueueSize( "ln", keyValues.size() + updateKeyValues.size() ));
 
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, 0 });
+    vm2.invoke(() ->validateRegionSize(
+        testName, 0 ));
 
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    resumeSenders();
 
     
     keyValues.putAll(updateKeyValues);
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        testName, keyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName, keyValues.size() });
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-      testName, keyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-      testName, keyValues });
+    validateReceiverRegionSize(keyValues);
     
   }
   
   public void testParallelPropagationColocatedRegionConflation()
       throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-
-    vm4.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);
-
-    Map custKeyValues = (Map)vm4.invoke(WANTestBase.class, "putCustomerPartitionedRegion",
-        new Object[] { 1000 });
-    Map orderKeyValues = (Map)vm4.invoke(WANTestBase.class, "putOrderPartitionedRegion",
-        new Object[] { 1000 });
-    Map shipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "putShipmentPartitionedRegion",
-        new Object[] { 1000 });
-
-    vm4.invoke(
-        WANTestBase.class,
-        "checkQueueSize",
-        new Object[] {
+    initialSetUp();
+
+    createSendersWithConflation();
+
+    createOrderShipmentOnSenders();
+
+    startPausedSenders();
+
+    createOrderShipmentOnReceivers();
+
+    Map custKeyValues = (Map)vm4.invoke(() ->putCustomerPartitionedRegion( 20 ));
+    Map orderKeyValues = (Map)vm4.invoke(() ->putOrderPartitionedRegion( 20 ));
+    Map shipmentKeyValues = (Map)vm4.invoke(() ->putShipmentPartitionedRegion( 20 ));
+
+    vm4.invoke(() -> 
+        WANTestBase.checkQueueSize(
             "ln",
             (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-                .size()) });
-
-    Map updatedCustKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateCustomerPartitionedRegion",
-        new Object[] { 500 });
-    Map updatedOrderKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateOrderPartitionedRegion",
-        new Object[] { 500 });
-    Map updatedShipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateShipmentPartitionedRegion",
-        new Object[] { 500 });
-
-    vm4.invoke(
-        WANTestBase.class,
-        "checkQueueSize",
-        new Object[] {
+                .size()) ));
+
+    Map updatedCustKeyValues = (Map)vm4.invoke(() ->updateCustomerPartitionedRegion( 10 ));
+    Map updatedOrderKeyValues = (Map)vm4.invoke(() ->updateOrderPartitionedRegion( 10 ));
+    Map updatedShipmentKeyValues = (Map)vm4.invoke(() ->updateShipmentPartitionedRegion( 10 ));
+    int sum = (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
+        .size())
+        + updatedCustKeyValues.size()
+        + updatedOrderKeyValues.size()
+        + updatedShipmentKeyValues.size();
+    vm4.invoke(() -> 
+        WANTestBase.checkQueueSize(
             "ln",
-            (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-                .size())
-                + updatedCustKeyValues.size()
-                + updatedOrderKeyValues.size()
-                + updatedShipmentKeyValues.size() });
-
-    updatedCustKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateCustomerPartitionedRegion",
-        new Object[] { 500 });
-    updatedOrderKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateOrderPartitionedRegion",
-        new Object[] { 500 });
-    updatedShipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateShipmentPartitionedRegion",
-        new Object[] { 500 });
-
-    vm4.invoke(
-        WANTestBase.class,
-        "checkQueueSize",
-        new Object[] {
+            sum));
+
+    
+    updatedCustKeyValues = (Map)vm4.invoke(() ->updateCustomerPartitionedRegion( 10 ));
+    updatedOrderKeyValues = (Map)vm4.invoke(() ->updateOrderPartitionedRegion( 10 ));
+    updatedShipmentKeyValues = (Map)vm4.invoke(() ->updateShipmentPartitionedRegion( 10 ));
+    int sum2 = (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
+        .size())
+        + updatedCustKeyValues.size()
+        + updatedOrderKeyValues.size()
+        + updatedShipmentKeyValues.size();
+    vm4.invoke(() -> 
+        WANTestBase.checkQueueSize(
             "ln",
-            (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-                .size())
-                + updatedCustKeyValues.size()
-                + updatedOrderKeyValues.size()
-                + updatedShipmentKeyValues.size() });
-
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, 0 });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, 0 });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, 0 });
-
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+            sum2));
+
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.customerRegionName, 0 ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.orderRegionName, 0 ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.shipmentRegionName, 0 ));
+
+    resumeSenders();
     
     custKeyValues.putAll(updatedCustKeyValues);
     orderKeyValues.putAll(updatedOrderKeyValues);
     shipmentKeyValues.putAll(updatedShipmentKeyValues);
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues.size() });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues.size() });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues.size() });
-
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues });
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues });
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues });
-    
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues.size() });
-
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues });
+    validateColocatedRegionContents(custKeyValues, orderKeyValues,
+        shipmentKeyValues);
     
   }
   
+  //
+  //This is the same as the previous test, except for the UsingCustId methods
   public void testParallelPropagationColoatedRegionConflationSameKey()
       throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm3.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-
-    vm4.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm5.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm6.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-    vm7.invoke(WANTestBase.class, "createCache", new Object[] {lnPort });
-
-    vm4.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm5.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm6.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-    vm7.invoke(WANTestBase.class, "createSender", new Object[] { "ln", 2,
-        true, 100, 10, true, false, null, true });
-
-    vm4.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm5.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm6.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-    vm7.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, "ln", 0, 100, isOffHeap() });
-
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-    pause(3000);
-
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-    vm2.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, null, 1, 100, isOffHeap() });
-    vm3.invoke(WANTestBase.class,
-        "createCustomerOrderShipmentPartitionedRegion", new Object[] {
-            testName, null, 1, 100, isOffHeap() });
-
-    pause(2000);
-
-    Map custKeyValues = (Map)vm4.invoke(WANTestBase.class, "putCustomerPartitionedRegion",
-        new Object[] { 1000 });
-    Map orderKeyValues = (Map)vm4.invoke(WANTestBase.class, "putOrderPartitionedRegionUsingCustId",
-        new Object[] { 1000 });
-    Map shipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "putShipmentPartitionedRegionUsingCustId",
-        new Object[] { 1000 });
-
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-      .size()) });
-
-    Map updatedCustKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateCustomerPartitionedRegion",
-        new Object[] { 500 });
-    Map updatedOrderKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateOrderPartitionedRegionUsingCustId",
-        new Object[] { 500 });
-    Map updatedShipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateShipmentPartitionedRegionUsingCustId",
-        new Object[] { 500 });
-
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-        .size()) + updatedCustKeyValues.size() + updatedOrderKeyValues.size() + updatedShipmentKeyValues.size() });
-
-    updatedCustKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateCustomerPartitionedRegion",
-        new Object[] { 500 });
-    updatedOrderKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateOrderPartitionedRegionUsingCustId",
-        new Object[] { 500 });
-    updatedShipmentKeyValues = (Map)vm4.invoke(WANTestBase.class, "updateShipmentPartitionedRegionUsingCustId",
-        new Object[] { 500 });
-
-    vm4.invoke(WANTestBase.class, "checkQueueSize", new Object[] { "ln", (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
-        .size()) + updatedCustKeyValues.size() + updatedOrderKeyValues.size() + updatedShipmentKeyValues.size() });
-
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, 0 });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, 0 });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, 0 });
-
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm6.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    vm7.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+    initialSetUp();
+
+    createSendersWithConflation();
+
+    createOrderShipmentOnSenders();
+
+    startPausedSenders();
+
+    createOrderShipmentOnReceivers();
+
+    Map custKeyValues = (Map)vm4.invoke(() ->putCustomerPartitionedRegion( 20 ));
+    Map orderKeyValues = (Map)vm4.invoke(() ->putOrderPartitionedRegionUsingCustId( 20 ));
+    Map shipmentKeyValues = (Map)vm4.invoke(() ->putShipmentPartitionedRegionUsingCustId( 20 ));
+
+    vm4.invoke(() ->checkQueueSize( "ln", (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
+      .size()) ));
+
+    Map updatedCustKeyValues = (Map)vm4.invoke(() ->updateCustomerPartitionedRegion( 10 ));
+    Map updatedOrderKeyValues = (Map)vm4.invoke(() ->updateOrderPartitionedRegionUsingCustId( 10 ));
+    Map updatedShipmentKeyValues = (Map)vm4.invoke(() ->updateShipmentPartitionedRegionUsingCustId( 10 ));
+    int sum = (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
+        .size()) + updatedCustKeyValues.size() + updatedOrderKeyValues.size() + updatedShipmentKeyValues.size() ;
+
+    vm4.invoke(() ->checkQueueSize( "ln", sum));
+
+    updatedCustKeyValues = (Map)vm4.invoke(() ->updateCustomerPartitionedRegion( 10 ));
+    updatedOrderKeyValues = (Map)vm4.invoke(() ->updateOrderPartitionedRegionUsingCustId( 10 ));
+    updatedShipmentKeyValues = (Map)vm4.invoke(() ->updateShipmentPartitionedRegionUsingCustId( 10 ));
+
+    int sum2 = (custKeyValues.size() + orderKeyValues.size() + shipmentKeyValues
+        .size()) + updatedCustKeyValues.size() + updatedOrderKeyValues.size() + updatedShipmentKeyValues.size();
+    vm4.invoke(() ->checkQueueSize( "ln", sum2));
+
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.customerRegionName, 0 ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.orderRegionName, 0 ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.shipmentRegionName, 0 ));
+
+    resumeSenders();
 
     custKeyValues.putAll(updatedCustKeyValues);
     orderKeyValues.putAll(updatedOrderKeyValues);
     shipmentKeyValues.putAll(updatedShipmentKeyValues);
     
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues.size() });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues.size() });
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues.size() });
-
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues });
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues });
-    vm2.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues });
-
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues.size() });
-    vm3.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues.size() });
-
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.customerRegionName, custKeyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.orderRegionName, orderKeyValues });
-    vm3.invoke(WANTestBase.class, "validateRegionContents", new Object[] {
-        WANTestBase.shipmentRegionName, shipmentKeyValues });
+    validateColocatedRegionContents(custKeyValues, orderKeyValues,
+        shipmentKeyValues);
+  }
+  
+  protected void validateColocatedRegionContents(Map custKeyValues,
+      Map orderKeyValues, Map shipmentKeyValues) {
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.customerRegionName, custKeyValues.size() ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.orderRegionName, orderKeyValues.size() ));
+    vm2.invoke(() ->validateRegionSize(
+        WANTestBase.shipmentRegionName, shipmentKeyValues.size() ));
+
+    vm2.invoke(() ->validateRegionContents(
+        WANTestBase.customerRegionName, custKeyValues ));
+    vm2.invoke(() ->validateRegionContents(
+        WANTestBase.orderRegionName, orderKeyValues ));
+    vm2.invoke(() ->validateRegionContents(
+        WANTestBase.shipmentRegionName, shipmentKeyValues ));
+    
+    vm3.invoke(() ->validateRegionSize(
+        WANTestBase.customerRegionName, custKeyValues.size() ));
+    vm3.invoke(() ->validateRegionSize(
+        WANTestBase.orderRegionName, orderKeyValues.size() ));
+    vm3.invoke(() ->validateRegionSize(
+        WANTestBase.shipmentRegionName, shipmentKeyValues.size() ));
+
+    vm3.invoke(() ->validateRegionContents(
+        WANTestBase.customerRegionName, custKeyValues ));
+    vm3.invoke(() ->validateRegionContents(
+        WANTestBase.orderRegionName, orderKeyValues ));
+    vm3.invoke(() ->validateRegionContents(
+        WANTestBase.shipmentRegionName, shipmentKeyValues ));
+  }
+
+  protected void createOrderShipmentOnReceivers() {
+    vm2.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, null, 1, 8, isOffHeap() ));
+    vm3.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, null, 1, 8, isOffHeap() ));
+  }
+
+  protected void createOrderShipmentOnSenders() {
+    vm4.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, "ln", 0, 8, isOffHeap() ));
+    vm5.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, "ln", 0, 8, isOffHeap() ));
+    vm6.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, "ln", 0, 8, isOffHeap() ));
+    vm7.invoke(() ->createCustomerOrderShipmentPartitionedRegion(
+            testName, "ln", 0, 8, isOffHeap() ));
+  }
+  
+  protected Map updateKeyValues() {
+    final Map updateKeyValues = new HashMap();
+    for(int i=0;i<10;i++) {
+      updateKeyValues.put(i, i+"_updated");
+    }
+    
+    vm4.invoke(() ->putGivenKeyValue( testName, updateKeyValues ));
+    return updateKeyValues;
+  }
+
+  protected Map putKeyValues() {
+    final Map keyValues = new HashMap();
+    for(int i=0; i< 20; i++) {
+      keyValues.put(i, i);
+    }
+    
+    
+    vm4.invoke(() ->putGivenKeyValue( testName, keyValues ));
+    return keyValues;
+  }
+
+  protected void validateReceiverRegionSize(final Map keyValues) {
+    vm2.invoke(() ->validateRegionSize(
+        testName, keyValues.size() ));
+    vm3.invoke(() ->validateRegionSize(
+      testName, keyValues.size() ));
+    
+    vm2.invoke(() ->validateRegionContents(
+        testName, keyValues ));
+    vm3.invoke(() ->validateRegionContents(
+        testName, keyValues ));
+  }
+
+  protected void resumeSenders() {
+    vm4.invoke(() ->resumeSender( "ln" ));
+    vm5.invoke(() ->resumeSender( "ln" ));
+    vm6.invoke(() ->resumeSender( "ln" ));
+    vm7.invoke(() ->resumeSender( "ln" ));
+  }
+
+  protected void createReceiverPrs() {
+    vm2.invoke(() ->createPartitionedRegion(
+        testName, null, 1, 8, isOffHeap() ));
+    vm3.invoke(() ->createPartitionedRegion(
+        testName, null, 1, 8, isOffHeap() ));
+  }
+
+  protected void startPausedSenders() {
+    startSenders();
+
+    pauseSenders();
+  }
+
+  protected void pauseSenders() {
+    vm4.invoke(() ->pauseSender( "ln" ));
+    vm5.invoke(() ->pauseSender( "ln" ));
+    vm6.invoke(() ->pauseSender( "ln" ));
+    vm7.invoke(() ->pauseSender( "ln" ));
+  }
+
+  protected void startSenders() {
+    vm4.invoke(() ->startSender( "ln" ));
+    vm5.invoke(() ->startSender( "ln" ));
+    vm6.invoke(() ->startSender( "ln" ));
+    vm7.invoke(() ->startSender( "ln" ));
+  }
+  
+  protected void createSenderPRs() {
+    createSenderPRs(0);
+  }
+
+  protected void createSenderPRs(int redundancy) {
+    vm4.invoke(() ->createPartitionedRegion(
+        testName, "ln", redundancy, 8, isOffHeap() ));
+    vm5.invoke(() ->createPartitionedRegion(
+        testName, "ln", redundancy, 8, isOffHeap() ));
+    vm6.invoke(() ->createPartitionedRegion(
+        testName, "ln", redundancy, 8, isOffHeap() ));
+    vm7.invoke(() ->createPartitionedRegion(
+        testName, "ln", redundancy, 8, isOffHeap() ));
+  }
+
+  protected void initialSetUp() {
+    Integer lnPort = (Integer)vm0.invoke(() ->createFirstLocatorWithDSId( 1 ));
+    Integer nyPort = (Integer)vm1.invoke(() ->createFirstRemoteLocator( 2, lnPort ));
+
+    vm2.invoke(() ->createReceiver( nyPort ));
+    vm3.invoke(() ->createReceiver( nyPort ));
+
+    vm4.invoke(() ->createCache(lnPort ));
+    vm5.invoke(() ->createCache(lnPort ));
+    vm6.invoke(() ->createCache(lnPort ));
+    vm7.invoke(() ->createCache(lnPort ));
+  }
+  
+  protected void createSendersNoConflation() {
+    vm4.invoke(() ->createSender( "ln", 2,
+        true, 100, 10, false, false, null, true ));
+    vm5.invoke(() ->createSender( "ln", 2,
+        true, 100, 10, false, false, null, true  ));
+    vm6.invoke(() ->createSender( "ln", 2,
+        true, 100, 10, false, false, null, true  ));
+    vm7.invoke(() ->createSender( "ln", 2,
+        true, 100, 10, false, false, null, true  ));
+  }
+  
+  protected void createSendersWithConflation() {
+    vm4.invoke(() ->createSender( "ln", 2,
+        true, 100, 2, true, false, null, true ));
+    vm5.invoke(() ->createSender( "ln", 2,
+        true, 100, 2, true, false, null, true ));
+    vm6.invoke(() ->createSender( "ln", 2,
+        true, 100, 2, true, false, null, true ));
+    vm7.invoke(() ->createSender( "ln", 2,
+        true, 100, 2, true, false, null, true ));
   }
   
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a7249514/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
index 979439b..a142f82 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/serial/SerialWANStatsDUnitTest.java
@@ -537,7 +537,7 @@ public class SerialWANStatsDUnitTest extends WANTestBase {
 
     vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
 
-    vm4.invoke(WANTestBase.class, "pauseSenderAndWaitForDispatcherToPause", new Object[] { "ln" });
+    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
 
     vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
         testName, null,1, 100, isOffHeap()  });


[10/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/SystemAdminDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/SystemAdminDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/SystemAdminDUnitTest.java
index 6d2d0ef..42d4ed1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/SystemAdminDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/SystemAdminDUnitTest.java
@@ -28,9 +28,8 @@ import java.util.Properties;
 
 import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.SystemAdmin;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.internal.SystemAdmin;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 public class SystemAdminDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/Bug40751DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/Bug40751DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/Bug40751DUnitTest.java
index ce00449..cedf650 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/Bug40751DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/Bug40751DUnitTest.java
@@ -35,11 +35,10 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.SubscriptionAttributes;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-	
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 	
 public class Bug40751DUnitTest extends CacheTestCase {
 	 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ConsoleDistributionManagerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ConsoleDistributionManagerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ConsoleDistributionManagerDUnitTest.java
index 16cf60e..bdc08b6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ConsoleDistributionManagerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ConsoleDistributionManagerDUnitTest.java
@@ -42,11 +42,10 @@ import com.gemstone.gemfire.internal.admin.GfManagerAgentConfig;
 import com.gemstone.gemfire.internal.admin.GfManagerAgentFactory;
 import com.gemstone.gemfire.internal.admin.StatResource;
 import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of the {@linkplain internal

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionAdvisorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionAdvisorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionAdvisorDUnitTest.java
index 869c475..98bfbbd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionAdvisorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionAdvisorDUnitTest.java
@@ -14,15 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
 package com.gemstone.gemfire.distributed.internal;
 
-import dunit.*;
-import java.util.*;
+import java.util.ArrayList;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Set;
 
 import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
index 773ef38..3da075f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/DistributionManagerDUnitTest.java
@@ -46,11 +46,10 @@ import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManage
 import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Manager;
 import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
 import com.gemstone.gemfire.internal.logging.LogService;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of the {@link

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
index bfc975f..d6f45d1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/ProductUseLogDUnitTest.java
@@ -27,12 +27,11 @@ import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.internal.cache.CacheServerImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class ProductUseLogDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
index be80150..efdcb0c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/deadlock/GemFireDeadlockDetectorDUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedLockService;
 import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/locks/CollaborationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/locks/CollaborationJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/locks/CollaborationJUnitTest.java
index 711500e..991030e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/locks/CollaborationJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/locks/CollaborationJUnitTest.java
@@ -30,12 +30,11 @@ import com.gemstone.gemfire.CancelCriterion;
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.SystemFailure;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Tests the Collaboration Lock used internally by dlock service.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/MembershipManagerHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/MembershipManagerHelper.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/MembershipManagerHelper.java
index f764ef9..2c2d4a9 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/MembershipManagerHelper.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/MembershipManagerHelper.java
@@ -26,9 +26,8 @@ import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedM
 import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
 import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Manager;
 import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * This helper class provides access to membership manager information that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationManyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationManyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationManyDUnitTest.java
index 2a6eb55..91e5e20 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationManyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationManyDUnitTest.java
@@ -20,15 +20,25 @@
 //
 package com.gemstone.gemfire.distributed.internal.streaming;
 
-import java.util.*;
-import dunit.*;
-
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
+
 import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.ReplyException;
+import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.Token;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class StreamingOperationManyDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationOneDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationOneDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationOneDUnitTest.java
index 0b5a0b0..a09c167 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationOneDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/streaming/StreamingOperationOneDUnitTest.java
@@ -20,17 +20,26 @@
 //
 package com.gemstone.gemfire.distributed.internal.streaming;
 
-import java.util.*;
-import java.io.*;
-import dunit.*;
-
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
+
 import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.ReplyException;
+import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.Token;
-
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class StreamingOperationOneDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServerBackwardCompatDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServerBackwardCompatDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServerBackwardCompatDUnitTest.java
index 2f5b80b..a6cc444 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServerBackwardCompatDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServerBackwardCompatDUnitTest.java
@@ -35,12 +35,11 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.distributed.internal.tcpserver.TcpServer;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.Version;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.junit.categories.DistributedTest;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This tests the rolling upgrade for locators with
  * different GOSSIPVERSION.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/CacheMapDistTXDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/CacheMapDistTXDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/CacheMapDistTXDUnitTest.java
index b8cdf0a..374136d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/CacheMapDistTXDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/CacheMapDistTXDUnitTest.java
@@ -18,9 +18,8 @@ package com.gemstone.gemfire.disttx;
 
 import com.gemstone.gemfire.cache30.CacheMapTxnDUnitTest;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
index 2523505..58e76a6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXDebugDUnitTest.java
@@ -42,11 +42,10 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.execute.CustomerIDPartitionResolver;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 public class DistTXDebugDUnitTest extends CacheTestCase {
   VM accessor = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXPersistentDebugDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXPersistentDebugDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXPersistentDebugDUnitTest.java
index b53407a..5a7375a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXPersistentDebugDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistTXPersistentDebugDUnitTest.java
@@ -27,7 +27,7 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.internal.cache.TXManagerImpl;
 import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Customer;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class DistTXPersistentDebugDUnitTest extends DistTXDebugDUnitTest {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
index 9dafa95..61c31d4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
@@ -57,10 +57,9 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Customer;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Port of GemFireXD's corresponding test for distributed transactions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/ClassNotFoundExceptionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/ClassNotFoundExceptionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/ClassNotFoundExceptionDUnitTest.java
index 55bdebc..185ae2d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/ClassNotFoundExceptionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/ClassNotFoundExceptionDUnitTest.java
@@ -38,11 +38,10 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.pdx.PdxReader;
 import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxWriter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
index 44d8a4e..54275dc 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JSSESocketJUnitTest.java
@@ -48,10 +48,9 @@ import org.junit.rules.TestName;
 
 import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.util.test.TestUtil;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * Test creation of server sockets and client sockets with various JSSE
  * configurations.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JarDeployerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JarDeployerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JarDeployerDUnitTest.java
index 5b6d212..99a3053 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JarDeployerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/JarDeployerDUnitTest.java
@@ -45,10 +45,9 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Unit tests for the JarDeployer class

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxDeleteFieldDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxDeleteFieldDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxDeleteFieldDUnitTest.java
index 3472bbf..d805a38 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxDeleteFieldDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxDeleteFieldDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxWriter;
 import com.gemstone.gemfire.pdx.internal.PdxType;
 import com.gemstone.gemfire.pdx.internal.PdxUnreadData;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PdxDeleteFieldDUnitTest  extends CacheTestCase{
   final List<String> filesToBeDeleted = new CopyOnWriteArrayList<String>();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxRenameDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxRenameDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxRenameDUnitTest.java
index 7b8a3ff..6303719 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxRenameDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/PdxRenameDUnitTest.java
@@ -39,10 +39,9 @@ import com.gemstone.gemfire.pdx.PdxWriter;
 import com.gemstone.gemfire.pdx.internal.EnumInfo;
 import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
 import com.gemstone.gemfire.pdx.internal.PdxType;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PdxRenameDUnitTest  extends CacheTestCase{
   final List<String> filesToBeDeleted = new CopyOnWriteArrayList<String>();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/SocketCloserJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/SocketCloserJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/SocketCloserJUnitTest.java
index b17ce6c..7335528 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/SocketCloserJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/SocketCloserJUnitTest.java
@@ -30,11 +30,10 @@ import org.junit.Before;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Tests the default SocketCloser.
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/BackupDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/BackupDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/BackupDUnitTest.java
index 3028803..6b0493e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/BackupDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/BackupDUnitTest.java
@@ -50,13 +50,12 @@ import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
 import com.gemstone.gemfire.distributed.internal.ReplyMessage;
 import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.cache.partitioned.PersistentPartitionedRegionTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DUnitEnv;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DUnitEnv;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33359DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33359DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33359DUnitTest.java
index 6be75a0..aa2a9b2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33359DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33359DUnitTest.java
@@ -21,6 +21,7 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import java.util.Properties;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
@@ -30,11 +31,12 @@ import com.gemstone.gemfire.cache.CacheTransactionManager;
 import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-import dunit.*;
-import java.util.Properties;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33726DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33726DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33726DUnitTest.java
index e8c7604..08cb340 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33726DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug33726DUnitTest.java
@@ -16,9 +16,8 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-
-
 import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
@@ -29,8 +28,9 @@ import com.gemstone.gemfire.cache.RegionEvent;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class Bug33726DUnitTest extends DistributedTestCase {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37241DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37241DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37241DUnitTest.java
index eca80dc..4ad5133 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37241DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37241DUnitTest.java
@@ -29,11 +29,9 @@ import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.ReplyException;
-
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /*
  * Confirms the bug 37241 is fixed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37377DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37377DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37377DUnitTest.java
index fe01c95..f7a2911 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37377DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug37377DUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
 import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Bug37377 DUNIT Test: The Clear operation during a GII in progress can leave a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
index 4927abe..cc07a3a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug39079DUnitTest.java
@@ -43,10 +43,9 @@ 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 dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests that if a node doing GII experiences DiskAccessException, it should

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40299DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40299DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40299DUnitTest.java
index 8a50d9f..e2d7eb7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40299DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40299DUnitTest.java
@@ -38,12 +38,11 @@ import com.gemstone.gemfire.internal.cache.DiskRegionHelperFactory;
 import com.gemstone.gemfire.internal.cache.DiskRegionProperties;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.SearchLoadAndWriteProcessor;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Bug40299 DUNIT Test: The Clear operation during a NetSearchMessage.doGet() in progress can 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40632DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40632DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40632DUnitTest.java
index d6a530b..9443c9a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40632DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug40632DUnitTest.java
@@ -52,11 +52,10 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.ResourceManagerStats;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceObserverAdapter;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
index f16e92a..e023ed4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41091DUnitTest.java
@@ -34,10 +34,9 @@ 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 dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41733DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41733DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41733DUnitTest.java
index eb0da72..ca93ad8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41733DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41733DUnitTest.java
@@ -34,14 +34,13 @@ import com.gemstone.gemfire.distributed.internal.DistributionMessage;
 import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
 import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage;
 import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage.ManageBucketReplyMessage;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
index ee34260..1cdf92e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug41957DUnitTest.java
@@ -16,19 +16,26 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import java.util.Properties;
+
+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.internal.cache.PartitionedRegion;
-
-import com.gemstone.gemfire.cache30.ClientServerTestCase;
-import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-
-import com.gemstone.gemfire.cache.client.*;
-
-import dunit.*;
-
-import java.util.*;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test for bug 41957.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug42055DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug42055DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug42055DUnitTest.java
index b95fc07..6871acf 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug42055DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug42055DUnitTest.java
@@ -25,11 +25,10 @@ import com.gemstone.gemfire.cache.PartitionAttributes;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Test that the bucket size does not go negative when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45164DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45164DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45164DUnitTest.java
index d4ebc1c..a2e9c5d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45164DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45164DUnitTest.java
@@ -23,10 +23,9 @@ import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class Bug45164DUnitTest extends CacheTestCase {
   private static final int count = 10000;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
index d3dbfee..ca1c1b1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug45934DUnitTest.java
@@ -28,10 +28,9 @@ 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 dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class Bug45934DUnitTest extends CacheTestCase {
   public Bug45934DUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug47667DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug47667DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug47667DUnitTest.java
index e6c27f1..40ba9ea 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug47667DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/Bug47667DUnitTest.java
@@ -24,10 +24,9 @@ import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
 import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.client.internal.LocatorTestBase;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class Bug47667DUnitTest extends LocatorTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
index 2e640a5..66a7880 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/CacheAdvisorDUnitTest.java
@@ -14,17 +14,33 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache30.*;
-import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import dunit.*;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Set;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.AttributesMutator;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Operation;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the use of CacheDistributionAdvisor in createSubRegion

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
index 95caf81..39e7604 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearDAckDUnitTest.java
@@ -21,6 +21,7 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import java.util.Properties;
 
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
@@ -31,14 +32,14 @@ import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.cache.Scope;
-
-import dunit.*;
-
-import java.util.Properties;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearGlobalDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearGlobalDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearGlobalDUnitTest.java
index 6763ad2..29b54df 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearGlobalDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClearGlobalDUnitTest.java
@@ -33,9 +33,9 @@ import com.gemstone.gemfire.cache.TimeoutException;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
 import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
index 392b5dd..b34b115 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerGetAllDUnitTest.java
@@ -16,20 +16,33 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+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 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;
+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.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.offheap.SimpleMemoryAllocatorImpl;
-import com.gemstone.gemfire.cache30.ClientServerTestCase;
-import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
-import com.gemstone.gemfire.cache.client.*;
-import com.gemstone.gemfire.cache.server.CacheServer;
-
-import dunit.*;
-
-import java.util.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Class <code>ClientServerGetAllDUnitTest</code> test client/server getAll.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
index 7ba7fc5..ac58ed2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
@@ -41,12 +41,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.internal.cache.tier.InterestType;
+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;
 
 /**
  * This tests the fix for bug #43407 under a variety of configurations and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionCCEDUnitTest.java
index 85bfe81..0ac6f67 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionCCEDUnitTest.java
@@ -24,9 +24,8 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * test client initiated transactions with concurrency checks enabled.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
index ff894f4..c19b7b6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
@@ -65,12 +65,11 @@ import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
 import com.gemstone.gemfire.internal.cache.execute.util.CommitFunction;
 import com.gemstone.gemfire.internal.cache.execute.util.RollbackFunction;
 import com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests the basic client-server transaction functionality

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentDestroySubRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentDestroySubRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentDestroySubRegionDUnitTest.java
index 72aa361..0611f63 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentDestroySubRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentDestroySubRegionDUnitTest.java
@@ -23,11 +23,10 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionDestroyedException;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
index c0ccfca..df0ea7f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentMapOpsDUnitTest.java
@@ -49,12 +49,11 @@ import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
 import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManagerHelper;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * tests for the concurrentMapOperations. there are more tests in ClientServerMiscDUnitTest

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRegionOperationsJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRegionOperationsJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRegionOperationsJUnitTest.java
index c74949e..55ce901 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRegionOperationsJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRegionOperationsJUnitTest.java
@@ -39,10 +39,9 @@ import org.junit.experimental.categories.Category;
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * This is a multi threaded tests. This test creates two regions. Region1 which
  * is persistent and Region2 which is not. There will be four sets of threads.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRollingAndRegionOperationsJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRollingAndRegionOperationsJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRollingAndRegionOperationsJUnitTest.java
index a42b372..36a0448 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRollingAndRegionOperationsJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConcurrentRollingAndRegionOperationsJUnitTest.java
@@ -41,10 +41,9 @@ import com.gemstone.gemfire.internal.cache.DiskRegionProperties;
 import com.gemstone.gemfire.internal.cache.DiskRegionTestingBase;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * This JUnit test tests concurrent rolling and normal region operations
  * put,get,clear,destroy in both sync and async mode

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
index 483d44f..f101acb 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ConnectDisconnectDUnitTest.java
@@ -37,13 +37,12 @@ import com.gemstone.gemfire.distributed.internal.membership.gms.messenger.JGroup
 import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /** A test of 46438 - missing response to an update attributes message */
 public class ConnectDisconnectDUnitTest extends CacheTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaFaultInDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaFaultInDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaFaultInDUnitTest.java
index 373f3c3..12de353 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaFaultInDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaFaultInDUnitTest.java
@@ -25,11 +25,10 @@ import com.gemstone.gemfire.cache.PartitionAttributes;
 import com.gemstone.gemfire.cache.PartitionAttributesFactory;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Test that the bucket size does not go negative when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
index 8c3ab34..43ed3da 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationDUnitTest.java
@@ -59,11 +59,10 @@ import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
 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 dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @since 6.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
index 6a74b22..d3f99bd 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaPropagationStatsDUnitTest.java
@@ -42,10 +42,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author ashetkar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaSizingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaSizingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaSizingDUnitTest.java
index 8f2e43d..5da448a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaSizingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DeltaSizingDUnitTest.java
@@ -30,11 +30,10 @@ import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegByteArrayDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegByteArrayDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegByteArrayDUnitTest.java
index 3a79bc8..49b47c8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegByteArrayDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegByteArrayDUnitTest.java
@@ -14,9 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-
 package com.gemstone.gemfire.internal.cache;
 
+import java.io.File;
+import java.util.Arrays;
+import java.util.Properties;
+
 import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
@@ -25,13 +28,11 @@ import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.*;
-
-import java.io.File;
-import java.util.*;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Disk Reg DUNIT Test:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
index 44a0049..d1e0791 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionClearJUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.cache.RegionEvent;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 // @TODO: use DiskRegionTestingBase and DiskRegionHelperFactory
 /**
  * Test methods to ensure that disk Clear is apparently atomic to region clear.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionJUnitTest.java
index e3b5ab0..36044f7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DiskRegionJUnitTest.java
@@ -47,11 +47,10 @@ import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
 import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
 import com.gemstone.gemfire.internal.cache.persistence.UninterruptibleFileChannel;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * TODO: fails when running integrationTest from gradle command-line on Windows 7
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistrbutedRegionProfileOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistrbutedRegionProfileOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistrbutedRegionProfileOffHeapDUnitTest.java
index 9718f5f..1c2f921 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistrbutedRegionProfileOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistrbutedRegionProfileOffHeapDUnitTest.java
@@ -27,9 +27,8 @@ import com.gemstone.gemfire.cache.RegionShortcut;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class DistrbutedRegionProfileOffHeapDUnitTest extends CacheTestCase {
   private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistributedCacheTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistributedCacheTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistributedCacheTestCase.java
index 61544f0..1571708 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistributedCacheTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/DistributedCacheTestCase.java
@@ -16,13 +16,24 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.InternalGemFireException;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.EntryNotFoundException;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.distributed.internal.DistributionManager;
+import com.gemstone.gemfire.distributed.internal.DistributionManagerDUnitTest;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-//import java.io.File;
-//import java.util.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is the abstract superclass of tests that validate the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EventTrackerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EventTrackerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EventTrackerDUnitTest.java
index 90f6007..19f72ab 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EventTrackerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EventTrackerDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionMessage;
 import com.gemstone.gemfire.distributed.internal.DistributionMessageObserver;
 import com.gemstone.gemfire.internal.cache.EventTracker.BulkOpHolder;
 import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests <code>EventTracker</code> management.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionStatsDUnitTest.java
index fbd2f54..189d0d2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionStatsDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
 import com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class EvictionStatsDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionTestBase.java
index b221f42..cbd2f65 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/EvictionTestBase.java
@@ -44,12 +44,11 @@ import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.Resou
 import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
 import com.gemstone.gemfire.internal.cache.control.MemoryThresholds.MemoryState;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class EvictionTestBase extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/FixedPRSinglehopDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/FixedPRSinglehopDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/FixedPRSinglehopDUnitTest.java
index 685211b..6a96948 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/FixedPRSinglehopDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/FixedPRSinglehopDUnitTest.java
@@ -40,11 +40,10 @@ import com.gemstone.gemfire.internal.cache.partitioned.fixed.QuarterPartitionRes
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.SingleHopQuarterPartitionResolver;
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.FixedPartitioningTestBase.Q1_Months;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIDeltaDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIDeltaDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIDeltaDUnitTest.java
index 69894e1..9f318fb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIDeltaDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIDeltaDUnitTest.java
@@ -55,13 +55,12 @@ import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 java.io.ByteArrayInputStream;
 import java.io.DataInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
index 7b847a0..d478b8b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/GIIFlowControlDUnitTest.java
@@ -30,11 +30,10 @@ 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.cache.InitialImageOperation.ImageReplyMessage;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith



[25/52] [abbrv] incubator-geode git commit: GEODE-854: Put pulseversion.properties in generated-resources

Posted by ds...@apache.org.
GEODE-854: Put pulseversion.properties in generated-resources

Using the same pattern as gemfire-core, put the version properties file
in a generated resources directory, not in source.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/2757f634
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/2757f634
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/2757f634

Branch: refs/heads/feature/GEODE-831
Commit: 2757f634f72e955e811d178afb045eb2096ec180
Parents: ed17d4c
Author: Dan Smith <up...@apache.org>
Authored: Mon Jan 25 12:22:43 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 10:12:32 2016 -0800

----------------------------------------------------------------------
 gemfire-pulse/build.gradle | 16 +++++++++++-----
 gradle/rat.gradle          |  1 -
 2 files changed, 11 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2757f634/gemfire-pulse/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-pulse/build.gradle b/gemfire-pulse/build.gradle
index f2076b5..4c1135d 100755
--- a/gemfire-pulse/build.gradle
+++ b/gemfire-pulse/build.gradle
@@ -28,8 +28,6 @@ buildscript {
 
 apply plugin: 'war'
 
-def resDir="$projectDir/src/main/resources"
-
 sourceSets {
   main {
     resources {
@@ -76,12 +74,20 @@ dependencies {
   testRuntime 'org.apache.commons:commons-exec:1.3'
 }
 
+def generatedResources = "$buildDir/generated-resources/main"
+
+sourceSets {
+  main {
+    output.dir(generatedResources, builtBy: 'createPulsePropFile')
+  }
+}
+
 // Creates the version properties file and writes it to the resources dir
 task createPulsePropFile {
   description 'Creates a new Pule properties file with build/ version information'
-  def propertiesFile = file(resDir + "/pulseversion.properties");
+  def propertiesFile = file(generatedResources + "/pulseversion.properties");
   outputs.file propertiesFile
-  inputs.dir resDir
+  inputs.dir compileJava.destinationDir
 
   doLast {
     try {
@@ -114,6 +120,7 @@ task createPulsePropFile {
             "Source-Repository" : ext.branch
     ] as Properties
 
+    propertiesFile.getParentFile().mkdirs();
     new FileOutputStream(propertiesFile).withStream { fos ->
       props.store(fos, '')
     }
@@ -146,7 +153,6 @@ artifacts {
 def pulseWarFile = "gemfire-pulse-"+version+".war"
 
 war {
-  dependsOn createPulsePropFile
   classpath configurations.runtime
   classpath project(':gemfire-core').webJar.archivePath
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2757f634/gradle/rat.gradle
----------------------------------------------------------------------
diff --git a/gradle/rat.gradle b/gradle/rat.gradle
index 07cb2f1..b81cffd 100644
--- a/gradle/rat.gradle
+++ b/gradle/rat.gradle
@@ -80,7 +80,6 @@ rat {
     'gemfire-spark-connector/project/plugins.sbt',
     'gemfire-spark-connector/project/build.properties',
     '**/log4j2*.xml',
-    'gemfire-pulse/src/main/resources/pulseversion.properties',
 
     // these are test files that don't expect the first element to be a comment
     'gemfire-core/src/test/resources/com/gemstone/gemfire/management/internal/configuration/domain/CacheElementJUnitTest.xml',


[35/52] [abbrv] incubator-geode git commit: GEODE-610: Add NOTICEs from dependent projects

Posted by ds...@apache.org.
GEODE-610: Add NOTICEs from dependent projects

For the binary distribution, each Apache-licensed jar that is
distributed with a NOTICE file must be included in the NOTICE
file that we include with the distribution.  I manually extracted
the NOTICE files from the dependent jars and merged the text.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/3bd930fd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/3bd930fd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/3bd930fd

Branch: refs/heads/feature/GEODE-831
Commit: 3bd930fd45bef7a15f6aa84268dcbf66ed6694a6
Parents: 49a984c
Author: Anthony Baker <ab...@apache.org>
Authored: Mon Jan 25 11:33:19 2016 -0800
Committer: Anthony Baker <ab...@apache.org>
Committed: Wed Jan 27 10:50:02 2016 -0800

----------------------------------------------------------------------
 gemfire-assembly/src/main/dist/NOTICE | 462 +++++++++++++++++++++++++++++
 1 file changed, 462 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3bd930fd/gemfire-assembly/src/main/dist/NOTICE
----------------------------------------------------------------------
diff --git a/gemfire-assembly/src/main/dist/NOTICE b/gemfire-assembly/src/main/dist/NOTICE
index 3f5dd07..b429715 100644
--- a/gemfire-assembly/src/main/dist/NOTICE
+++ b/gemfire-assembly/src/main/dist/NOTICE
@@ -3,3 +3,465 @@ Copyright 2016 The Apache Software Foundation.
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).
+
+
+The following NOTICEs pertain to software distributed with this project.
+
+Apache Commons FileUpload
+Copyright 2002-2014 The Apache Software Foundation
+
+Apache Commons IO
+Copyright 2002-2012 The Apache Software Foundation
+
+Apache Commons Lang
+Copyright 2001-2010 The Apache Software Foundation
+
+// ------------------------------------------------------------------
+// NOTICE file corresponding to the section 4d of The Apache License,
+// Version 2.0, in this case for Commons Logging
+// ------------------------------------------------------------------
+
+Commons Logging
+Copyright 2001-2007 The Apache Software Foundation
+
+This product includes/uses software(s) developed by 'an unknown organization'
+  - Unnamed - avalon-framework:avalon-framework:jar:4.1.3
+  - Unnamed - log4j:log4j:jar:1.2.12
+  - Unnamed - logkit:logkit:jar:1.0.1
+
+HBase
+Copyright 2015 The Apache Software Foundation
+
+# Jackson JSON processor
+
+Jackson is a high-performance, Free/Open Source JSON processing library.
+It was originally written by Tatu Saloranta (tatu.saloranta@iki.fi), and has
+been in development since 2007.
+It is currently developed by a community of developers, as well as supported
+commercially by FasterXML.com.
+
+## Licensing
+
+Jackson core and extension components may licensed under different licenses.
+To find the details that apply to this artifact see the accompanying LICENSE file.
+For more information, including possible other licensing options, contact
+FasterXML.com (http://fasterxml.com).
+
+## Credits
+
+A list of contributors may be found from CREDITS file, which is included
+in some artifacts (usually source distributions); but is always available
+from the source code management (SCM) system project uses.
+
+Java ClassMate library was originally written by Tatu Saloranta (tatu.saloranta@iki.fi)
+
+Other developers who have contributed code are:
+
+* Brian Langel
+
+Apache Log4j API
+Copyright 1999-2015 Apache Software Foundation
+
+Apache Log4j Core
+Copyright 1999-2012 Apache Software Foundation
+
+ResolverUtil.java
+Copyright 2005-2006 Tim Fennell
+
+Apache Log4j Commons Logging Bridge
+Copyright 1999-2015 Apache Software Foundation
+
+Apache Log4j JUL Adapter
+Copyright 1999-2015 Apache Software Foundation
+
+Apache Log4j SLF4J Binding
+Copyright 1999-2015 Apache Software Foundation
+
+Apache Lucene
+Copyright 2014 The Apache Software Foundation
+
+Includes software from other Apache Software Foundation projects,
+including, but not limited to:
+ - Apache Ant
+ - Apache Jakarta Regexp
+ - Apache Commons
+ - Apache Xerces
+
+ICU4J, (under analysis/icu) is licensed under an MIT styles license
+and Copyright (c) 1995-2008 International Business Machines Corporation and others
+
+Some data files (under analysis/icu/src/data) are derived from Unicode data such
+as the Unicode Character Database. See http://unicode.org/copyright.html for more
+details.
+
+Brics Automaton (under core/src/java/org/apache/lucene/util/automaton) is 
+BSD-licensed, created by Anders Møller. See http://www.brics.dk/automaton/
+
+The levenshtein automata tables (under core/src/java/org/apache/lucene/util/automaton) were
+automatically generated with the moman/finenight FSA library, created by
+Jean-Philippe Barrette-LaPierre. This library is available under an MIT license,
+see http://sites.google.com/site/rrettesite/moman and 
+http://bitbucket.org/jpbarrette/moman/overview/
+
+The class org.apache.lucene.util.WeakIdentityMap was derived from
+the Apache CXF project and is Apache License 2.0.
+
+The Google Code Prettify is Apache License 2.0.
+See http://code.google.com/p/google-code-prettify/
+
+JUnit (junit-4.10) is licensed under the Common Public License v. 1.0
+See http://junit.sourceforge.net/cpl-v10.html
+
+This product includes code (JaspellTernarySearchTrie) from Java Spelling Checkin
+g Package (jaspell): http://jaspell.sourceforge.net/
+License: The BSD License (http://www.opensource.org/licenses/bsd-license.php)
+
+The snowball stemmers in
+  analysis/common/src/java/net/sf/snowball
+were developed by Martin Porter and Richard Boulton.
+The snowball stopword lists in
+  analysis/common/src/resources/org/apache/lucene/analysis/snowball
+were developed by Martin Porter and Richard Boulton.
+The full snowball package is available from
+  http://snowball.tartarus.org/
+
+The KStem stemmer in
+  analysis/common/src/org/apache/lucene/analysis/en
+was developed by Bob Krovetz and Sergio Guzman-Lara (CIIR-UMass Amherst)
+under the BSD-license.
+
+The Arabic,Persian,Romanian,Bulgarian, and Hindi analyzers (common) come with a default
+stopword list that is BSD-licensed created by Jacques Savoy.  These files reside in:
+analysis/common/src/resources/org/apache/lucene/analysis/ar/stopwords.txt,
+analysis/common/src/resources/org/apache/lucene/analysis/fa/stopwords.txt,
+analysis/common/src/resources/org/apache/lucene/analysis/ro/stopwords.txt,
+analysis/common/src/resources/org/apache/lucene/analysis/bg/stopwords.txt,
+analysis/common/src/resources/org/apache/lucene/analysis/hi/stopwords.txt
+See http://members.unine.ch/jacques.savoy/clef/index.html.
+
+The German,Spanish,Finnish,French,Hungarian,Italian,Portuguese,Russian and Swedish light stemmers
+(common) are based on BSD-licensed reference implementations created by Jacques Savoy and
+Ljiljana Dolamic. These files reside in:
+analysis/common/src/java/org/apache/lucene/analysis/de/GermanLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/de/GermanMinimalStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/es/SpanishLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/fi/FinnishLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/fr/FrenchLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/fr/FrenchMinimalStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/hu/HungarianLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/it/ItalianLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/pt/PortugueseLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/ru/RussianLightStemmer.java
+analysis/common/src/java/org/apache/lucene/analysis/sv/SwedishLightStemmer.java
+
+The Stempel analyzer (stempel) includes BSD-licensed software developed 
+by the Egothor project http://egothor.sf.net/, created by Leo Galambos, Martin Kvapil,
+and Edmond Nolan.
+
+The Polish analyzer (stempel) comes with a default
+stopword list that is BSD-licensed created by the Carrot2 project. The file resides
+in stempel/src/resources/org/apache/lucene/analysis/pl/stopwords.txt.
+See http://project.carrot2.org/license.html.
+
+The SmartChineseAnalyzer source code (smartcn) was
+provided by Xiaoping Gao and copyright 2009 by www.imdict.net.
+
+WordBreakTestUnicode_*.java (under modules/analysis/common/src/test/) 
+is derived from Unicode data such as the Unicode Character Database. 
+See http://unicode.org/copyright.html for more details.
+
+The Morfologik analyzer (morfologik) includes BSD-licensed software
+developed by Dawid Weiss and Marcin Miłkowski (http://morfologik.blogspot.com/).
+
+Morfologik uses data from Polish ispell/myspell dictionary
+(http://www.sjp.pl/slownik/en/) licenced on the terms of (inter alia)
+LGPL and Creative Commons ShareAlike.
+
+Morfologic includes data from BSD-licensed dictionary of Polish (SGJP)
+(http://sgjp.pl/morfeusz/)
+
+Servlet-api.jar and javax.servlet-*.jar are under the CDDL license, the original
+source code for this can be found at http://www.eclipse.org/jetty/downloads.php
+
+===========================================================================
+Kuromoji Japanese Morphological Analyzer - Apache Lucene Integration
+===========================================================================
+
+This software includes a binary and/or source version of data from
+
+  mecab-ipadic-2.7.0-20070801
+
+which can be obtained from
+
+  http://atilika.com/releases/mecab-ipadic/mecab-ipadic-2.7.0-20070801.tar.gz
+
+or
+
+  http://jaist.dl.sourceforge.net/project/mecab/mecab-ipadic/2.7.0-20070801/mecab-ipadic-2.7.0-20070801.tar.gz
+
+===========================================================================
+mecab-ipadic-2.7.0-20070801 Notice
+===========================================================================
+
+Nara Institute of Science and Technology (NAIST),
+the copyright holders, disclaims all warranties with regard to this
+software, including all implied warranties of merchantability and
+fitness, in no event shall NAIST be liable for
+any special, indirect or consequential damages or any damages
+whatsoever resulting from loss of use, data or profits, whether in an
+action of contract, negligence or other tortuous action, arising out
+of or in connection with the use or performance of this software.
+
+A large portion of the dictionary entries
+originate from ICOT Free Software.  The following conditions for ICOT
+Free Software applies to the current dictionary as well.
+
+Each User may also freely distribute the Program, whether in its
+original form or modified, to any third party or parties, PROVIDED
+that the provisions of Section 3 ("NO WARRANTY") will ALWAYS appear
+on, or be attached to, the Program, which is distributed substantially
+in the same form as set out herein and that such intended
+distribution, if actually made, will neither violate or otherwise
+contravene any of the laws and regulations of the countries having
+jurisdiction over the User or the intended distribution itself.
+
+NO WARRANTY
+
+The program was produced on an experimental basis in the course of the
+research and development conducted during the project and is provided
+to users as so produced on an experimental basis.  Accordingly, the
+program is provided without any warranty whatsoever, whether express,
+implied, statutory or otherwise.  The term "warranty" used herein
+includes, but is not limited to, any warranty of the quality,
+performance, merchantability and fitness for a particular purpose of
+the program and the nonexistence of any infringement or violation of
+any right of any third party.
+
+Each user of the program will agree and understand, and be deemed to
+have agreed and understood, that there is no warranty whatsoever for
+the program and, accordingly, the entire risk arising from or
+otherwise connected with the program is assumed by the user.
+
+Therefore, neither ICOT, the copyright holder, or any other
+organization that participated in or was otherwise related to the
+development of the program and their respective officials, directors,
+officers and other employees shall be held liable for any and all
+damages, including, without limitation, general, special, incidental
+and consequential damages, arising out of or otherwise in connection
+with the use or inability to use the program or any product, material
+or result produced or otherwise obtained by using the program,
+regardless of whether they have been advised of, or otherwise had
+knowledge of, the possibility of such damages at any time during the
+project or thereafter.  Each user will be deemed to have agreed to the
+foregoing by his or her commencement of use of the program.  The term
+"use" as used herein includes, but is not limited to, the use,
+modification, copying and distribution of the program and the
+production of secondary products from the program.
+
+In the case where the program, whether in its original form or
+modified, was distributed or delivered to or received by a user from
+any person, organization or entity other than ICOT, unless it makes or
+grants independently of ICOT any specific warranty to the user in
+writing, such person, organization or entity, will also be exempted
+from and not be held liable to the user for any such damages as noted
+above as far as the program is concerned.
+
+
+                            The Netty Project
+                            =================
+
+Please visit the Netty web site for more information:
+
+  * http://netty.io/
+
+Copyright 2011 The Netty Project
+
+The Netty Project licenses this file to you under the Apache License,
+version 2.0 (the "License"); you may not use this file except in compliance
+with the License. You may obtain a copy of the License at:
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
+WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
+License for the specific language governing permissions and limitations
+under the License.
+
+Also, please refer to each LICENSE.<component>.txt file, which is located in
+the 'license' directory of the distribution file, for the license terms of the
+components that this product depends on.
+
+-------------------------------------------------------------------------------
+This product contains the extensions to Java Collections Framework which has
+been derived from the works by JSR-166 EG, Doug Lea, and Jason T. Greene:
+
+  * LICENSE:
+    * license/LICENSE.jsr166y.txt (Public Domain)
+  * HOMEPAGE:
+    * http://gee.cs.oswego.edu/cgi-bin/viewcvs.cgi/jsr166/
+    * http://viewvc.jboss.org/cgi-bin/viewvc.cgi/jbosscache/experimental/jsr166/
+
+This product contains a modified version of Robert Harder's Public Domain
+Base64 Encoder and Decoder, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.base64.txt (Public Domain)
+  * HOMEPAGE:
+    * http://iharder.sourceforge.net/current/java/base64/
+
+This product contains a modified portion of 'Webbit', an event based  
+WebSocket and HTTP server, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.webbit.txt (BSD License)
+  * HOMEPAGE:
+    * https://github.com/joewalnes/webbit
+
+This product contains a modified portion of 'SLF4J', a simple logging
+facade for Java, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.slf4j.txt (MIT License)
+  * HOMEPAGE:
+    * http://www.slf4j.org/
+
+
+This product contains a modified version of Roland Kuhn's ASL2
+AbstractNodeQueue, which is based on Dmitriy Vyukov's non-intrusive MPSC queue.
+It can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.abstractnodequeue.txt (Public Domain)
+  * HOMEPAGE:
+    * https://github.com/akka/akka/blob/wip-2.2.3-for-scala-2.11/akka-actor/src/main/java/akka/dispatch/AbstractNodeQueue.java
+
+This product contains a modified portion of Nitsan Wakart's 'JCTools', Java Concurrency Tools for the JVM,
+ which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.jctools.txt (ASL2 License)
+  * HOMEPAGE:
+    * https://github.com/JCTools/JCTools
+
+
+This product optionally depends on 'JZlib', a re-implementation of zlib in
+pure Java, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.jzlib.txt (BSD style License)
+  * HOMEPAGE:
+    * http://www.jcraft.com/jzlib/
+
+This product optionally depends on 'Protocol Buffers', Google's data
+interchange format, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.protobuf.txt (New BSD License)
+  * HOMEPAGE:
+    * http://code.google.com/p/protobuf/
+
+This product optionally depends on 'Bouncy Castle Crypto APIs' to generate
+a temporary self-signed X.509 certificate when the JVM does not provide the
+equivalent functionality.  It can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.bouncycastle.txt (MIT License)
+  * HOMEPAGE:
+    * http://www.bouncycastle.org/
+
+This product optionally depends on 'Snappy', a compression library produced
+by Google Inc, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.snappy.txt (New BSD License)
+  * HOMEPAGE:
+    * http://code.google.com/p/snappy/
+
+This product optionally depends on 'JBoss Marshalling', an alternative Java
+serialization API, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.jboss-marshalling.txt (GNU LGPL 2.1)
+  * HOMEPAGE:
+    * http://www.jboss.org/jbossmarshalling
+
+This product optionally depends on 'Caliper', Google's micro-
+benchmarking framework, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.caliper.txt (Apache License 2.0)
+  * HOMEPAGE:
+    * http://code.google.com/p/caliper/
+
+This product optionally depends on 'Apache Commons Logging', a logging
+framework, which can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.commons-logging.txt (Apache License 2.0)
+  * HOMEPAGE:
+    * http://commons.apache.org/logging/
+
+This product optionally depends on 'Apache Log4J', a logging framework, which
+can be obtained at:
+
+  * LICENSE:
+    * license/LICENSE.log4j.txt (Apache License 2.0)
+  * HOMEPAGE:
+    * http://logging.apache.org/log4j/
+
+Spring Framework 3.2.12.RELEASE
+Copyright (c) 2002-2014 Pivotal, Inc.
+
+This product is licensed to you under the Apache License, Version 2.0
+(the "License"). You may not use this product except in compliance with
+the License.
+
+This product may include a number of subcomponents with separate
+copyright notices and license terms. Your use of the source code for
+these subcomponents is subject to the terms and conditions of the
+subcomponent's license, as noted in the license.txt file.
+
+   ======================================================================
+   == NOTICE file corresponding to section 4 d of the Apache License,  ==
+   == Version 2.0, for the Spring Framework distribution.              ==
+   ======================================================================
+
+   This product includes software developed by
+   the Apache Software Foundation (http://www.apache.org).
+
+   The end-user documentation included with a redistribution, if any,
+   must include the following acknowledgement:
+
+     "This product includes software developed by the Spring Framework
+      Project (http://www.springframework.org)."
+
+   Alternately, this acknowledgement may appear in the software itself,
+   if and wherever such third-party acknowledgements normally appear.
+
+   The names "Spring", "Spring Framework", and "Spring GemFire" must
+   not be used to endorse or promote products derived from this
+   software without prior written permission. For written permission,
+   please contact enquiries@springsource.com.
+
+   ======================================================================
+   == NOTICE file corresponding to section 4 d of the Apache License,  ==
+   == Version 2.0, for the Spring Framework distribution.              ==
+   ======================================================================
+
+   This product includes software developed by
+   the Apache Software Foundation (http://www.apache.org).
+
+   The end-user documentation included with a redistribution, if any,
+   must include the following acknowledgement:
+
+     "This product includes software developed by the Spring Framework
+      Project (http://www.springframework.org)."
+
+   Alternately, this acknowledgement may appear in the software itself,
+   if and wherever such third-party acknowledgements normally appear.
+
+   The names "Spring", "Spring Framework", and "Spring Shell" must
+   not be used to endorse or promote products derived from this
+   software without prior written permission. For written permission,
+   please contact enquiries@springsource.com.


[29/52] [abbrv] incubator-geode git commit: GEODE-819: Fix dunit imports in WAN and CQ tests

Posted by ds...@apache.org.
GEODE-819: Fix dunit imports in WAN and CQ tests

Merging from develop to wan_cq_donation picked up some package renames
of the dunit framework. These needed to be applied to all of the wan and
cq tests.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/27d965d9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/27d965d9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/27d965d9

Branch: refs/heads/feature/GEODE-831
Commit: 27d965d96d0131d094ec1d54172d40d6439ff191
Parents: 8d8b573
Author: Dan Smith <up...@apache.org>
Authored: Tue Jan 26 11:07:34 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 11:10:25 2016 -0800

----------------------------------------------------------------------
 .../cache/query/cq/dunit/CqDataDUnitTest.java        | 11 +++++------
 .../cq/dunit/CqDataOptimizedExecuteDUnitTest.java    |  3 +--
 .../query/cq/dunit/CqDataUsingPoolDUnitTest.java     |  9 ++++-----
 .../CqDataUsingPoolOptimizedExecuteDUnitTest.java    |  3 +--
 .../cache/query/cq/dunit/CqPerfDUnitTest.java        |  7 +++----
 .../query/cq/dunit/CqPerfUsingPoolDUnitTest.java     |  7 +++----
 .../cache/query/cq/dunit/CqQueryDUnitTest.java       | 15 +++++++--------
 .../cq/dunit/CqQueryOptimizedExecuteDUnitTest.java   |  7 +++----
 .../query/cq/dunit/CqQueryUsingPoolDUnitTest.java    | 13 ++++++-------
 .../CqQueryUsingPoolOptimizedExecuteDUnitTest.java   |  3 +--
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java      |  7 +++----
 ...qResultSetUsingPoolOptimizedExecuteDUnitTest.java |  7 +++----
 .../cache/query/cq/dunit/CqStateDUnitTest.java       | 11 +++++------
 .../cache/query/cq/dunit/CqStatsDUnitTest.java       |  7 +++----
 .../cq/dunit/CqStatsOptimizedExecuteDUnitTest.java   |  3 +--
 .../query/cq/dunit/CqStatsUsingPoolDUnitTest.java    |  7 +++----
 .../CqStatsUsingPoolOptimizedExecuteDUnitTest.java   |  3 +--
 .../cache/query/cq/dunit/CqTimeTestListener.java     |  5 ++---
 .../cq/dunit/PartitionedRegionCqQueryDUnitTest.java  |  7 +++----
 ...tionedRegionCqQueryOptimizedExecuteDUnitTest.java |  7 +++----
 .../cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java |  7 +++----
 .../PrCqUsingPoolOptimizedExecuteDUnitTest.java      |  3 +--
 .../cache/query/dunit/PdxQueryCQDUnitTest.java       |  8 ++++----
 .../cache/query/dunit/PdxQueryCQTestBase.java        | 12 +++---------
 .../query/dunit/QueryIndexUpdateRIDUnitTest.java     |  7 +++----
 .../cache/query/dunit/QueryMonitorDUnitTest.java     | 11 +++++------
 .../cache/snapshot/ClientSnapshotDUnitTest.java      |  5 ++---
 .../internal/cache/PRDeltaPropagationDUnitTest.java  |  9 ++++-----
 .../gemfire/internal/cache/PutAllCSDUnitTest.java    | 13 ++++++-------
 .../internal/cache/RemoteCQTransactionDUnitTest.java |  7 +++----
 .../internal/cache/ha/CQListGIIDUnitTest.java        |  6 +++---
 .../internal/cache/ha/HADispatcherDUnitTest.java     |  7 +++----
 .../tier/sockets/ClientToServerDeltaDUnitTest.java   |  7 +++----
 .../sockets/DeltaPropagationWithCQDUnitTest.java     |  7 +++----
 ...DeltaToRegionRelationCQRegistrationDUnitTest.java |  9 ++++-----
 .../tier/sockets/DurableClientSimpleDUnitTest.java   | 11 +++++------
 .../cache/tier/sockets/DurableClientTestCase.java    |  7 +++----
 .../management/CacheServerManagementDUnitTest.java   |  9 ++++-----
 .../cli/commands/ClientCommandsDUnitTest.java        | 10 +++++-----
 .../cli/commands/DurableClientCommandsDUnitTest.java |  7 +++----
 .../management/internal/pulse/TestCQDUnitTest.java   |  2 +-
 .../internal/pulse/TestClientsDUnitTest.java         |  3 +--
 .../internal/pulse/TestServerDUnitTest.java          |  2 +-
 .../security/ClientAuthorizationTwoDUnitTest.java    |  3 +--
 .../security/ClientAuthzObjectModDUnitTest.java      |  7 +++----
 .../security/ClientCQPostAuthorizationDUnitTest.java |  7 +++----
 .../security/ClientPostAuthorizationDUnitTest.java   |  3 +--
 .../gemfire/security/MultiuserAPIDUnitTest.java      |  4 ++--
 .../security/MultiuserDurableCQAuthzDUnitTest.java   |  5 ++---
 .../internal/cache/UpdateVersionDUnitTest.java       | 11 +++++------
 .../gemfire/internal/cache/wan/WANTestBase.java      |  6 +++---
 .../ConcurrentParallelGatewaySenderDUnitTest.java    |  3 +--
 ...ntParallelGatewaySenderOperation_1_DUnitTest.java |  3 +--
 ...ntParallelGatewaySenderOperation_2_DUnitTest.java |  5 ++---
 ...urrentSerialGatewaySenderOperationsDUnitTest.java |  2 +-
 .../ConcurrentWANPropogation_1_DUnitTest.java        |  3 +--
 .../ConcurrentWANPropogation_2_DUnitTest.java        |  3 +--
 .../cache/wan/disttx/DistTXWANDUnitTest.java         |  5 ++---
 .../misc/CommonParallelGatewaySenderDUnitTest.java   |  5 ++---
 .../NewWANConcurrencyCheckForDestroyDUnitTest.java   |  3 +--
 .../internal/cache/wan/misc/PDXNewWanDUnitTest.java  |  3 +--
 ...icatedRegion_ParallelWANPersistenceDUnitTest.java |  5 ++---
 ...icatedRegion_ParallelWANPropogationDUnitTest.java |  9 ++++-----
 .../wan/misc/SenderWithTransportFilterDUnitTest.java |  3 +--
 .../ShutdownAllPersistentGatewaySenderDUnitTest.java |  9 ++++-----
 .../cache/wan/misc/WANLocatorServerDUnitTest.java    |  3 +--
 .../internal/cache/wan/misc/WANSSLDUnitTest.java     |  3 +--
 .../cache/wan/misc/WanAutoDiscoveryDUnitTest.java    |  5 ++---
 .../ParallelGatewaySenderOperationsDUnitTest.java    |  9 ++++-----
 .../ParallelGatewaySenderQueueOverflowDUnitTest.java |  3 +--
 ...lWANPersistenceEnabledGatewaySenderDUnitTest.java |  5 ++---
 .../ParallelWANPropagationClientServerDUnitTest.java |  3 +--
 ...ParallelWANPropagationConcurrentOpsDUnitTest.java |  3 +--
 .../parallel/ParallelWANPropagationDUnitTest.java    |  3 +--
 .../wan/parallel/ParallelWANStatsDUnitTest.java      |  3 +--
 ...ialGatewaySenderDistributedDeadlockDUnitTest.java |  2 +-
 .../SerialGatewaySenderEventListenerDUnitTest.java   |  3 +--
 .../SerialGatewaySenderOperationsDUnitTest.java      |  5 ++---
 .../serial/SerialGatewaySenderQueueDUnitTest.java    |  3 +--
 ...lWANPersistenceEnabledGatewaySenderDUnitTest.java |  3 +--
 .../wan/serial/SerialWANPropogationDUnitTest.java    |  3 +--
 ...ialWANPropogation_PartitionedRegionDUnitTest.java |  3 +--
 .../cache/wan/serial/SerialWANStatsDUnitTest.java    |  3 +--
 .../cache/wan/wancommand/WANCommandTestBase.java     |  7 +++----
 .../WanCommandCreateGatewayReceiverDUnitTest.java    |  5 ++---
 .../WanCommandGatewayReceiverStartDUnitTest.java     |  5 ++---
 .../WanCommandGatewayReceiverStopDUnitTest.java      |  5 ++---
 .../gemfire/management/WANManagementDUnitTest.java   |  7 +++----
 .../configuration/ClusterConfigurationDUnitTest.java |  9 +++++----
 .../internal/pulse/TestRemoteClusterDUnitTest.java   |  7 +++----
 90 files changed, 222 insertions(+), 306 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataDUnitTest.java
index 63235d4..c26282c 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataDUnitTest.java
@@ -38,12 +38,11 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.cache30.CertifiableTestCacheListener;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataOptimizedExecuteDUnitTest.java
index 2a44b3e..45f61f8 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataOptimizedExecuteDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.cache.query.cq.dunit;
 
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqServiceImpl#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolDUnitTest.java
index 245b6e4..5feb1b5 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolDUnitTest.java
@@ -57,11 +57,10 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolOptimizedExecuteDUnitTest.java
index dd0adec..e157fb0 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqDataUsingPoolOptimizedExecuteDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.cache.query.cq.dunit;
 
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqServiceImpl#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
index 989fee0..cdc11f2 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfDUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
index 5fd1998..059c8a0 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqPerfUsingPoolDUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryDUnitTest.java
index 5ee75e3..1ea2fdd 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryDUnitTest.java
@@ -64,11 +64,10 @@ import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.DistributedTombstoneOperation;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.
@@ -2066,7 +2065,7 @@ public class CqQueryDUnitTest extends CacheTestCase {
     try {
       createCQ(client, "testCQCreateClose_0", cqs[0]);
       fail("Trying to create CQ with same name. Should have thrown CQExistsException");
-    } catch (dunit.RMIException rmiExc) {
+    } catch (com.gemstone.gemfire.test.dunit.RMIException rmiExc) {
       Throwable cause = rmiExc.getCause();
       assertTrue("unexpected cause: " + cause.getClass().getName(), cause instanceof AssertionError);
       Throwable causeCause = cause.getCause(); // should be a CQExistsException
@@ -2081,7 +2080,7 @@ public class CqQueryDUnitTest extends CacheTestCase {
     try {
       createCQ(server, "testCQCreateClose_1", cqs[0]);
       fail("Trying to create CQ on Cache Server. Should have thrown Exception.");
-    } catch (dunit.RMIException rmiExc) {
+    } catch (com.gemstone.gemfire.test.dunit.RMIException rmiExc) {
       Throwable cause = rmiExc.getCause();
       assertTrue("unexpected cause: " + cause.getClass().getName(), 
           cause instanceof AssertionError);
@@ -2095,7 +2094,7 @@ public class CqQueryDUnitTest extends CacheTestCase {
     try {
       executeCQ(client, "testCQCreateClose_2", false, "RegionNotFoundException");
       fail("Trying to create CQ on non-existing Region. Should have thrown Exception.");
-    } catch (dunit.RMIException rmiExc) {
+    } catch (com.gemstone.gemfire.test.dunit.RMIException rmiExc) {
       Throwable cause = rmiExc.getCause();
       if (!(cause instanceof AssertionError)) {
         getLogWriter().severe("Expected to see an AssertionError.", cause);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryOptimizedExecuteDUnitTest.java
index 8688057..54ec12d 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryOptimizedExecuteDUnitTest.java
@@ -24,10 +24,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.CqServiceProvider;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test class for testing {@link CqServiceImpl#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolDUnitTest.java
index 343b529..4988831 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolDUnitTest.java
@@ -66,11 +66,10 @@ import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.
@@ -1783,7 +1782,7 @@ public class CqQueryUsingPoolDUnitTest extends CacheTestCase {
     try {
       createCQ(client, poolName, "testCQCreateClose_0", cqs[0]);
       fail("Trying to create CQ with same name. Should have thrown CQExistsException");
-    } catch (dunit.RMIException rmiExc) {
+    } catch (com.gemstone.gemfire.test.dunit.RMIException rmiExc) {
       Throwable cause = rmiExc.getCause();
       assertTrue("unexpected cause: " + cause.getClass().getName(), cause instanceof AssertionError);
       Throwable causeCause = cause.getCause(); // should be a CQExistsException
@@ -1798,7 +1797,7 @@ public class CqQueryUsingPoolDUnitTest extends CacheTestCase {
     try {
       createCQ(server, "testCQCreateClose_1", cqs[0]);
       fail("Trying to create CQ on Cache Server. Should have thrown Exception.");
-    } catch (dunit.RMIException rmiExc) {
+    } catch (com.gemstone.gemfire.test.dunit.RMIException rmiExc) {
       Throwable cause = rmiExc.getCause();
       assertTrue("unexpected cause: " + cause.getClass().getName(), 
           cause instanceof AssertionError);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolOptimizedExecuteDUnitTest.java
index acfb473..07c1650 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqQueryUsingPoolOptimizedExecuteDUnitTest.java
@@ -17,8 +17,7 @@
 package com.gemstone.gemfire.cache.query.cq.dunit;
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqServiceImpl#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolDUnitTest.java
index 2346e91..de349a5 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolDUnitTest.java
@@ -32,10 +32,9 @@ import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolOptimizedExecuteDUnitTest.java
index 14affa6..74351b0 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqResultSetUsingPoolOptimizedExecuteDUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.ServerCQImpl;
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CqResultSetUsingPoolOptimizedExecuteDUnitTest extends CqResultSetUsingPoolDUnitTest{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStateDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStateDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStateDUnitTest.java
index 56d8f77..6d6213b 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStateDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStateDUnitTest.java
@@ -21,12 +21,11 @@ import java.util.Properties;
 import com.gemstone.gemfire.cache.query.CqQuery;
 import com.gemstone.gemfire.cache.query.dunit.HelperTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CqStateDUnitTest extends HelperTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsDUnitTest.java
index 2109e24..8f3c260 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsDUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.CqServiceVsdStats;
 import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsOptimizedExecuteDUnitTest.java
index fdb46c3..f52d655 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsOptimizedExecuteDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.cache.query.cq.dunit;
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqService;
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqService#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolDUnitTest.java
index 249f3da..1210426 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolDUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.CqServiceVsdStats;
 import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the ContiunousQuery mechanism in GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolOptimizedExecuteDUnitTest.java
index 9769ddd..8723eb3 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqStatsUsingPoolOptimizedExecuteDUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.cache.query.cq.dunit;
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqService;
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqService#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqTimeTestListener.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqTimeTestListener.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqTimeTestListener.java
index cd75e97..23d0728 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqTimeTestListener.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/CqTimeTestListener.java
@@ -25,9 +25,8 @@ import com.gemstone.gemfire.cache.Operation;
 import com.gemstone.gemfire.cache.query.CqEvent;
 import com.gemstone.gemfire.cache.query.CqListener;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * @author anil.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
index a236909..360c0d9 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryDUnitTest.java
@@ -46,10 +46,9 @@ import com.gemstone.gemfire.cache30.ClientServerTestCase;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 /**
  * Test class for Partitioned Region and CQs
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryOptimizedExecuteDUnitTest.java
index 4bbc5e7..e5544b7 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PartitionedRegionCqQueryOptimizedExecuteDUnitTest.java
@@ -23,10 +23,9 @@ import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceProvider;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PartitionedRegionCqQueryOptimizedExecuteDUnitTest extends PartitionedRegionCqQueryDUnitTest{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java
index c8e502f..80cd738 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolDUnitTest.java
@@ -40,12 +40,11 @@ import com.gemstone.gemfire.cache.query.Struct;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.ClientServerTestCase;
+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.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
 /**
  * Test class for Partitioned Region and CQs
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolOptimizedExecuteDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolOptimizedExecuteDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolOptimizedExecuteDUnitTest.java
index c890c87..5db4b22 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolOptimizedExecuteDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/cq/dunit/PrCqUsingPoolOptimizedExecuteDUnitTest.java
@@ -17,8 +17,7 @@
 package com.gemstone.gemfire.cache.query.cq.dunit;
 
 import com.gemstone.gemfire.cache.query.internal.cq.CqServiceImpl;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test class for testing {@link CqServiceImpl#EXECUTE_QUERY_DURING_INIT} flag

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQDUnitTest.java
index 15a74ce..8abed40 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQDUnitTest.java
@@ -35,12 +35,12 @@ import com.gemstone.gemfire.cache.query.Struct;
 import com.gemstone.gemfire.cache.query.cq.dunit.CqQueryTestListener;
 import com.gemstone.gemfire.cache.query.dunit.PdxQueryCQTestBase.TestObject;
 import com.gemstone.gemfire.cache30.ClientServerTestCase;
+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.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
 
 public class PdxQueryCQDUnitTest extends PdxQueryCQTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQTestBase.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQTestBase.java
index 7129f62..3637dce 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQTestBase.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/PdxQueryCQTestBase.java
@@ -35,15 +35,10 @@ 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.query.CacheUtils;
-import com.gemstone.gemfire.cache.query.CqAttributes;
-import com.gemstone.gemfire.cache.query.CqEvent;
-import com.gemstone.gemfire.cache.query.CqListener;
-import com.gemstone.gemfire.cache.query.CqQuery;
 import com.gemstone.gemfire.cache.query.Query;
 import com.gemstone.gemfire.cache.query.QueryService;
 import com.gemstone.gemfire.cache.query.SelectResults;
 import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.cq.dunit.CqQueryTestListener;
 import com.gemstone.gemfire.cache.query.data.PortfolioPdx;
 import com.gemstone.gemfire.cache.query.data.PositionPdx;
 import com.gemstone.gemfire.cache.server.CacheServer;
@@ -56,10 +51,9 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.pdx.PdxReader;
 import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxWriter;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public abstract class PdxQueryCQTestBase extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
index 8f80f48..a39f5e8 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryIndexUpdateRIDUnitTest.java
@@ -40,14 +40,13 @@ import com.gemstone.gemfire.cache.query.internal.QueryObserverAdapter;
 import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.ClientServerTestCase;
+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.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.cache30.CertifiableTestCacheListener;
 
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * This class tests register interest behavior on client at startup given that
  * client has already created a Index on region on which it registers interest.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
index f421273..14884bd 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryMonitorDUnitTest.java
@@ -48,12 +48,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests for QueryMonitoring service.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
index 5ccaeb3..cc053fc 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/cache/snapshot/ClientSnapshotDUnitTest.java
@@ -40,9 +40,8 @@ import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
 import com.gemstone.gemfire.cache.util.CqListenerAdapter;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class ClientSnapshotDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
index 4810e28..f77f845 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PRDeltaPropagationDUnitTest.java
@@ -56,11 +56,10 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PutAllCSDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PutAllCSDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PutAllCSDUnitTest.java
index 3737ffb..cd2a26e 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PutAllCSDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/PutAllCSDUnitTest.java
@@ -75,13 +75,12 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests putAll for c/s. Also tests removeAll

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
index 0f089c5..3722afb 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/RemoteCQTransactionDUnitTest.java
@@ -69,10 +69,9 @@ import com.gemstone.gemfire.internal.cache.execute.data.CustId;
 import com.gemstone.gemfire.internal.cache.execute.data.Customer;
 import com.gemstone.gemfire.internal.cache.execute.data.Order;
 import com.gemstone.gemfire.internal.cache.execute.data.OrderId;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author sbawaska

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
index 4bce2ac..f5f1fc1 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/CQListGIIDUnitTest.java
@@ -58,9 +58,9 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
 import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADispatcherDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADispatcherDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADispatcherDUnitTest.java
index 2f64285..ddc907c 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADispatcherDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/ha/HADispatcherDUnitTest.java
@@ -54,10 +54,9 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerTestUtil;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ConflationDUnitTest;
 import com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This Dunit test is to verify that when the dispatcher of CS dispatches the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
index 968eda9..d04d249 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientToServerDeltaDUnitTest.java
@@ -50,10 +50,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionLocalMaxMemoryDUnitTest.TestObject1;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test client to server flow for delta propogation

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
index 382b056..2e7efe7 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaPropagationWithCQDUnitTest.java
@@ -52,10 +52,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author ashetkar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
index 6902619..ed7232f 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DeltaToRegionRelationCQRegistrationDUnitTest.java
@@ -42,11 +42,10 @@ 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.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 /**
  * This tests the flag setting for region ( DataPolicy as Empty ) for
  * Delta propogation for a client while registering CQ

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
index 7771e67..04ce137 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientSimpleDUnitTest.java
@@ -41,12 +41,11 @@ import com.gemstone.gemfire.internal.cache.ClientServerObserver;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DurableClientSimpleDUnitTest extends DurableClientTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientTestCase.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientTestCase.java
index 98e0624..c3a3482 100755
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientTestCase.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientTestCase.java
@@ -62,10 +62,9 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.InternalCache;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Class <code>DurableClientTestCase</code> tests durable client

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
index bc9c6a9..58c682b 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/CacheServerManagementDUnitTest.java
@@ -49,11 +49,10 @@ import com.gemstone.gemfire.management.internal.JmxManagerLocatorRequest;
 import com.gemstone.gemfire.management.internal.JmxManagerLocatorResponse;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Cache Server related management test cases

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ClientCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ClientCommandsDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ClientCommandsDUnitTest.java
index 5908c5f..d1d9559 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ClientCommandsDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ClientCommandsDUnitTest.java
@@ -63,12 +63,12 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData;
 import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData.SectionResultData;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.management.internal.cli.result.TabularResultData;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
index 6010f38..89c7d5e 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DurableClientCommandsDUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.management.cli.Result.Status;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
index 0497305..131cbcd 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestCQDUnitTest.java
@@ -21,7 +21,7 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing continuous query.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
index 9fff40d..814e07e 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestClientsDUnitTest.java
@@ -21,8 +21,7 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing Number of clients and can be extended for relevant test

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
index d53e085..6475fa5 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/management/internal/pulse/TestServerDUnitTest.java
@@ -21,7 +21,7 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.management.DistributedSystemMXBean;
 import com.gemstone.gemfire.management.ManagementService;
 import com.gemstone.gemfire.management.ManagementTestBase;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is for testing server count details from MBean

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTwoDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTwoDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTwoDUnitTest.java
index bd6529a..7725ef6 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTwoDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthorizationTwoDUnitTest.java
@@ -17,8 +17,7 @@
 package com.gemstone.gemfire.security;
 
 import com.gemstone.gemfire.cache.operations.OperationContext.OperationCode;
-
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.Host;
 
 /**
  * Tests for authorization from client to server. This tests for authorization

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthzObjectModDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthzObjectModDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthzObjectModDUnitTest.java
index 3fe7652..58f26bb 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthzObjectModDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientAuthzObjectModDUnitTest.java
@@ -32,10 +32,9 @@ import com.gemstone.gemfire.cache.operations.OperationContext.OperationCode;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.security.ObjectWithAuthz;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests for authorization callback that modify objects and callbacks from

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientCQPostAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientCQPostAuthorizationDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientCQPostAuthorizationDUnitTest.java
index 6115f17..2854c24 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientCQPostAuthorizationDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientCQPostAuthorizationDUnitTest.java
@@ -42,10 +42,9 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 /**
  * This is for multiuser-authentication
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientPostAuthorizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientPostAuthorizationDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientPostAuthorizationDUnitTest.java
index 4ae7430..bd22dfb 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientPostAuthorizationDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/ClientPostAuthorizationDUnitTest.java
@@ -26,8 +26,7 @@ import security.AuthzCredentialGenerator;
 import security.CredentialGenerator;
 import com.gemstone.gemfire.cache.operations.OperationContext.OperationCode;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.Host;
 
 /**
  * Tests for authorization from client to server. This tests for authorization

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserAPIDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserAPIDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserAPIDUnitTest.java
index 57f649e..26f2e31 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserAPIDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserAPIDUnitTest.java
@@ -36,9 +36,9 @@ import com.gemstone.gemfire.cache.query.Query;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.Host;
-import dunit.VM;
 import security.DummyCredentialGenerator;
 
 public class MultiuserAPIDUnitTest extends ClientAuthorizationTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserDurableCQAuthzDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserDurableCQAuthzDUnitTest.java b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserDurableCQAuthzDUnitTest.java
index c44683f..675f8c6 100644
--- a/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserDurableCQAuthzDUnitTest.java
+++ b/gemfire-cq/src/test/java/com/gemstone/gemfire/security/MultiuserDurableCQAuthzDUnitTest.java
@@ -38,9 +38,8 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * @author ashetkar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
index 065ba6c..70ecac5 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/UpdateVersionDUnitTest.java
@@ -53,12 +53,11 @@ import com.gemstone.gemfire.internal.cache.versions.VersionSource;
 import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.cache.wan.InternalGatewaySenderFactory;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * @author Shobhit Agarwal

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index e3c3a89..230c8d8 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -113,11 +113,11 @@ import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderEve
 import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
 import com.gemstone.gemfire.pdx.SimpleClass;
 import com.gemstone.gemfire.pdx.SimpleClass1;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
 import junit.framework.Assert;
 
 public class WANTestBase extends DistributedTestCase{

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderDUnitTest.java
index b2e2fd2..c14af54 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderDUnitTest.java
@@ -24,12 +24,11 @@ import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.BatchException70;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderEventProcessor;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 import java.net.SocketException;
 import java.util.Set;
 
-import dunit.AsyncInvocation;
-
 /**
  * Test the functionality of ParallelGatewaySender with multiple dispatchers.
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
index 216c76a..e0775b7 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_1_DUnitTest.java
@@ -18,8 +18,7 @@ package com.gemstone.gemfire.internal.cache.wan.concurrent;
 
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
index be8c3ac..f770062 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
@@ -21,9 +21,8 @@ import com.gemstone.gemfire.cache.RegionDestroyedException;
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 /**
  * @author skumar
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
index 3126c4e..b709334 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentSerialGatewaySenderOperationsDUnitTest.java
@@ -21,8 +21,8 @@ import java.util.Set;
 import com.gemstone.gemfire.cache.wan.GatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
-import dunit.AsyncInvocation;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_1_DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_1_DUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_1_DUnitTest.java
index 7066fc5..804c3ed 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_1_DUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_1_DUnitTest.java
@@ -23,8 +23,7 @@ import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.wan.BatchException70;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * All the test cases are similar to SerialWANPropogationDUnitTest except that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
index 1700664..9bcc72b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentWANPropogation_2_DUnitTest.java
@@ -23,8 +23,7 @@ import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase.MyGatewayEventFilter;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * All the test cases are similar to SerialWANPropogationDUnitTest except that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/disttx/DistTXWANDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/disttx/DistTXWANDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/disttx/DistTXWANDUnitTest.java
index 242dfbe..ca68454 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/disttx/DistTXWANDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/disttx/DistTXWANDUnitTest.java
@@ -20,9 +20,8 @@ import com.gemstone.gemfire.CancelException;
 import com.gemstone.gemfire.cache.CacheClosedException;
 import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
 
 public class DistTXWANDUnitTest extends WANTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/CommonParallelGatewaySenderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/CommonParallelGatewaySenderDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/CommonParallelGatewaySenderDUnitTest.java
index d2b6595..39e3fed 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/CommonParallelGatewaySenderDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/CommonParallelGatewaySenderDUnitTest.java
@@ -25,9 +25,8 @@ import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderEventProcessor;
 import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
 import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/NewWANConcurrencyCheckForDestroyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/NewWANConcurrencyCheckForDestroyDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/NewWANConcurrencyCheckForDestroyDUnitTest.java
index 68be55b..62ed047 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/NewWANConcurrencyCheckForDestroyDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/NewWANConcurrencyCheckForDestroyDUnitTest.java
@@ -30,8 +30,7 @@ import com.gemstone.gemfire.internal.cache.RegionEntry;
 import com.gemstone.gemfire.internal.cache.Token.Tombstone;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * @author shobhit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
index b4d4f2f..0393e82 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/PDXNewWanDUnitTest.java
@@ -19,8 +19,7 @@ package com.gemstone.gemfire.internal.cache.wan.misc;
 import com.gemstone.gemfire.cache.CacheWriterException;
 import com.gemstone.gemfire.cache.client.ServerOperationException;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class PDXNewWanDUnitTest extends WANTestBase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/27d965d9/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
index e9d9a2c..7d3da8b 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/misc/ReplicatedRegion_ParallelWANPersistenceDUnitTest.java
@@ -20,9 +20,8 @@ import com.gemstone.gemfire.cache.CacheClosedException;
 import com.gemstone.gemfire.cache.DataPolicy;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase.ExpectedException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.ExpectedException;
 
 public class ReplicatedRegion_ParallelWANPersistenceDUnitTest extends WANTestBase {
   


[40/52] [abbrv] incubator-geode git commit: GEODE-865: CI Failure: ConcurrentParallelGatewaySenderOperation_2_DUnitTest.testParallelGatewaySenders_SingleNode_UserPR_localDestroy_RecreateRegion

Posted by ds...@apache.org.
GEODE-865: CI Failure: ConcurrentParallelGatewaySenderOperation_2_DUnitTest.testParallelGatewaySenders_SingleNode_UserPR_localDestroy_RecreateRegion


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/68a85fed
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/68a85fed
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/68a85fed

Branch: refs/heads/feature/GEODE-831
Commit: 68a85fed991d7ebd9519c0f77b5b5b564b965a56
Parents: 09bd530
Author: Barry Oglesby <bo...@pivotal.io>
Authored: Tue Jan 26 13:43:21 2016 -0800
Committer: Barry Oglesby <bo...@pivotal.io>
Committed: Wed Jan 27 18:02:19 2016 -0800

----------------------------------------------------------------------
 .../gemfire/internal/cache/wan/WANTestBase.java |  14 +-
 ...allelGatewaySenderOperation_2_DUnitTest.java | 841 +++++--------------
 2 files changed, 234 insertions(+), 621 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/68a85fed/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
index 0c32d1f..3dd4742 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/WANTestBase.java
@@ -2395,7 +2395,7 @@ public class WANTestBase extends DistributedTestCase{
   public static void createConcurrentSender(String dsName, int remoteDsId,
       boolean isParallel, Integer maxMemory, Integer batchSize,
       boolean isConflation, boolean isPersistent, GatewayEventFilter filter,
-      boolean isManulaStart, int concurrencyLevel, OrderPolicy policy) {
+      boolean isManualStart, int concurrencyLevel, OrderPolicy policy) {
 
     File persistentDirectory = new File(dsName + "_disk_"
         + System.currentTimeMillis() + "_" + VM.getCurrentVMNum());
@@ -2408,7 +2408,7 @@ public class WANTestBase extends DistributedTestCase{
       gateway.setParallel(true);
       gateway.setMaximumQueueMemory(maxMemory);
       gateway.setBatchSize(batchSize);
-      gateway.setManualStart(isManulaStart);
+      gateway.setManualStart(isManualStart);
       ((InternalGatewaySenderFactory) gateway)
           .setLocatorDiscoveryCallback(new MyLocatorCallback());
       if (filter != null) {
@@ -2430,7 +2430,7 @@ public class WANTestBase extends DistributedTestCase{
       GatewaySenderFactory gateway = cache.createGatewaySenderFactory();
       gateway.setMaximumQueueMemory(maxMemory);
       gateway.setBatchSize(batchSize);
-      gateway.setManualStart(isManulaStart);
+      gateway.setManualStart(isManualStart);
       ((InternalGatewaySenderFactory) gateway)
           .setLocatorDiscoveryCallback(new MyLocatorCallback());
       if (filter != null) {
@@ -4825,7 +4825,13 @@ public class WANTestBase extends DistributedTestCase{
       }
     }
   }
-  
+
+  protected Integer[] createLNAndNYLocators() {
+    Integer lnPort = (Integer) vm0.invoke(() -> createFirstLocatorWithDSId(1));
+    Integer nyPort = (Integer) vm1.invoke(() -> createFirstRemoteLocator(2, lnPort));
+    return new Integer[] { lnPort, nyPort };
+  }
+
   public static class MyLocatorCallback extends
       LocatorDiscoveryCallbackAdapter {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/68a85fed/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
index f770062..694fc1f 100644
--- a/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
+++ b/gemfire-wan/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentParallelGatewaySenderOperation_2_DUnitTest.java
@@ -23,6 +23,8 @@ import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
 import com.gemstone.gemfire.internal.cache.wan.WANTestBase;
 import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * @author skumar
  *
@@ -46,239 +48,75 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
   // to test that when userPR is locally destroyed, shadow Pr is also locally
   // destroyed and on recreation usrePr , shadow Pr is also recreated.
   public void testParallelGatewaySender_SingleNode_UserPR_localDestroy_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      getLogWriter().info("Created PRs on local site");
-
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      createAndStartSender(vm4, lnPort, 5, false, true);
 
-      // since sender is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
-      vm4.invoke(WANTestBase.class, "localDestroyRegion",
-          new Object[] { testName + "_PR" });
+      vm4.invoke(() -> localDestroyRegion(testName + "_PR"));
 
-      // since shodowPR is locally destroyed, so no data to dispatch
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
-
-      vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      recreatePRDoPutsAndValidateRegionSizes(0, true);
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
   
   public void testParallelGatewaySender_SingleNode_UserPR_Destroy_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
+      createAndStartSender(vm4, lnPort, 4, false, true);
 
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 4, OrderPolicy.KEY });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
+      vm4.invoke(() -> resumeSender("ln"));
 
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
+      vm4.invoke(() -> validateParallelSenderQueueAllBucketsDrained("ln"));
 
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      getLogWriter().info("Created PRs on local site");
+      vm4.invoke(() -> localDestroyRegion(testName + "_PR"));
 
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-
-      // since resume is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
-
-      vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+      recreatePRDoPutsAndValidateRegionSizes(10, false);
+    } finally {
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+    }
+  }
 
-      vm4.invoke(WANTestBase.class, "destroyRegion", new Object[] { testName
-          + "_PR" });
+  public void testParallelGatewaySender_SingleNode_UserPR_Close_RecreateRegion() throws Exception {
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
-      // before destoy, there is wait for queue to drain, so data will be
-      // dispatched
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+    createAndStartSender(vm4, lnPort, 7, false, true);
 
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
+    createReceiverAndDoPutsInPausedSender(nyPort);
 
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
+    vm4.invoke(() -> closeRegion(testName + "_PR"));
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+    vm4.invoke(() -> resumeSender("ln"));
 
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 20 });
-    } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-        "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-    }
-  }
-  
-  
-  public void testParallelGatewaySender_SingleNode_UserPR_Close_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
+    pause(500); //paused if there is any element which is received on remote site
 
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    recreatePRDoPutsAndValidateRegionSizes(0, false);
 
-    vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class, "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME", new Object[] { lnPort });
-    
-    getLogWriter().info("Created cache on local site");
-    
-    getLogWriter().info("Created senders on local site");
-    
-    vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] { "ln", 2,
-      true, 100, 10, false, false, null, false, 7, OrderPolicy.KEY });
-  
-    vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-    
-    vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-    
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-      testName + "_PR", "ln", 1, 10, isOffHeap()});
-    
-    getLogWriter().info("Created PRs on local site");
-    
-    vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-        testName + "_PR", null, 1, 10, isOffHeap() });
-   
-    vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR", 10 });
-    
-    vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_PR", 10 });
-    
-    //since resume is paused, no dispatching
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_PR", 0 });
-    
-    vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class, "closeRegion", new Object[] { testName + "_PR" });
-    
-    vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-    
-    pause(500); //paused if there is any element which is received on remote site
-    
-    //before close, there is wait for queue to drain, so data will be dispatched
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_PR", 0 });
-    
-    vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-      testName + "_PR", "ln", 1, 10, isOffHeap() });
-    
-    vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] { testName + "_PR", 10, 20 });
-    
-    vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_PR", 10 });
-    
-    vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-      testName + "_PR", 10 });
-    
-    vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-        "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+    vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
   }
   
   //to test that while localDestroy is in progress, put operation does not successed
   public void testParallelGatewaySender_SingleNode_UserPR_localDestroy_SimultenuousPut_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      getLogWriter().info("Created cache on local site");
+      createAndStartSender(vm4, lnPort, 5, false, true);
 
-      getLogWriter().info("Created senders on local site");
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      getLogWriter().info("Created PRs on local site");
-
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-
-      // since resume is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
       AsyncInvocation putAsync = vm4.invokeAsync(WANTestBase.class,
           "doPutsFrom", new Object[] { testName + "_PR", 100, 2000 });
@@ -302,73 +140,30 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
             putAsync.getException());
       }
 
-      vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+      vm4.invoke(() -> resumeSender("ln"));
 
       pause(500); // paused if there is any element which is received on remote
                   // site
 
-      // since shodowPR is locally destroyed, so no data to dispatch
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      recreatePRDoPutsAndValidateRegionSizes(0, false);
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
   
   public void testParallelGatewaySender_SingleNode_UserPR_Destroy_SimultenuousPut_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 6, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-      vm4.invoke(WANTestBase.class, "addCacheListenerAndDestroyRegion", new Object[] {
-        testName + "_PR"});
-      
-      getLogWriter().info("Created PRs on local site");
-
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
+      createAndStartSender(vm4, lnPort, 6, false, true);
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      vm4.invoke(() -> addCacheListenerAndDestroyRegion(testName + "_PR"));
 
-      // since resume is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
-      vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
+      vm4.invoke(() -> resumeSender("ln"));
 
       AsyncInvocation putAsync = vm4.invokeAsync(WANTestBase.class,
           "doPutsFrom", new Object[] { testName + "_PR", 10, 101 });
@@ -387,27 +182,18 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
 
       // before destroy, there is wait for queue to drain, so data will be
       // dispatched
-      vm2.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "validateRegionSizeWithinRange", new Object[] { testName + "_PR", 10,
-              101 }); // possible size is more than 10
+      vm2.invoke(() -> validateRegionSizeWithinRange(testName + "_PR", 10, 101)); // possible size is more than 10
 
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
+      vm4.invoke(() -> createPartitionedRegion(testName + "_PR", "ln", 1, 10, isOffHeap()));
 
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
+      vm4.invoke(() -> doPutsFrom(testName + "_PR", 10, 20));
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      vm4.invoke(() -> validateRegionSize(testName + "_PR", 10));
 
-      vm2.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "validateRegionSizeWithinRange", new Object[] { testName + "_PR", 20,
-              101 });// possible size is more than 20
+      vm2.invoke(() -> validateRegionSizeWithinRange(testName + "_PR", 20, 101)); // possible size is more than 20
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
-    
   }
   
   public void testParallelGatewaySender_SingleNode_UserPR_Destroy_NodeDown()
@@ -415,60 +201,16 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
     addExpectedException("Broken pipe");
     addExpectedException("Connection reset");
     addExpectedException("Unexpected IOException");
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm6.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-      vm6.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-      vm6.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-      vm5.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-      vm6.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-      vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-      vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      getLogWriter().info("Created PRs on local site");
-
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10000 });
+      createAndStartSender(vm4, lnPort, 5, false, true);
+      createAndStartSender(vm5, lnPort, 5, false, true);
+      createAndStartSender(vm6, lnPort, 5, false, true);
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10000 });
-
-      // since resume is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
       vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
       vm5.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
@@ -488,60 +230,24 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
         fail("Interrupted the async invocation.");
       }
 
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10000 });// possible size is more than 20
+      vm2.invoke(() -> validateRegionSize(testName + "_PR", 10));
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm6.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm5.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm6.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
 
   }
   
   public void testParallelGatewaySender_SingleNode_UserPR_Close_SimultenuousPut_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      getLogWriter().info("Created cache on local site");
-
-      getLogWriter().info("Created senders on local site");
+      createAndStartSender(vm4, lnPort, 5, false, true);
 
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, false, 5, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "pauseSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      getLogWriter().info("Created PRs on local site");
-
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
-
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-
-      // since resume is paused, no dispatching
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
+      createReceiverAndDoPutsInPausedSender(nyPort);
 
       AsyncInvocation putAsync = vm4.invokeAsync(WANTestBase.class,
           "doPutsFrom", new Object[] { testName + "_PR", 10, 2000 });
@@ -556,140 +262,108 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
         fail("Interrupted the async invocation.");
       }
 
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 0 });
-
-      vm4.invoke(WANTestBase.class, "resumeSender", new Object[] { "ln" });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 10, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
+      recreatePRDoPutsAndValidateRegionSizes(0, true);
+    } finally {
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+    }
+  }
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+  private void createReceiverAndDoPutsInPausedSender(int port) {
+    // Note: This is a test-specific method used by several tests to do puts from vm4 to vm2.
+    String regionName = testName + "_PR";
+    vm2.invoke(() -> createReceiver(port));
+    vm2.invoke(() -> createPartitionedRegion(regionName, null, 1, 10, isOffHeap()));
+    vm4.invoke(() -> doPuts(regionName, 10));
+    vm4.invoke(() -> validateRegionSize(regionName, 10));
+    // since sender is paused, no dispatching
+    vm2.invoke(() -> validateRegionSize(regionName, 0));
+  }
 
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
-    } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+  private void recreatePRDoPutsAndValidateRegionSizes(int expectedRegionSize, boolean resumeSender) {
+    // Note: This is a test-specific method used by several test to recreate a partitioned region,
+    // do puts and validate region sizes in vm2 and vm4.
+    // since shadowPR is locally destroyed, so no data to dispatch
+    String regionName = testName + "_PR";
+    vm2.invoke(() -> validateRegionSize(regionName, expectedRegionSize));
+    if (resumeSender) {
+      vm4.invoke(() -> resumeSender("ln"));
     }
+    vm4.invoke(() -> createPartitionedRegion(regionName, "ln", 1, 10, isOffHeap()));
+    vm4.invoke(() -> doPutsFrom(regionName, 10, 20));
+    validateRegionSizes(regionName, 10, vm4, vm2);
   }
-  
+
   public void testParallelGatewaySenders_SingleNode_UserPR_localDestroy_RecreateRegion() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-    Integer tkPort = (Integer)vm2.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 3, lnPort });
-    Integer pnPort = (Integer)vm3.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 4, lnPort });
-    
-    vm4.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm5.invoke(WANTestBase.class, "createReceiver", new Object[] { tkPort });
-    vm6.invoke(WANTestBase.class, "createReceiver", new Object[] { pnPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
+    Integer tkPort = (Integer)vm2.invoke(() -> createFirstRemoteLocator(3, lnPort));
+    Integer pnPort = (Integer)vm3.invoke(() -> createFirstRemoteLocator(4, lnPort));
+
+    vm4.invoke(() -> createReceiver(nyPort));
+    vm5.invoke(() -> createReceiver(tkPort));
+    vm6.invoke(() -> createReceiver(pnPort));
 
     try {
-      vm7.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
+      vm7.invoke(() -> createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME(lnPort));
 
       getLogWriter().info("Created cache on local site");
 
-      vm7.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln1", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
+      vm7.invoke(() -> createConcurrentSender("ln1", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY));
+      vm7.invoke(() -> createConcurrentSender("ln2", 3, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY));
+      vm7.invoke(() -> createConcurrentSender("ln3", 4, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY));
 
-      vm7.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln2", 3, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
+      vm7.invoke(() -> startSender("ln1"));
+      vm7.invoke(() -> startSender("ln2"));
+      vm7.invoke(() -> startSender("ln3"));
 
-      vm7.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln3", 4, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
+      String regionName = testName + "_PR";
+      vm7.invoke(() -> createPartitionedRegion(regionName, "ln1,ln2,ln3", 1, 10, isOffHeap()));
 
-      vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln1" });
-      vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln2" });
-      vm7.invoke(WANTestBase.class, "startSender", new Object[] { "ln3" });
+      getLogWriter().info("Created PRs on local site");
 
-      vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln1,ln2,ln3", 1, 10, isOffHeap() });
+      vm4.invoke(() -> createPartitionedRegion(regionName, null, 1, 10, isOffHeap()));
+      vm5.invoke(() -> createPartitionedRegion(regionName, null, 1, 10, isOffHeap()));
+      vm6.invoke(() -> createPartitionedRegion(regionName, null, 1, 10, isOffHeap()));
 
-      getLogWriter().info("Created PRs on local site");
+      vm7.invoke(() -> doPuts(regionName, 10));
 
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-      vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
-      vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 10, isOffHeap() });
+      vm7.invoke(() -> validateParallelSenderQueueAllBucketsDrained("ln1"));
+      vm7.invoke(() -> validateParallelSenderQueueAllBucketsDrained("ln2"));
+      vm7.invoke(() -> validateParallelSenderQueueAllBucketsDrained("ln3"));
 
-      vm7.invoke(WANTestBase.class, "doPuts", new Object[] { testName + "_PR",
-          10 });
-      pause(1000);
-      vm7.invoke(WANTestBase.class, "localDestroyRegion",
-          new Object[] { testName + "_PR" });
+      vm7.invoke(() -> localDestroyRegion(regionName));
 
-      vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln1,ln2,ln3", 1, 10, isOffHeap() });
+      vm7.invoke(() -> createPartitionedRegion(regionName, "ln1,ln2,ln3", 1, 10, isOffHeap()));
 
-      vm7.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 10, 20 });
+      vm7.invoke(() -> doPutsFrom(regionName, 10, 20));
 
-      vm7.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 10 });
+      vm7.invoke(() -> validateRegionSize(regionName, 10));
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 20 });
-      vm5.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 20 });
-      vm6.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 20 });
+      validateRegionSizes(regionName, 20, vm4, vm5, vm6);
     } finally {
-      vm7.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm7.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
   
   public void testParallelGatewaySender_MultipleNode_UserPR_localDestroy_Recreate() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+    vm2.invoke(() -> createReceiver(nyPort));
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 100, isOffHeap() });
-      vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 100, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-
-      getLogWriter().info("Created PRs on local site");
+      createAndStartSender(vm4, lnPort, 5, true, false);
+      createAndStartSender(vm5, lnPort, 5, true, false);
 
-      vm2.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 100, isOffHeap() });
+      String regionName = testName + "_PR";
+      vm2.invoke(() -> createPartitionedRegion(regionName, null, 1, 10, isOffHeap()));
 
       AsyncInvocation inv1 = vm4.invokeAsync(WANTestBase.class, "doPuts",
-          new Object[] { testName + "_PR", 1000 });
+          new Object[] { regionName, 10 });
       pause(1000);
-      vm5.invoke(WANTestBase.class, "localDestroyRegion",
-          new Object[] { testName + "_PR" });
+      vm5.invoke(() -> localDestroyRegion(regionName));
 
       try {
         inv1.join();
@@ -698,79 +372,45 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
         fail("Interrupted the async invocation.");
       }
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 1000 });
-
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 1000 });
 
-      vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln", 1, 100, isOffHeap() });
+      validateRegionSizes(regionName, 10, vm4, vm2);
 
-      vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 1000, 2000 });
+      vm5.invoke(() -> createPartitionedRegion(regionName, "ln", 1, 10, isOffHeap()));
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 2000 });
+      vm4.invoke(() -> doPutsFrom(regionName, 10, 20));
 
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 2000 });
+      validateRegionSizes(regionName, 20, vm4, vm2);
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm5.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
   
   public void testParallelGatewaySenders_MultiplNode_UserPR_localDestroy_Recreate() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
-    Integer tkPort = (Integer)vm2.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 3, lnPort });
-    
-    vm6.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
-    vm7.invoke(WANTestBase.class, "createReceiver", new Object[] { tkPort });
-    
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
+    Integer tkPort = (Integer)vm2.invoke(() -> createFirstRemoteLocator(3, lnPort));
+
+    vm6.invoke(() -> createReceiver(nyPort));
+    vm7.invoke(() -> createReceiver(tkPort));
+
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln1,ln2", 1, 100, isOffHeap() });
-      vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln1,ln2", 1, 100, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln1", 2, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY });
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln2", 3, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln1", 2, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln2", 3, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln1" });
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln2" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln1" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln2" });
+      createAndStartTwoSenders(vm4, lnPort);
+      createAndStartTwoSenders(vm5, lnPort);
 
+      String regionName = testName + "_PR";
       vm6.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 100, isOffHeap() });
+          regionName, null, 1, 100, isOffHeap() });
       vm7.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", null, 1, 100, isOffHeap() });
+          regionName, null, 1, 100, isOffHeap() });
 
       AsyncInvocation inv1 = vm4.invokeAsync(WANTestBase.class, "doPuts",
-          new Object[] { testName + "_PR", 1000 });
+          new Object[] { regionName, 10 });
+
       pause(1000);
       vm5.invoke(WANTestBase.class, "localDestroyRegion",
-          new Object[] { testName + "_PR" });
+          new Object[] { regionName });
 
       try {
         inv1.join();
@@ -779,79 +419,52 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
         fail("Interrupted the async invocation.");
       }
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 1000 });
-
-      vm6.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 1000 });
-      vm7.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 1000 });
+      validateRegionSizes(regionName, 10, vm4, vm6, vm7);
 
       vm5.invoke(WANTestBase.class, "createPartitionedRegion", new Object[] {
-          testName + "_PR", "ln1,ln2", 1, 100, isOffHeap() });
+          regionName, "ln1,ln2", 1, 100, isOffHeap() });
 
       vm4.invoke(WANTestBase.class, "doPutsFrom", new Object[] {
-          testName + "_PR", 1000, 2000 });
+          regionName, 10, 20 });
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 2000 });
-
-      vm6.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 2000 });
-      vm7.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          testName + "_PR", 2000 });
+      validateRegionSizes(regionName, 20, vm4, vm6, vm7);
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm5.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
-  
-  public void testParallelGatewaySender_ColocatedPartitionedRegions_localDestroy() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
 
-    vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
+  private void createAndStartTwoSenders(VM vm, int port) {
+    // Note: This is a test-specific method used to create and start 2 senders.
+    vm.invoke(() -> createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME(port));
+    vm.invoke(() -> createPartitionedRegion(testName + "_PR", "ln1,ln2", 1, 100, isOffHeap()));
+    vm.invoke(() -> createConcurrentSender("ln1", 2, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY));
+    vm.invoke(() -> createConcurrentSender("ln2", 3, true, 100, 10, false, false, null, true, 4, OrderPolicy.KEY));
+    vm.invoke(() -> startSender("ln1"));
+    vm.invoke(() -> startSender("ln2"));
+  }
 
-    try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class,
-          "createCustomerOrderShipmentPartitionedRegion", new Object[] { null,
-              "ln", 1, 100, isOffHeap() });
-      vm5.invoke(WANTestBase.class,
-          "createCustomerOrderShipmentPartitionedRegion", new Object[] { null,
-              "ln", 1, 100, isOffHeap() });
+  public void testParallelGatewaySender_ColocatedPartitionedRegions_localDestroy() throws Exception {
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 5, OrderPolicy.KEY });
+    vm2.invoke(() -> createReceiver(nyPort));
 
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
+    try {
+      createAndStartSenderWithCustomerOrderShipmentRegion(vm4, lnPort, 5, true);
+      createAndStartSenderWithCustomerOrderShipmentRegion(vm5, lnPort, 5, true);
 
       getLogWriter().info("Created PRs on local site");
 
-      vm2.invoke(WANTestBase.class,
-          "createCustomerOrderShipmentPartitionedRegion", new Object[] { null,
-              null, 1, 100, isOffHeap() });
+      vm2.invoke(() -> createCustomerOrderShipmentPartitionedRegion(null, null, 1, 100, isOffHeap()));
 
       AsyncInvocation inv1 = vm4.invokeAsync(WANTestBase.class,
-          "putcolocatedPartitionedRegion", new Object[] { 2000 });
+          "putcolocatedPartitionedRegion", new Object[] { 10 });
       pause(1000);
 
       try {
-        vm5.invoke(WANTestBase.class, "localDestroyRegion",
-            new Object[] { customerRegionName });
+        vm5.invoke(() -> localDestroyRegion(customerRegionName));
       } catch (Exception ex) {
         assertTrue(ex.getCause() instanceof UnsupportedOperationException);
       }
@@ -862,51 +475,29 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
         fail("Unexpected exception", e);
       }
 
-      vm4.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          customerRegionName, 2000 });
-      vm5.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          customerRegionName, 2000 });
-      vm2.invoke(WANTestBase.class, "validateRegionSize", new Object[] {
-          customerRegionName, 2000 });
+      validateRegionSizes(customerRegionName, 10, vm4, vm5, vm2);
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm5.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
-    
   }
-  
+
+  private void validateRegionSizes(String regionName, int expectedRegionSize, VM... vms) {
+    for (VM vm : vms) {
+      vm.invoke(() -> validateRegionSize(regionName, expectedRegionSize));
+    }
+  }
+
   public void testParallelGatewaySender_ColocatedPartitionedRegions_destroy() throws Exception {
-    Integer lnPort = (Integer)vm0.invoke(WANTestBase.class,
-        "createFirstLocatorWithDSId", new Object[] { 1 });
-    Integer nyPort = (Integer)vm1.invoke(WANTestBase.class,
-        "createFirstRemoteLocator", new Object[] { 2, lnPort });
+    Integer[] locatorPorts = createLNAndNYLocators();
+    Integer lnPort = locatorPorts[0];
+    Integer nyPort = locatorPorts[1];
 
     vm2.invoke(WANTestBase.class, "createReceiver", new Object[] { nyPort });
 
     try {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME",
-          new Object[] { lnPort });
-
-      vm4.invoke(WANTestBase.class,
-          "createCustomerOrderShipmentPartitionedRegion", new Object[] { null,
-              "ln", 1, 100, isOffHeap() });
-      vm5.invoke(WANTestBase.class,
-          "createCustomerOrderShipmentPartitionedRegion", new Object[] { null,
-              "ln", 1, 100, isOffHeap() });
-
-      vm4.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 6, OrderPolicy.KEY });
-      vm5.invoke(WANTestBase.class, "createConcurrentSender", new Object[] {
-          "ln", 2, true, 100, 10, false, false, null, true, 6, OrderPolicy.KEY });
-
-      vm4.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
-      vm5.invoke(WANTestBase.class, "startSender", new Object[] { "ln" });
+      createAndStartSenderWithCustomerOrderShipmentRegion(vm4, lnPort, 6, true);
+      createAndStartSenderWithCustomerOrderShipmentRegion(vm5, lnPort, 6, true);
 
       getLogWriter().info("Created PRs on local site");
 
@@ -927,13 +518,29 @@ public class ConcurrentParallelGatewaySenderOperation_2_DUnitTest extends WANTes
       }
       fail("Excpeted UnsupportedOperationException");
     } finally {
-      vm4.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
-      vm5.invoke(ConcurrentParallelGatewaySenderOperation_2_DUnitTest.class,
-          "clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME");
+      vm4.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
+      vm5.invoke(() -> clear_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME());
     }
   }
-  
+
+  private void createAndStartSenderWithCustomerOrderShipmentRegion(VM vm, int port, int concurrencyLevel, boolean manualStart) {
+    vm.invoke(() -> createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME(port));
+    vm.invoke(() -> createCustomerOrderShipmentPartitionedRegion(null, "ln", 1, 100, isOffHeap()));
+    vm.invoke(() -> createConcurrentSender("ln", 2, true, 100, 10, false, false, null, manualStart, concurrencyLevel, OrderPolicy.KEY));
+    vm.invoke(() -> startSender("ln"));
+  }
+
+  private void createAndStartSender(VM vm, int port, int concurrencyLevel, boolean manualStart, boolean pause) {
+    vm.invoke(() -> createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME(port));
+    vm.invoke(() -> createConcurrentSender("ln", 2, true, 100, 10, false, false, null, manualStart, concurrencyLevel, OrderPolicy.KEY));
+    vm.invoke(() -> startSender("ln"));
+    if (pause) {
+      vm.invoke(() -> pauseSender("ln"));
+    }
+    vm.invoke(() -> createPartitionedRegion(testName + "_PR", "ln", 1, 10, isOffHeap()));
+    getLogWriter().info("Created PRs on local site");
+  }
+
   public static void createCache_INFINITE_MAXIMUM_SHUTDOWN_WAIT_TIME(
       Integer locPort) {
     createCache(false, locPort);


[07/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationOneDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationOneDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationOneDUnitTest.java
index a2e42d1..b9e8ebe 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationOneDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperationOneDUnitTest.java
@@ -20,21 +20,35 @@
 //
 package com.gemstone.gemfire.internal.cache.partitioned;
 
-import java.util.*;
-import java.io.*;
-import dunit.*;
-
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
+
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.cache30.*;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.PartitionAttributes;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
+import com.gemstone.gemfire.cache30.CacheTestCase;
+import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.ReplyException;
+import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.Token;
-
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class StreamingPartitionOperationOneDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningDUnitTest.java
index 887cacf..30063d4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningDUnitTest.java
@@ -23,10 +23,9 @@ import com.gemstone.gemfire.cache.DuplicatePrimaryPartitionException;
 import com.gemstone.gemfire.cache.EntryNotFoundException;
 import com.gemstone.gemfire.cache.FixedPartitionAttributes;
 import com.gemstone.gemfire.cache.partition.PartitionNotAvailableException;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase.ExpectedException;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.ExpectedException;
 
 /**
  * This Dunit test class have multiple tests to tests different validations of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningTestBase.java
index ddc83ea..f48ab61 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningTestBase.java
@@ -71,11 +71,10 @@ import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionObserver
 import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionObserverHolder;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * This is the base class to do operations

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningWithColocationAndPersistenceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningWithColocationAndPersistenceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningWithColocationAndPersistenceDUnitTest.java
index 741495d..8f2dceb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningWithColocationAndPersistenceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/fixed/FixedPartitioningWithColocationAndPersistenceDUnitTest.java
@@ -20,9 +20,8 @@ import java.util.ArrayList;
 import java.util.List;
 
 import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
 
 public class FixedPartitioningWithColocationAndPersistenceDUnitTest extends
     FixedPartitioningTestBase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
index 08a4a56..ed0b6dc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRVVRecoveryDUnitTest.java
@@ -65,12 +65,11 @@ import com.gemstone.gemfire.internal.cache.Token.Tombstone;
 import com.gemstone.gemfire.internal.cache.TombstoneService;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PersistentRVVRecoveryDUnitTest extends PersistentReplicatedTestBase {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderDUnitTest.java
index ccd2660..cd6118a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderDUnitTest.java
@@ -70,12 +70,11 @@ import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.TXManagerImpl;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionHolder;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is a test of how persistent distributed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderOldConfigDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderOldConfigDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderOldConfigDUnitTest.java
index 76bc685..20624fc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderOldConfigDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentRecoveryOrderOldConfigDUnitTest.java
@@ -25,10 +25,9 @@ import com.gemstone.gemfire.cache.DiskStoreFactory;
 import com.gemstone.gemfire.cache.DiskWriteAttributesFactory;
 import com.gemstone.gemfire.cache.RegionFactory;
 import com.gemstone.gemfire.cache.Scope;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentReplicatedTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentReplicatedTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentReplicatedTestBase.java
index d2fea0e..ff82082 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentReplicatedTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/persistence/PersistentReplicatedTestBase.java
@@ -36,10 +36,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
 import com.gemstone.gemfire.internal.cache.RegionFactoryImpl;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public abstract class PersistentReplicatedTestBase extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/Bug40396DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/Bug40396DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/Bug40396DUnitTest.java
index 8752879..ed85295 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/Bug40396DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/Bug40396DUnitTest.java
@@ -30,11 +30,10 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.tier.sockets.DeltaEOFException;
 import com.gemstone.gemfire.internal.cache.tier.sockets.FaultyDelta;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 /**
  * Test delta propagation for faulty delta implementation
  * @author aingle

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/BackwardCompatibilityHigherVersionClientDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/BackwardCompatibilityHigherVersionClientDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/BackwardCompatibilityHigherVersionClientDUnitTest.java
index 5ce7fba..27240e5 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/BackwardCompatibilityHigherVersionClientDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/BackwardCompatibilityHigherVersionClientDUnitTest.java
@@ -30,14 +30,13 @@ 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.tier.ConnectionProxy;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.client.internal.ConnectionFactoryImpl;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * @author Pallavi
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36269DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36269DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36269DUnitTest.java
index 63c86fe..6198ad2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36269DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36269DUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * The Region Destroy Operation from Cache Client does not pass the Client side

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36457DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36457DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36457DUnitTest.java
index 071fd6e..0124e92 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36457DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36457DUnitTest.java
@@ -37,10 +37,9 @@ import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Bug Test for bug#36457

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36805DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36805DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36805DUnitTest.java
index f0315e8..fa1bed1 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36805DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36805DUnitTest.java
@@ -34,10 +34,9 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * bug test for bug 36805

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36829DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36829DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36829DUnitTest.java
index 0a543f7..74139bb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36829DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36829DUnitTest.java
@@ -27,10 +27,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.cache.RegionDestroyedException;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class Bug36829DUnitTest extends DistributedTestCase {
   private VM serverVM;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36995DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36995DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36995DUnitTest.java
index b4f50e8..3eb924e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36995DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug36995DUnitTest.java
@@ -27,13 +27,12 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 public class Bug36995DUnitTest extends DistributedTestCase
 {
   private static Cache cache = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37210DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37210DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37210DUnitTest.java
index 69f4142..3a9ab10 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37210DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37210DUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This tests the fix for bug 73210. Reason for the bug was that HARegionQueue's
  * destroy was not being called on CacheClientProxy's closure. As a result,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37805DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37805DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37805DUnitTest.java
index c8b7aa8..24674fe 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37805DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/Bug37805DUnitTest.java
@@ -28,10 +28,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.HARegion;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerMaxConnectionsJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerMaxConnectionsJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerMaxConnectionsJUnitTest.java
index 2b61f99..2921554 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerMaxConnectionsJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerMaxConnectionsJUnitTest.java
@@ -39,11 +39,10 @@ import com.gemstone.gemfire.cache.client.internal.Connection;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Make sure max-connections on cache server is enforced
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTestUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTestUtil.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTestUtil.java
index 123a275..1f47d72 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTestUtil.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTestUtil.java
@@ -50,8 +50,7 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl.PoolAttributes;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 /**
  *
  * @author Yogesh Mahajan

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
index f8281e4..fa38741 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheServerTransactionsDUnitTest.java
@@ -36,10 +36,9 @@ import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests behaviour of transactions in client server model

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClearPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClearPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClearPropagationDUnitTest.java
index 00828dd..79dd760 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClearPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClearPropagationDUnitTest.java
@@ -36,15 +36,14 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
 import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
 import com.gemstone.gemfire.internal.cache.EventID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
 import com.gemstone.gemfire.cache.client.internal.Connection;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This is the DUnit Test to verify clear and DestroyRegion operation in
  * Client-Server Configuration.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientConflationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientConflationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientConflationDUnitTest.java
index 5773507..3673228 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientConflationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientConflationDUnitTest.java
@@ -39,12 +39,11 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This test verifies the per-client queue conflation override functionality
  * Taken from the existing ConflationDUnitTest.java and modified.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientHealthMonitorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientHealthMonitorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientHealthMonitorJUnitTest.java
index 4dd271f..cdfda98 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientHealthMonitorJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientHealthMonitorJUnitTest.java
@@ -41,11 +41,10 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EventID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * This is a functional-test for <code>ClientHealthMonitor</code>.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientInterestNotifyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientInterestNotifyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientInterestNotifyDUnitTest.java
index 2c9c5a1..2153746 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientInterestNotifyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientInterestNotifyDUnitTest.java
@@ -39,10 +39,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test verifies the per-client notify-by-subscription (NBS) override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientServerMiscDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientServerMiscDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientServerMiscDUnitTest.java
index 761fe06..8d3b9ab 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientServerMiscDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ClientServerMiscDUnitTest.java
@@ -41,12 +41,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 java.util.Iterator;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConflationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConflationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConflationDUnitTest.java
index 366c3a1..fe5d03f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConflationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConflationDUnitTest.java
@@ -40,13 +40,12 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.HARegion;
 import com.gemstone.gemfire.internal.cache.ha.HAHelper;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This test verifies the conflation functionality of the
  * dispatcher.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
index 3c23e5d..ae73ed4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ConnectionProxyJUnitTest.java
@@ -54,11 +54,10 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * @author asif
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DataSerializerPropogationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DataSerializerPropogationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DataSerializerPropogationDUnitTest.java
index 9b530eb..85bed81 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DataSerializerPropogationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DataSerializerPropogationDUnitTest.java
@@ -47,10 +47,9 @@ import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DataSerializerPropogationDUnitTest extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DestroyEntryPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DestroyEntryPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DestroyEntryPropagationDUnitTest.java
index c6fd271..55bd889 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DestroyEntryPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DestroyEntryPropagationDUnitTest.java
@@ -38,6 +38,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.cache30.CertifiableTestCacheListener;
 import com.gemstone.gemfire.cache.client.*;
@@ -46,10 +49,6 @@ import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
 import com.gemstone.gemfire.cache.client.internal.Connection;
 import com.gemstone.gemfire.cache.server.CacheServer;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Tests propagation of destroy entry operation across the vms
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientBug39997DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientBug39997DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientBug39997DUnitTest.java
index 93ea3bf..d40563b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientBug39997DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientBug39997DUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DurableClientBug39997DUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
index 9b86cbc..3e23ab5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientQueueSizeDUnitTest.java
@@ -34,10 +34,9 @@ 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.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author ashetkar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectAutoDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectAutoDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectAutoDUnitTest.java
index 16e9cd7..5e015ea 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectAutoDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectAutoDUnitTest.java
@@ -18,9 +18,8 @@ package com.gemstone.gemfire.internal.cache.tier.sockets;
 
 import com.gemstone.gemfire.cache.client.PoolFactory;
 import com.gemstone.gemfire.cache.client.PoolManager;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectDUnitTest.java
index e5420e4..309f44a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientReconnectDUnitTest.java
@@ -43,10 +43,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 /**      

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientStatsDUnitTest.java
index 09fc134..08eaa9d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableClientStatsDUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableRegistrationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableRegistrationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableRegistrationDUnitTest.java
index 94f697d..f2ef6d1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableRegistrationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableRegistrationDUnitTest.java
@@ -39,10 +39,9 @@ import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.query.data.Portfolio;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableResponseMatrixDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableResponseMatrixDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableResponseMatrixDUnitTest.java
index 308c490..bbbdf80 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableResponseMatrixDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/DurableResponseMatrixDUnitTest.java
@@ -24,14 +24,13 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * 
  * Tests that the Matris defined in <code>ServerResponseMatrix</code> is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationDUnitTest.java
index b975cee..6cb897e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationDUnitTest.java
@@ -42,10 +42,9 @@ import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.RegionEventImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to verify EventID generated from Cache Client is correctly passed on to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
index a9b1468..4e8b82d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/EventIDVerificationInP2PDUnitTest.java
@@ -31,10 +31,9 @@ import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.InternalCacheEvent;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to verify EventID generated from a peer is correctly passed on to the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateEvictionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateEvictionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateEvictionDUnitTest.java
index 02cef5e..3d89089 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateEvictionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateEvictionDUnitTest.java
@@ -43,10 +43,9 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CachedDeserializable;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.Token;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author dsmith

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateOffHeapEvictionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateOffHeapEvictionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateOffHeapEvictionDUnitTest.java
index 51d35d9..7a441c6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateOffHeapEvictionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ForceInvalidateOffHeapEvictionDUnitTest.java
@@ -20,8 +20,7 @@ import java.util.Properties;
 
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Runs force invalidate eviction tests with off-heap regions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HABug36738DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HABug36738DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HABug36738DUnitTest.java
index 0a250b3..395047a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HABug36738DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HABug36738DUnitTest.java
@@ -37,10 +37,9 @@ import com.gemstone.gemfire.internal.cache.ha.HAHelper;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessage;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This is the bugtest for bug no. 36738. When Object of class

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart1DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart1DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart1DUnitTest.java
index 27779a6..e82faae 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart1DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart1DUnitTest.java
@@ -16,7 +16,7 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings("serial")
 public class HAInterestPart1DUnitTest extends HAInterestTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart2DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart2DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart2DUnitTest.java
index 31a2811..28bee9f 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart2DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestPart2DUnitTest.java
@@ -19,9 +19,8 @@ package com.gemstone.gemfire.internal.cache.tier.sockets;
 import com.gemstone.gemfire.cache.EntryDestroyedException;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-
-import dunit.DistributedTestCase;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.VM;
 
 @SuppressWarnings({"rawtypes", "serial"})
 public class HAInterestPart2DUnitTest extends HAInterestTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestTestCase.java
index 481863c..a80b21c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAInterestTestCase.java
@@ -39,12 +39,11 @@ import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.tier.InterestType;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAStartupAndFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAStartupAndFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAStartupAndFailoverDUnitTest.java
index 9a00680..54ef4c0 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAStartupAndFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/HAStartupAndFailoverDUnitTest.java
@@ -38,12 +38,11 @@ import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Test to verify Startup. and failover during startup.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
index 72bbdbd..17ef1cc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InstantiatorPropagationDUnitTest.java
@@ -45,10 +45,9 @@ import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class InstantiatorPropagationDUnitTest extends DistributedTestCase {
   private static Cache cache = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListDUnitTest.java
index 485783e..8bc4e42 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListDUnitTest.java
@@ -47,14 +47,13 @@ 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.CacheServerImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.cache.client.*;
 import com.gemstone.gemfire.cache.NoSubscriptionServersAvailableException;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * Test Scenario :
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
index 4a6e096..1faa051 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
@@ -44,11 +44,10 @@ 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.CacheServerImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListFailoverDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListFailoverDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListFailoverDUnitTest.java
index 2c7d6a4..1b0ecb1 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListFailoverDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListFailoverDUnitTest.java
@@ -25,12 +25,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.PoolFactoryImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Test Scenario :
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
index 9f2d527..5359cb8 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestListRecoveryDUnitTest.java
@@ -39,12 +39,12 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.cache.client.internal.RegisterInterestTracker;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
index 8cba3f8..090577b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestRegrListenerDUnitTest.java
@@ -38,10 +38,9 @@ import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
 import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Written to test fix for Bug #47132

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestResultPolicyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestResultPolicyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestResultPolicyDUnitTest.java
index f49ca55..5e74812 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestResultPolicyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/InterestResultPolicyDUnitTest.java
@@ -33,12 +33,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * DUnit Test for use-cases of various {@link InterestResultPolicy} types.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
index 455aef1..0896c5a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/NewRegionAttributesDUnitTest.java
@@ -29,10 +29,9 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This tests that basic entry operations work properly when regions are

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
index e697414..879d878 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart1DUnitTest.java
@@ -16,8 +16,8 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
 
 /**
  * Tests Redundancy Level Functionality

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart2DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart2DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart2DUnitTest.java
index 3545246..1c83206 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart2DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart2DUnitTest.java
@@ -16,8 +16,8 @@
  */
 package com.gemstone.gemfire.internal.cache.tier.sockets;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
 
 public class RedundancyLevelPart2DUnitTest extends RedundancyLevelTestBase
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
index 0371cdc..c1266e7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
@@ -18,11 +18,10 @@ package com.gemstone.gemfire.internal.cache.tier.sockets;
 
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-
 /**
  * Tests Redundancy Level Functionality
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelTestBase.java
index 607b15d..7f95f8b 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RedundancyLevelTestBase.java
@@ -40,12 +40,11 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.ClientServerObserver;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverAdapter;
 import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Tests Redundancy Level Functionality
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegionCloseDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegionCloseDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegionCloseDUnitTest.java
index 9561bd5..88b684c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegionCloseDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegionCloseDUnitTest.java
@@ -32,12 +32,11 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Test to verify that client side region.close() should unregister the client with the server.
  * It also checks that client region queue also gets removed properly.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestBeforeRegionCreationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestBeforeRegionCreationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestBeforeRegionCreationDUnitTest.java
index 0481ef3..6d71b43 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestBeforeRegionCreationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestBeforeRegionCreationDUnitTest.java
@@ -31,14 +31,13 @@ import com.gemstone.gemfire.cache30.CacheSerializableRunnable;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.CacheServerImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.internal.cache.CacheObserverAdapter;
 import com.gemstone.gemfire.internal.cache.CacheObserverHolder;
 import com.gemstone.gemfire.cache.client.*;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * This test tests the scenario whereby a register interest has been called before
  * the region has been created. After that if a region is created and the new region

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestKeysDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestKeysDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestKeysDUnitTest.java
index 42863a3..691f98d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestKeysDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/RegisterInterestKeysDUnitTest.java
@@ -23,12 +23,11 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.AvailablePort;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * Test code copied from UpdatePropagationDUnitTest
  * Tests that registering interest KEYS works correctly.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ReliableMessagingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ReliableMessagingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ReliableMessagingDUnitTest.java
index 48577f1..ffab9b9 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ReliableMessagingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/ReliableMessagingDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
 import com.gemstone.gemfire.internal.cache.ha.HAHelper;
 import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
 import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
index 9b7cefd..c4ebead 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UnregisterInterestDUnitTest.java
@@ -37,10 +37,9 @@ import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.FilterProfile;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author ashetkar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UpdatePropagationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UpdatePropagationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UpdatePropagationDUnitTest.java
index 34ea3a6..c21cbcb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UpdatePropagationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/UpdatePropagationDUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.ServerLocation;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
index aeeffc1..16fb199 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyEventIDGenerationInP2PDUnitTest.java
@@ -30,10 +30,9 @@ import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyUpdatesFromNonInterestEndPointDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyUpdatesFromNonInterestEndPointDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyUpdatesFromNonInterestEndPointDUnitTest.java
index 25c4f90..d1c3da7 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyUpdatesFromNonInterestEndPointDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/tier/sockets/VerifyUpdatesFromNonInterestEndPointDUnitTest.java
@@ -33,15 +33,14 @@ import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.cache.client.*;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.cache.client.internal.Connection;
 import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-
 /**
  * One Client , two servers.
  * Ensure that client 1 has registered interest list on server 2.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/versions/RegionVersionVectorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/versions/RegionVersionVectorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/versions/RegionVersionVectorJUnitTest.java
index 45d74d2..0efea5a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/versions/RegionVersionVectorJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/versions/RegionVersionVectorJUnitTest.java
@@ -35,10 +35,9 @@ import com.gemstone.gemfire.internal.HeapDataOutputStream;
 import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
-import dunit.DistributedTestCase;
-
 @Category(UnitTest.class)
 public class RegionVersionVectorJUnitTest extends TestCase {
 



[24/52] [abbrv] incubator-geode git commit: GEODE-836: multicast state flush is broken

Posted by ds...@apache.org.
GEODE-836: multicast state flush is broken

The Digest from the multicast NAKACK2 protocol is immutable and needs
to be fetched each time it is checked in order to get an up-to-date
digest.  I also added warning and timeout for the method similar to
what's in DistributionAdvisor.waitForCurrentOperations(long) that
guarantee that the wait will terminate.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/ed17d4cd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/ed17d4cd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/ed17d4cd

Branch: refs/heads/feature/GEODE-831
Commit: ed17d4cd50595b5a611b4a4068a1e2b895a06ff6
Parents: 2609946
Author: Bruce Schuchardt <bs...@pivotal.io>
Authored: Tue Jan 26 08:53:40 2016 -0800
Committer: Bruce Schuchardt <bs...@pivotal.io>
Committed: Tue Jan 26 08:56:47 2016 -0800

----------------------------------------------------------------------
 .../gms/messenger/JGroupsMessenger.java         | 35 ++++++++++++++++----
 .../gms/membership/GMSJoinLeaveJUnitTest.java   |  2 +-
 .../messenger/JGroupsMessengerJUnitTest.java    | 26 +++++++++++----
 3 files changed, 48 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed17d4cd/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessenger.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
index ccff687..be2c405 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
@@ -533,16 +533,37 @@ public class JGroupsMessenger implements Messenger {
    */
   protected void waitForMessageState(NAKACK2 nakack, InternalDistributedMember sender, Long seqno)
     throws InterruptedException {
+    long timeout = services.getConfig().getDistributionConfig().getAckWaitThreshold() * 1000L;
+    long startTime = System.currentTimeMillis();
+    long warnTime = startTime + timeout;
+    long quitTime = warnTime + timeout - 1000L;
+    boolean warned = false;
+    
     JGAddress jgSender = new JGAddress(sender);
-    Digest digest = nakack.getDigest(jgSender);
-    if (digest != null) {
-      for (;;) {
-        long[] senderSeqnos = digest.get(jgSender);
-        if (senderSeqnos == null || senderSeqnos[0] >= seqno.longValue()) {
-          break;
+    
+    for (;;) {
+      Digest digest = nakack.getDigest(jgSender);
+      if (digest == null) {
+        return;
+      }
+      String received = "none";
+      long[] senderSeqnos = digest.get(jgSender);
+      if (senderSeqnos == null || senderSeqnos[0] >= seqno.longValue()) {
+        break;
+      }
+      long now = System.currentTimeMillis();
+      if (!warned && now >= warnTime) {
+        warned = true;
+        if (senderSeqnos != null) {
+          received = String.valueOf(senderSeqnos[0]);
         }
-        Thread.sleep(50);
+        logger.warn("{} seconds have elapsed while waiting for multicast messages from {}.  Received {} but expecting at least {}.",
+            Long.toString((warnTime-startTime)/1000L), sender, received, seqno);
+      }
+      if (now >= quitTime) {
+        throw new GemFireIOException("Multicast operations from " + sender + " did not distribute within " + (now - startTime) + " milliseconds");
       }
+      Thread.sleep(50);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed17d4cd/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/membership/GMSJoinLeaveJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/membership/GMSJoinLeaveJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/membership/GMSJoinLeaveJUnitTest.java
index ca699b5..5b53290 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/membership/GMSJoinLeaveJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/membership/GMSJoinLeaveJUnitTest.java
@@ -630,7 +630,7 @@ public class GMSJoinLeaveJUnitTest {
     installViewMessage = new InstallViewMessage(partitionView, credentials, false);
     gmsJoinLeave.processMessage(installViewMessage);
     
-    verify(manager).forceDisconnect(any(String.class));
+    verify(manager).forceDisconnect(isA(String.class));
     verify(manager).quorumLost(crashes, newView);
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed17d4cd/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
index ae55f4f..805dd88 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/internal/membership/gms/messenger/JGroupsMessengerJUnitTest.java
@@ -104,6 +104,7 @@ public class JGroupsMessengerJUnitTest {
     nonDefault.put(DistributionConfig.LOG_FILE_NAME, "");
     nonDefault.put(DistributionConfig.LOG_LEVEL_NAME, "fine");
     nonDefault.put(DistributionConfig.LOCATORS_NAME, "localhost[10344]");
+    nonDefault.put(DistributionConfig.ACK_WAIT_THRESHOLD_NAME, "1");
     DistributionConfigImpl config = new DistributionConfigImpl(nonDefault);
     RemoteTransportConfig tconfig = new RemoteTransportConfig(config,
         DistributionManager.NORMAL_DM_TYPE);
@@ -819,7 +820,7 @@ public class JGroupsMessengerJUnitTest {
   }
   
   @Test
-  public void testWaitForMessageState() throws Exception {
+  public void testWaitForMessageStateSucceeds() throws Exception {
     initMocks(true/*multicast*/);
     NAKACK2 nakack = mock(NAKACK2.class);
     Digest digest = mock(Digest.class);
@@ -834,14 +835,25 @@ public class JGroupsMessengerJUnitTest {
         new long[] {0,0}, new long[] {2, 50}, null);
     messenger.waitForMessageState(nakack, createAddress(1234), Long.valueOf(50));
     verify(digest, times(3)).get(isA(Address.class));
-    
-    // for code coverage let's invoke the other waitForMessageState method
-    Map state = new HashMap();
-    state.put("JGroups.mcastState", Long.valueOf(10L));
-    messenger.waitForMessageState(createAddress(1234), state);
   }
   
-
+  @Test
+  public void testWaitForMessageStateThrowsExceptionIfMessagesMissing() throws Exception {
+    initMocks(true/*multicast*/);
+    NAKACK2 nakack = mock(NAKACK2.class);
+    Digest digest = mock(Digest.class);
+    when(nakack.getDigest(any(Address.class))).thenReturn(digest);
+    when(digest.get(any(Address.class))).thenReturn(
+        new long[] {0,0}, new long[] {2, 50}, new long[] {49, 50});
+    try {
+      // message 50 will never arrive
+      messenger.waitForMessageState(nakack, createAddress(1234), Long.valueOf(50));
+      fail("expected a GemFireIOException to be thrown");
+    } catch (GemFireIOException e) {
+      // pass
+    }
+  }
+  
   @Test
   public void testMulticastTest() throws Exception {
     initMocks(true);


[11/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistAckMapMethodsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistAckMapMethodsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistAckMapMethodsDUnitTest.java
index ddfc657..216cdb8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistAckMapMethodsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistAckMapMethodsDUnitTest.java
@@ -20,25 +20,36 @@
  *
  * Created on August 4, 2005, 12:36 PM
  */
-
 package com.gemstone.gemfire.cache30;
 
+import java.util.HashSet;
+import java.util.Properties;
+import java.util.Set;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheWriter;
+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.RegionDestroyedException;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  *
  * @author  prafulla
  */
-
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-
-import java.util.*;
-
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-//import com.gemstone.gemfire.cache30.*;
-
-
 public class DistAckMapMethodsDUnitTest extends DistributedTestCase{
     static Cache cache;
     static Properties props = new Properties();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckOverflowRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckOverflowRegionCCEOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckOverflowRegionCCEOffHeapDUnitTest.java
index 8d00f34..5971d5c 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckOverflowRegionCCEOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckOverflowRegionCCEOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed Ack Overflow Region with ConcurrencyChecksEnabled and OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
index b17c3c3..aec7c8b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEDUnitTest.java
@@ -35,14 +35,13 @@ import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 import java.io.IOException;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEOffHeapDUnitTest.java
index c2b58be..24c386a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckPersistentRegionCCEOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed Ack Persistent Region with ConcurrencyChecksEnabled and OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
index 9c03700..0ba2e27 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEDUnitTest.java
@@ -60,14 +60,13 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserver;
-import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserverHolder;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserverHolder;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * @author Bruce Schuchardt

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
index 393f28b..4b7e49d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCCEOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed Ack Region with ConcurrencyChecksEnabled and OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
index 09b8669..192a375 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionCompressionDUnitTest.java
@@ -20,8 +20,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
-
-import dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 /**
  * Tests Distributed Ack Region with compression.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
index cf258b4..27da3d6 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionDUnitTest.java
@@ -16,32 +16,18 @@
  */
 package com.gemstone.gemfire.cache30;
 
-//import java.util.*;
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Delta;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.TombstoneService;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.io.IOException;
-import java.io.Serializable;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Map;
 import java.util.Properties;
-import java.util.Random;
-import java.util.Set;
-
-import junit.framework.AssertionFailedError;
 
-import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of a cache {@link Region region}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
index f6378ab..5d7f8f6 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedAckRegionOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed Ack Region with OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
index 517aa17..3728cf6 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedMulticastRegionDUnitTest.java
@@ -35,12 +35,11 @@ import com.gemstone.gemfire.distributed.internal.SharedConfiguration;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class DistributedMulticastRegionDUnitTest extends CacheTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
index 4c77562..c65101e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEDUnitTest.java
@@ -32,12 +32,11 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DistributedNoAckRegionCCEDUnitTest extends
     DistributedNoAckRegionDUnitTest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
index 6134cc4..4d3bb80 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionCCEOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed Ack Region with ConcurrencyChecksEnabled and OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
index a9b3e92..aa39758 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionDUnitTest.java
@@ -16,14 +16,23 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import java.util.*;
+import java.util.Arrays;
+import java.util.Set;
 
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
 import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.StateFlushOperation;
-
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of a cache {@link Region region}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
index a43cf1e..2aa1f1e 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DistributedNoAckRegionOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Distributed NoAck Region with OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
index 41bec18..f8baf5a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/DynamicRegionDUnitTest.java
@@ -16,14 +16,23 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.cache.*;
+import java.io.File;
+import java.util.Properties;
 
+import com.gemstone.gemfire.SystemFailure;
+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.DynamicRegionFactory;
+import com.gemstone.gemfire.cache.EvictionAction;
+import com.gemstone.gemfire.cache.EvictionAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.internal.OSProcess;
-import dunit.*;
-import java.io.*;
-import java.util.*;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to make sure dynamic regions work

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
index 9c5df7d..c6b5a05 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalLockingDUnitTest.java
@@ -16,9 +16,20 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
 import java.util.concurrent.locks.Lock;
-import dunit.*;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionExistsException;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TimeoutException;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests distributed locking of global region entries.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
index 0081fed..22b303f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEDUnitTest.java
@@ -36,10 +36,9 @@ import com.gemstone.gemfire.internal.cache.RegionClearedException;
 import com.gemstone.gemfire.internal.cache.RegionEntry;
 import com.gemstone.gemfire.internal.cache.TombstoneService;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test is only for GLOBAL REPLICATE Regions. Tests are

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
index 9f22542..8579548 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionCCEOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Global Region with ConcurrencyChecksEnabled and OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
index 923673e..f08b66f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionDUnitTest.java
@@ -16,15 +16,26 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import java.util.*;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
+import java.util.Random;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.locks.Lock;
-import dunit.*;
-//import junit.framework.Test;
-//import junit.framework.TestSuite;
+
+import com.gemstone.gemfire.SystemFailure;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TimeoutException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of a cache {@link Region region}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
index ef5a4a6..4af6072 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/GlobalRegionOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Global Region with OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
index 2f41bb0..df02539 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LRUEvictionControllerDUnitTest.java
@@ -45,9 +45,8 @@ import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
 import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the basic functionality of the lru eviction 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
index e76497e..0ea842d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/LocalRegionDUnitTest.java
@@ -16,16 +16,21 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.distributed.DistributedSystem;
-//import com.gemstone.gemfire.internal.cache.LocalRegion;
-//import dunit.*;
-//import java.util.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheWriterException;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TimeoutException;
 
 /**
  * Tests the functionality of a {@link Scope#LOCAL locally scoped}
  * cache {@link Region} including its callbacks.  Note that even
- * though this test is a {@link dunit.DistributedTestCase}, it does
+ * though this test is a {@link com.gemstone.gemfire.test.dunit.DistributedTestCase}, it does
  * not perform any distribution.
  *
  * @author David Whitlock

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
index ce9cfbf..2bb172e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
@@ -112,15 +112,14 @@ import com.gemstone.gemfire.internal.cache.versions.VersionTag;
 import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.internal.offheap.MemoryChunkWithRefCount;
 import com.gemstone.gemfire.internal.offheap.SimpleMemoryAllocatorImpl;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+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.DistributedTestCase.WaitCriterion;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/OffHeapLRUEvictionControllerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/OffHeapLRUEvictionControllerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/OffHeapLRUEvictionControllerDUnitTest.java
index 8d1407c..8f3573b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/OffHeapLRUEvictionControllerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/OffHeapLRUEvictionControllerDUnitTest.java
@@ -23,8 +23,7 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
 import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests the basic functionality of the lru eviction 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PRBucketSynchronizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PRBucketSynchronizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PRBucketSynchronizationDUnitTest.java
index f020d93..c81a55f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PRBucketSynchronizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PRBucketSynchronizationDUnitTest.java
@@ -40,10 +40,9 @@ import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
 import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
 import com.gemstone.gemfire.internal.cache.versions.VersionSource;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * concurrency-control tests for client/server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionDUnitTest.java
index fe8f7c7..234203f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionDUnitTest.java
@@ -23,14 +23,28 @@ import java.util.Random;
 import java.util.Set;
 
 import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.EntryExistsException;
+import com.gemstone.gemfire.cache.InterestPolicy;
+import com.gemstone.gemfire.cache.PartitionAttributes;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionFactory;
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.SubscriptionAttributes;
 import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.internal.cache.PartitionedRegionException;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.PureLogWriter;
-
-import dunit.*;
+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;
 
 /**
  * This class tests the functionality of a cache {@link Region region}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionMembershipListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionMembershipListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionMembershipListenerDUnitTest.java
index 0409e91..a1e480a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionMembershipListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionMembershipListenerDUnitTest.java
@@ -31,8 +31,7 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.cache30.RegionMembershipListenerDUnitTest.MyRML;
 import com.gemstone.gemfire.distributed.DistributedMember;
-
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author Mitch Thomas

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionOffHeapDUnitTest.java
index f8ee594..455cefc 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PartitionedRegionOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.cache.AttributesFactory;
 import com.gemstone.gemfire.cache.RegionAttributes;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests Partitioned Region with OffHeap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PreloadedRegionTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PreloadedRegionTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PreloadedRegionTestCase.java
index 0ff4c02..97bae11 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PreloadedRegionTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PreloadedRegionTestCase.java
@@ -16,11 +16,15 @@
  */
 package com.gemstone.gemfire.cache30;
 
-//import java.util.*;
-import com.gemstone.gemfire.cache.*;
-
-
-import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the functionality of a cache {@link Region region}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ProxyDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ProxyDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ProxyDUnitTest.java
index c65af94..54554ab 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ProxyDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ProxyDUnitTest.java
@@ -16,12 +16,34 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import java.util.*;
-import dunit.*;
+import java.util.HashMap;
+import java.util.Map;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.AttributesMutator;
+import com.gemstone.gemfire.cache.CacheEvent;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheWriter;
+import com.gemstone.gemfire.cache.CacheWriterException;
+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.Operation;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.SubscriptionAttributes;
+import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.internal.DMStats;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * Make sure that operations are distributed and done in
  * regions remote from a PROXY

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkRemoteVMDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkRemoteVMDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkRemoteVMDUnitTest.java
index 7ea0f84..ac818f3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkRemoteVMDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkRemoteVMDUnitTest.java
@@ -20,18 +20,29 @@
  *
  * Created on September 2, 2005, 2:49 PM
 */
-
 package com.gemstone.gemfire.cache30;
 
-import dunit.*;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
 
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheWriter;
+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.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
-
-import java.util.*;
-
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkSingleVMDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkSingleVMDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkSingleVMDUnitTest.java
index 856bc45..572ad53 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkSingleVMDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllCallBkSingleVMDUnitTest.java
@@ -20,24 +20,28 @@
  *
  * Created on August 31, 2005, 4:17 PM
  */
-
 package com.gemstone.gemfire.cache30;
 
-/**
- *
- * @author vjadhav
- */
-
-import dunit.*;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
 
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheWriter;
+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.util.CacheListenerAdapter;
 import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
-
-import java.util.*;
-
 import com.gemstone.gemfire.distributed.DistributedSystem;
-
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class PutAllCallBkSingleVMDUnitTest extends DistributedTestCase{
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllMultiVmDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllMultiVmDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllMultiVmDUnitTest.java
index c460091..2113118 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllMultiVmDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/PutAllMultiVmDUnitTest.java
@@ -20,17 +20,28 @@
  *
  * Created on September 1, 2005, 12:19 PM
  */
-
 package com.gemstone.gemfire.cache30;
 
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-
-import java.util.*;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+import java.util.TreeMap;
 
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionDestroyedException;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
-//import com.gemstone.gemfire.cache30.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/QueueMsgDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/QueueMsgDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/QueueMsgDUnitTest.java
index f55ae70..5a00ec0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/QueueMsgDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/QueueMsgDUnitTest.java
@@ -16,11 +16,29 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-import java.util.*;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+import java.util.TreeMap;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheEvent;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.InterestPolicy;
+import com.gemstone.gemfire.cache.Operation;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.SubscriptionAttributes;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.internal.cache.CachePerfStats;
+import com.gemstone.gemfire.internal.cache.DistributedRegion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test to make sure message queuing works.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RRSynchronizationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RRSynchronizationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RRSynchronizationDUnitTest.java
index 2e89abb..e707ea8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RRSynchronizationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RRSynchronizationDUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
 import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
 import com.gemstone.gemfire.internal.cache.versions.VersionSource;
 import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * concurrency-control tests for client/server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
index 9d0f69f..b4a73bc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
@@ -54,13 +54,12 @@ import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershi
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class ReconnectDUnitTest extends CacheTestCase
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionExpirationDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionExpirationDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionExpirationDUnitTest.java
index 3580e6a..af10e85 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionExpirationDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionExpirationDUnitTest.java
@@ -16,10 +16,16 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-//import com.gemstone.gemfire.internal.cache.LocalRegion;
-import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.ExpirationAction;
+import com.gemstone.gemfire.cache.ExpirationAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test Region expiration - both time-to-live and idle timeout.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionMembershipListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionMembershipListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionMembershipListenerDUnitTest.java
index 80ff586..8ecb00a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionMembershipListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionMembershipListenerDUnitTest.java
@@ -16,21 +16,31 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.List;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.Operation;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.RegionMembershipListener;
+import com.gemstone.gemfire.cache.util.RegionMembershipListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
 import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.distributed.internal.membership.gms.MembershipManagerHelper;
 import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
 import com.gemstone.gemfire.internal.cache.DistributedRegion;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-
-import java.util.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
 /**
  * Test {@link RegionMembershipListener}
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityListenerDUnitTest.java
index 9604d13..66a873d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityListenerDUnitTest.java
@@ -16,13 +16,25 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import dunit.*;
-import java.util.*;
+import java.util.Properties;
+import java.util.Set;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.LossAction;
+import com.gemstone.gemfire.cache.MembershipAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionRoleListener;
+import com.gemstone.gemfire.cache.ResumptionAction;
+import com.gemstone.gemfire.cache.RoleEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.RegionRoleListenerAdapter;
+import com.gemstone.gemfire.distributed.Role;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests the functionality of the {@link RegionRoleListener} class.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityTestCase.java
index f197425..26108cd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionReliabilityTestCase.java
@@ -16,22 +16,58 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.cache.*;
-
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Map;
+import java.util.Properties;
+import java.util.Set;
 import java.util.concurrent.locks.Lock;
 
-import dunit.*;
-import dunit.DistributedTestCase.WaitCriterion;
-
-import java.io.*;
-import java.util.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.AttributesMutator;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.CommitDistributionException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.ExpirationAction;
+import com.gemstone.gemfire.cache.ExpirationAttributes;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.LossAction;
+import com.gemstone.gemfire.cache.MembershipAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAccessException;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionDistributionException;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.RegionMembershipListener;
+import com.gemstone.gemfire.cache.RegionReinitializedException;
+import com.gemstone.gemfire.cache.RequiredRoles;
+import com.gemstone.gemfire.cache.ResumptionAction;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.query.Query;
+import com.gemstone.gemfire.cache.query.QueryService;
+import com.gemstone.gemfire.cache.util.RegionMembershipListenerAdapter;
+import com.gemstone.gemfire.distributed.Role;
+import com.gemstone.gemfire.distributed.internal.DM;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import com.gemstone.gemfire.internal.cache.AbstractRegion;
+import com.gemstone.gemfire.internal.cache.DistributedCacheOperation;
+import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.internal.cache.TXManagerImpl;
+import com.gemstone.gemfire.internal.cache.TXState;
+import com.gemstone.gemfire.internal.cache.TXStateInterface;
+import com.gemstone.gemfire.internal.cache.TXStateProxyImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests region reliability defined by MembershipAttributes.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
index 0bc0ec0..9c3add6 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RegionTestCase.java
@@ -58,11 +58,10 @@ import com.gemstone.gemfire.internal.cache.EntryExpiryTask;
 import com.gemstone.gemfire.internal.cache.EntrySnapshot;
 import com.gemstone.gemfire.internal.cache.ExpiryTask;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 //import com.gemstone.gemfire.internal.util.DebuggerSupport;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RemoveAllMultiVmDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RemoveAllMultiVmDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RemoveAllMultiVmDUnitTest.java
index aa07826..1d878aa 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RemoveAllMultiVmDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RemoveAllMultiVmDUnitTest.java
@@ -20,16 +20,26 @@
  *
  * Adapted from PutAllMultiVmDUnitTest
  */
-
 package com.gemstone.gemfire.cache30;
 
-import dunit.*;
-
-import com.gemstone.gemfire.cache.*;
-
-import java.util.*;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.Properties;
 
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.DistributedSystem;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RequiredRolesDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RequiredRolesDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RequiredRolesDUnitTest.java
index b950ed0..a4120b0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RequiredRolesDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RequiredRolesDUnitTest.java
@@ -16,15 +16,27 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-
-import dunit.*;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.Properties;
+import java.util.Set;
 
-import java.util.*;
+import com.gemstone.gemfire.SystemFailure;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.LossAction;
+import com.gemstone.gemfire.cache.MembershipAttributes;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RequiredRoles;
+import com.gemstone.gemfire.cache.ResumptionAction;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.distributed.Role;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests the functionality of the {@link RequiredRoles} class.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RolePerformanceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RolePerformanceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RolePerformanceDUnitTest.java
index 91a55d4..81cd191 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RolePerformanceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/RolePerformanceDUnitTest.java
@@ -16,10 +16,17 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-import java.util.*;
+import java.util.Properties;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests the performance of Regions when Roles are assigned.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SearchAndLoadDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SearchAndLoadDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SearchAndLoadDUnitTest.java
index cf9ff9c..ace3e4b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SearchAndLoadDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SearchAndLoadDUnitTest.java
@@ -19,9 +19,25 @@ package com.gemstone.gemfire.cache30;
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.*;
-
-import dunit.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheWriter;
+import com.gemstone.gemfire.cache.CacheWriterException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TimeoutException;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests various search load and write scenarios for distributed regions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SlowRecDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SlowRecDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SlowRecDUnitTest.java
index e79eddc..4d5cac2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SlowRecDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/SlowRecDUnitTest.java
@@ -16,22 +16,35 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import java.io.Serializable;
+import java.util.Iterator;
+import java.util.LinkedList;
+import java.util.Properties;
+import java.util.Set;
+
+import org.junit.Ignore;
+import org.junit.experimental.categories.Category;
+
 import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import com.gemstone.gemfire.cache.RegionEvent;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.distributed.internal.DM;
+import com.gemstone.gemfire.distributed.internal.DMStats;
 import com.gemstone.gemfire.internal.tcp.Connection;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.junit.categories.DistributedTest;
 
-import dunit.*;
-
-import java.io.*;
-import java.util.*;
-
-import org.junit.Ignore;
-import org.junit.experimental.categories.Category;
-
 /**
  * Test to make sure slow receiver queuing is working
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXDistributedDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXDistributedDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXDistributedDUnitTest.java
index c0034cd..2c065a1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXDistributedDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXDistributedDUnitTest.java
@@ -79,12 +79,11 @@ import com.gemstone.gemfire.internal.cache.TXStateProxyImpl;
 import com.gemstone.gemfire.internal.cache.locks.TXLockBatch;
 import com.gemstone.gemfire.internal.cache.locks.TXLockService;
 import com.gemstone.gemfire.internal.cache.locks.TXLockServiceImpl;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class TXDistributedDUnitTest extends CacheTestCase {
   public TXDistributedDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
index 2891de6..584a929 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXOrderDUnitTest.java
@@ -16,22 +16,45 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Iterator;
+import java.util.List;
+
+import javax.naming.Context;
+import javax.transaction.UserTransaction;
+
 import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.cache.*;
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheEvent;
+import com.gemstone.gemfire.cache.CacheException;
+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.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.PartitionAttributes;
+import com.gemstone.gemfire.cache.PartitionAttributesFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.TransactionEvent;
+import com.gemstone.gemfire.cache.TransactionListener;
 import com.gemstone.gemfire.cache.query.IndexType;
 import com.gemstone.gemfire.cache.query.Query;
 import com.gemstone.gemfire.cache.query.QueryService;
 import com.gemstone.gemfire.cache.query.SelectResults;
 import com.gemstone.gemfire.cache.query.transaction.Person;
-import com.gemstone.gemfire.cache.util.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import java.util.*;
-
-import javax.naming.Context;
-import javax.transaction.UserTransaction;
+import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import com.gemstone.gemfire.cache.util.TransactionListenerAdapter;
+import com.gemstone.gemfire.distributed.DistributedMember;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
-import dunit.*;
 /**
  * Test the order of operations done on the farside of a tx.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXRestrictionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXRestrictionsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXRestrictionsDUnitTest.java
index 6a32785..14c0bca 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXRestrictionsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TXRestrictionsDUnitTest.java
@@ -25,15 +25,19 @@
  * @see MultiVMRegionTestCase
  *
  */
-
 package com.gemstone.gemfire.cache30;
 
-
-import com.gemstone.gemfire.cache.*;
-
 import java.io.File;
-import dunit.*;
+
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+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.internal.OSProcess;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class TXRestrictionsDUnitTest extends CacheTestCase {
   public TXRestrictionsDUnitTest(String name) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TestCacheCallback.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TestCacheCallback.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TestCacheCallback.java
index 25629a1..118ebca 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TestCacheCallback.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/TestCacheCallback.java
@@ -17,9 +17,8 @@
 package com.gemstone.gemfire.cache30;
 
 import com.gemstone.gemfire.cache.*;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * An abstract superclass of implementation of GemFire cache callbacks

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedMemberDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedMemberDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedMemberDUnitTest.java
index 55a63ff..263ccf9 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedMemberDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedMemberDUnitTest.java
@@ -16,18 +16,26 @@
  */
 package com.gemstone.gemfire.distributed;
 
-import com.gemstone.gemfire.IncompatibleSystemException;
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-
 import java.net.InetAddress;
 import java.net.UnknownHostException;
-import java.util.*;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Properties;
+import java.util.Set;
 
-import org.junit.experimental.categories.Category;
-
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+import com.gemstone.gemfire.IncompatibleSystemException;
+import com.gemstone.gemfire.distributed.internal.DM;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 junit.framework.AssertionFailedError;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedSystemDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedSystemDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedSystemDUnitTest.java
index 6220019..3975133 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedSystemDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/DistributedSystemDUnitTest.java
@@ -44,10 +44,9 @@ import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershi
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.SocketCreator;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the functionality of the {@link DistributedSystem} class.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/HostedLocatorsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/HostedLocatorsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/HostedLocatorsDUnitTest.java
index 6a622e3..af241c1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/HostedLocatorsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/HostedLocatorsDUnitTest.java
@@ -33,11 +33,10 @@ import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedM
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.SocketCreator;
 import com.gemstone.gemfire.internal.util.StopWatch;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Extracted from LocatorLauncherLocalJUnitTest.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
index e13d0f3..de60132 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
@@ -50,13 +50,12 @@ import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LocalLogWriter;
 import com.gemstone.gemfire.internal.tcp.Connection;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests the ability of the {@link Locator} API to start and stop

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorJUnitTest.java
index a140ea3..c369f19 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/LocatorJUnitTest.java
@@ -50,11 +50,10 @@ import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 import com.gemstone.gemfire.management.internal.JmxManagerAdvisor.JmxManagerProfile;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 @Category(IntegrationTest.class)
 public class LocatorJUnitTest {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/RoleDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/RoleDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/RoleDUnitTest.java
index 3c2e4a9..eb36cdc 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/RoleDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/distributed/RoleDUnitTest.java
@@ -16,10 +16,18 @@
  */
 package com.gemstone.gemfire.distributed;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import dunit.*;
-import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import java.util.Iterator;
+import java.util.Properties;
+import java.util.Set;
+
+import com.gemstone.gemfire.distributed.internal.DM;
+import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Tests the functionality of the {@link DistributedMember} class.



[51/52] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-831

Posted by ds...@apache.org.
Merge remote-tracking branch 'origin/develop' into feature/GEODE-831


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/cd3d95fd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/cd3d95fd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/cd3d95fd

Branch: refs/heads/feature/GEODE-831
Commit: cd3d95fdd3945200a267e90ba0c59cdff4d05a92
Parents: 7f26733 46eaaa9
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Jan 28 13:33:28 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Jan 28 13:33:28 2016 -0800

----------------------------------------------------------------------
 LICENSE                                         |   80 +-
 NOTICE                                          |    2 +-
 README.md                                       |    7 +-
 build.gradle                                    |   22 +-
 gemfire-assembly/build.gradle                   |   10 +
 gemfire-assembly/src/main/dist/LICENSE          |   81 +-
 gemfire-assembly/src/main/dist/NOTICE           |  464 +-
 .../SharedConfigurationEndToEndDUnitTest.java   |    9 +-
 gemfire-core/build.gradle                       |    4 +-
 .../com/gemstone/gemfire/SystemFailure.java     |   49 +-
 .../cache/client/ClientCacheFactory.java        |    2 +-
 .../internal/AutoConnectionSourceImpl.java      |    2 +-
 .../cache/client/internal/ConnectionImpl.java   |    5 +-
 .../query/internal/index/MemoryIndexStore.java  |   67 +-
 .../gemfire/distributed/LocatorLauncher.java    |   13 +
 .../internal/InternalDistributedSystem.java     |   26 +-
 .../distributed/internal/InternalLocator.java   |   23 +-
 .../internal/membership/NetView.java            |   10 +
 .../gms/messenger/JGroupsMessenger.java         |   38 +-
 .../membership/gms/messenger/Transport.java     |   34 +-
 .../internal/tcpserver/TcpClient.java           |    8 +-
 .../internal/tcpserver/TcpServer.java           |   17 +-
 .../gemfire/internal/cache/AbstractRegion.java  |    5 +-
 .../gemfire/internal/cache/BucketRegion.java    |    5 +-
 .../internal/cache/GemFireCacheImpl.java        |  103 +-
 .../gemfire/internal/cache/LocalRegion.java     |    7 +-
 .../internal/cache/LocalRegionDataView.java     |    2 +-
 .../cache/PartitionedRegionDataStore.java       |    4 +-
 .../cache/PartitionedRegionDataView.java        |    2 +-
 .../gemfire/internal/cache/PoolManagerImpl.java |    4 +-
 .../gemfire/internal/cache/TXState.java         |    2 +-
 .../internal/i18n/ParentLocalizedStrings.java   |    9 +-
 .../gemfire/SystemFailureJUnitTest.java         |   60 +
 .../com/gemstone/gemfire/TXExpiryJUnitTest.java |    5 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |    7 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |    7 +-
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |    9 +-
 .../ClientServerRegisterInterestsDUnitTest.java |   13 +-
 .../internal/AutoConnectionSourceDUnitTest.java |   11 +-
 .../CacheServerSSLConnectionDUnitTest.java      |    7 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |   16 +-
 .../cache/client/internal/LocatorTestBase.java  |   11 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |    7 +-
 .../pooling/ConnectionManagerJUnitTest.java     |    5 +-
 .../management/MemoryThresholdsDUnitTest.java   |   13 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |   13 +-
 .../management/ResourceManagerDUnitTest.java    |    9 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |    3 +-
 .../PartitionRegionHelperDUnitTest.java         |   11 +-
 .../gemfire/cache/query/QueryTestUtils.java     |    5 +-
 .../query/cq/dunit/CqQueryTestListener.java     |    5 +-
 .../query/dunit/CompactRangeIndexDUnitTest.java |   11 +-
 .../cache/query/dunit/CqTimeTestListener.java   |    5 +-
 .../cache/query/dunit/GroupByDUnitImpl.java     |    7 +-
 .../dunit/GroupByPartitionedQueryDUnitTest.java |    7 +-
 .../query/dunit/GroupByQueryDUnitTest.java      |    7 +-
 .../cache/query/dunit/HashIndexDUnitTest.java   |    9 +-
 .../cache/query/dunit/HelperTestCase.java       |    9 +-
 .../dunit/NonDistinctOrderByDUnitImpl.java      |    7 +-
 .../NonDistinctOrderByPartitionedDUnitTest.java |    7 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    |   13 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   11 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |   13 +-
 .../QueryParamsAuthorizationDUnitTest.java      |    7 +-
 .../QueryUsingFunctionContextDUnitTest.java     |    7 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |    7 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   34 +-
 ...esourceManagerWithQueryMonitorDUnitTest.java |   11 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |    7 +-
 .../IndexCreationDeadLockJUnitTest.java         |    3 +-
 .../IndexMaintenanceAsynchJUnitTest.java        |    5 +-
 .../functional/LikePredicateJUnitTest.java      |    3 +-
 .../internal/ExecutionContextJUnitTest.java     |    3 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |    5 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |    9 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |    9 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |   12 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |   12 +-
 .../index/CopyOnReadIndexDUnitTest.java         |   11 +-
 .../index/IndexCreationInternalsJUnitTest.java  |    3 +-
 .../index/IndexMaintainceJUnitTest.java         |    3 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |    9 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |    9 +-
 .../index/MemoryIndexStoreJUnitTest.java        |  396 ++
 ...exStoreWithInplaceModificationJUnitTest.java |   54 +
 .../index/MultiIndexCreationDUnitTest.java      |   11 +-
 .../index/PutAllWithIndexPerfDUnitTest.java     |    5 +-
 .../PRBasicIndexCreationDUnitTest.java          |   11 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   11 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |    9 +-
 .../partitioned/PRBasicQueryDUnitTest.java      |    5 +-
 .../PRBasicRemoveIndexDUnitTest.java            |    5 +-
 .../PRColocatedEquiJoinDUnitTest.java           |    5 +-
 .../partitioned/PRInvalidQueryDUnitTest.java    |    5 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |    9 +-
 .../PRQueryCacheClosedJUnitTest.java            |    3 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |   16 +-
 .../query/partitioned/PRQueryDUnitTest.java     |    7 +-
 .../query/partitioned/PRQueryPerfDUnitTest.java |    5 +-
 .../PRQueryRegionCloseDUnitTest.java            |    9 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |    9 +-
 .../PRQueryRegionDestroyedJUnitTest.java        |    3 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    |   11 +-
 .../snapshot/ParallelSnapshotDUnitTest.java     |    7 +-
 .../snapshot/SnapshotByteArrayDUnitTest.java    |    5 +-
 .../cache/snapshot/SnapshotDUnitTest.java       |    5 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |    5 +-
 .../gemfire/cache30/Bug34387DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug34948DUnitTest.java      |   26 +-
 .../gemfire/cache30/Bug35214DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug38013DUnitTest.java      |   25 +-
 .../gemfire/cache30/Bug38741DUnitTest.java      |    9 +-
 .../gemfire/cache30/CacheCloseDUnitTest.java    |   16 +-
 .../gemfire/cache30/CacheLoaderTestCase.java    |   14 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   26 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |    7 +-
 .../cache30/CacheSerializableRunnable.java      |   10 +-
 .../cache30/CacheStatisticsDUnitTest.java       |   13 +-
 .../gemstone/gemfire/cache30/CacheTestCase.java |    7 +-
 .../gemfire/cache30/CacheXml30DUnitTest.java    |   12 +-
 .../gemfire/cache30/CacheXml41DUnitTest.java    |   34 +-
 .../gemfire/cache30/CacheXml45DUnitTest.java    |    7 +-
 .../gemfire/cache30/CacheXml51DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml57DUnitTest.java    |   18 +-
 .../gemfire/cache30/CacheXml60DUnitTest.java    |   16 +-
 .../gemfire/cache30/CacheXml61DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml66DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml81DUnitTest.java    |    2 +-
 .../gemfire/cache30/CacheXml90DUnitTest.java    |   17 +-
 .../cache30/CachedAllEventsDUnitTest.java       |   16 +-
 .../gemfire/cache30/CallbackArgDUnitTest.java   |   29 +-
 .../cache30/CertifiableTestCacheListener.java   |    5 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   27 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   33 +-
 .../cache30/ClientMembershipDUnitTest.java      |   11 +-
 .../ClientRegisterInterestDUnitTest.java        |    7 +-
 .../cache30/ClientServerCCEDUnitTest.java       |    9 +-
 .../gemfire/cache30/ClientServerTestCase.java   |    3 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   11 +-
 .../gemfire/cache30/DiskRegionDUnitTest.java    |   45 +-
 .../gemfire/cache30/DiskRegionTestImpl.java     |   19 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   37 +-
 ...tedAckOverflowRegionCCEOffHeapDUnitTest.java |    3 +-
 ...tributedAckPersistentRegionCCEDUnitTest.java |   15 +-
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedAckRegionCCEDUnitTest.java       |   15 +-
 ...DistributedAckRegionCCEOffHeapDUnitTest.java |    3 +-
 ...istributedAckRegionCompressionDUnitTest.java |    3 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   34 +-
 .../DistributedAckRegionOffHeapDUnitTest.java   |    3 +-
 .../DistributedMulticastRegionDUnitTest.java    |   11 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |   11 +-
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedNoAckRegionDUnitTest.java        |   17 +-
 .../DistributedNoAckRegionOffHeapDUnitTest.java |    3 +-
 .../gemfire/cache30/DynamicRegionDUnitTest.java |   21 +-
 .../gemfire/cache30/GlobalLockingDUnitTest.java |   15 +-
 .../cache30/GlobalRegionCCEDUnitTest.java       |    7 +-
 .../GlobalRegionCCEOffHeapDUnitTest.java        |    3 +-
 .../gemfire/cache30/GlobalRegionDUnitTest.java  |   25 +-
 .../cache30/GlobalRegionOffHeapDUnitTest.java   |    3 +-
 .../cache30/LRUEvictionControllerDUnitTest.java |    5 +-
 .../gemfire/cache30/LocalRegionDUnitTest.java   |   17 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  |   17 +-
 .../OffHeapLRUEvictionControllerDUnitTest.java  |    3 +-
 .../PRBucketSynchronizationDUnitTest.java       |    7 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   22 +-
 ...tionedRegionMembershipListenerDUnitTest.java |    3 +-
 .../PartitionedRegionOffHeapDUnitTest.java      |    3 +-
 .../cache30/PreloadedRegionTestCase.java        |   14 +-
 .../gemfire/cache30/ProxyDUnitTest.java         |   34 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |   23 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   28 +-
 .../gemfire/cache30/PutAllMultiVmDUnitTest.java |   25 +-
 .../gemfire/cache30/QueueMsgDUnitTest.java      |   28 +-
 .../cache30/RRSynchronizationDUnitTest.java     |    7 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     |   54 +-
 .../cache30/RegionExpirationDUnitTest.java      |   14 +-
 .../RegionMembershipListenerDUnitTest.java      |   28 +-
 .../RegionReliabilityListenerDUnitTest.java     |   26 +-
 .../cache30/RegionReliabilityTestCase.java      |   64 +-
 .../gemfire/cache30/RegionTestCase.java         |    9 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |   22 +-
 .../gemfire/cache30/RequiredRolesDUnitTest.java |   28 +-
 .../cache30/RolePerformanceDUnitTest.java       |   15 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |   22 +-
 .../gemfire/cache30/SlowRecDUnitTest.java       |   35 +-
 .../gemfire/cache30/TXDistributedDUnitTest.java |   11 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |   41 +-
 .../cache30/TXRestrictionsDUnitTest.java        |   14 +-
 .../gemfire/cache30/TestCacheCallback.java      |    5 +-
 .../distributed/DistributedMemberDUnitTest.java |   26 +-
 .../distributed/DistributedSystemDUnitTest.java |    7 +-
 .../distributed/HostedLocatorsDUnitTest.java    |    9 +-
 .../gemfire/distributed/LocatorDUnitTest.java   |   13 +-
 .../gemfire/distributed/LocatorJUnitTest.java   |    5 +-
 .../gemfire/distributed/RoleDUnitTest.java      |   16 +-
 .../distributed/SystemAdminDUnitTest.java       |    5 +-
 .../distributed/internal/Bug40751DUnitTest.java |    9 +-
 .../ConsoleDistributionManagerDUnitTest.java    |    9 +-
 .../internal/DistributionAdvisorDUnitTest.java  |   13 +-
 .../internal/DistributionManagerDUnitTest.java  |    9 +-
 .../internal/ProductUseLogDUnitTest.java        |   11 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   11 +-
 .../internal/locks/CollaborationJUnitTest.java  |    5 +-
 .../internal/membership/NetViewJUnitTest.java   |   19 +-
 .../membership/gms/MembershipManagerHelper.java |    5 +-
 .../gms/fd/GMSHealthMonitorJUnitTest.java       |   26 +-
 .../gms/membership/GMSJoinLeaveJUnitTest.java   |   36 +-
 .../messenger/GMSQuorumCheckerJUnitTest.java    |    4 +-
 .../messenger/JGroupsMessengerJUnitTest.java    |   61 +-
 .../gms/mgr/GMSMembershipManagerJUnitTest.java  |   21 +-
 .../StreamingOperationManyDUnitTest.java        |   20 +-
 .../StreamingOperationOneDUnitTest.java         |   23 +-
 .../TcpServerBackwardCompatDUnitTest.java       |    7 +-
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java |    5 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |    9 +-
 .../disttx/DistTXPersistentDebugDUnitTest.java  |    2 +-
 .../disttx/DistributedTransactionDUnitTest.java |    7 +-
 .../ClassNotFoundExceptionDUnitTest.java        |    9 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |    3 +-
 .../gemfire/internal/JarDeployerDUnitTest.java  |    7 +-
 .../internal/PdxDeleteFieldDUnitTest.java       |    7 +-
 .../gemfire/internal/PdxRenameDUnitTest.java    |    7 +-
 .../gemfire/internal/SocketCloserJUnitTest.java |    5 +-
 .../gemfire/internal/cache/BackupDUnitTest.java |   13 +-
 .../internal/cache/Bug33359DUnitTest.java       |    8 +-
 .../internal/cache/Bug33726DUnitTest.java       |    8 +-
 .../internal/cache/Bug37241DUnitTest.java       |    8 +-
 .../internal/cache/Bug37377DUnitTest.java       |   11 +-
 .../internal/cache/Bug39079DUnitTest.java       |    7 +-
 .../internal/cache/Bug40299DUnitTest.java       |   11 +-
 .../internal/cache/Bug40632DUnitTest.java       |    9 +-
 .../internal/cache/Bug41091DUnitTest.java       |    7 +-
 .../internal/cache/Bug41733DUnitTest.java       |   15 +-
 .../internal/cache/Bug41957DUnitTest.java       |   29 +-
 .../internal/cache/Bug42055DUnitTest.java       |    9 +-
 .../internal/cache/Bug45164DUnitTest.java       |    7 +-
 .../internal/cache/Bug45934DUnitTest.java       |    7 +-
 .../internal/cache/Bug47667DUnitTest.java       |    7 +-
 .../internal/cache/CacheAdvisorDUnitTest.java   |   30 +-
 .../internal/cache/ClearDAckDUnitTest.java      |   11 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |    6 +-
 .../cache/ClientServerGetAllDUnitTest.java      |   33 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |  995 ++--
 .../ClientServerTransactionCCEDUnitTest.java    |    5 +-
 .../cache/ClientServerTransactionDUnitTest.java |   11 +-
 .../ConcurrentDestroySubRegionDUnitTest.java    |    9 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |   11 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |    3 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |    3 +-
 .../cache/ConnectDisconnectDUnitTest.java       |   13 +-
 .../internal/cache/DeltaFaultInDUnitTest.java   |    9 +-
 .../cache/DeltaPropagationDUnitTest.java        |    9 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |    7 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |    9 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   15 +-
 .../cache/DiskRegionClearJUnitTest.java         |    3 +-
 .../internal/cache/DiskRegionJUnitTest.java     |    5 +-
 ...DistrbutedRegionProfileOffHeapDUnitTest.java |    5 +-
 .../cache/DistributedCacheTestCase.java         |   23 +-
 .../internal/cache/EventTrackerDUnitTest.java   |    7 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |    7 +-
 .../internal/cache/EvictionTestBase.java        |   11 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |    9 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |   13 +-
 .../internal/cache/GIIFlowControlDUnitTest.java |    9 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |   25 +-
 .../internal/cache/HABug36773DUnitTest.java     |    7 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |    7 +-
 .../cache/IncrementalBackupDUnitTest.java       |   11 +-
 .../cache/InterruptClientServerDUnitTest.java   |    9 +-
 .../internal/cache/InterruptsDUnitTest.java     |    9 +-
 .../internal/cache/IteratorDUnitTest.java       |    7 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   14 +-
 .../internal/cache/MapInterface2JUnitTest.java  |    3 +-
 .../cache/NetSearchMessagingDUnitTest.java      |   11 +-
 .../cache/OffHeapEvictionDUnitTest.java         |    7 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |    3 +-
 .../gemfire/internal/cache/OplogJUnitTest.java  |    5 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |    7 +-
 .../internal/cache/PRBadToDataDUnitTest.java    |    9 +-
 .../cache/PartitionListenerDUnitTest.java       |    9 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |    7 +-
 .../PartitionedRegionAsSubRegionDUnitTest.java  |    5 +-
 ...gionBucketCreationDistributionDUnitTest.java |   22 +-
 .../PartitionedRegionCacheCloseDUnitTest.java   |    9 +-
 ...rtitionedRegionCacheXMLExampleDUnitTest.java |    5 +-
 .../PartitionedRegionCreationDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionDUnitTestCase.java   |    5 +-
 ...rtitionedRegionDelayedRecoveryDUnitTest.java |    9 +-
 .../PartitionedRegionDestroyDUnitTest.java      |   11 +-
 .../PartitionedRegionEntryCountDUnitTest.java   |    9 +-
 .../PartitionedRegionEvictionDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionHADUnitTest.java     |   13 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |   22 +-
 .../PartitionedRegionInvalidateDUnitTest.java   |    7 +-
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |    7 +-
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java |    3 +-
 .../PartitionedRegionMultipleDUnitTest.java     |    8 +-
 ...rtitionedRegionOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/PartitionedRegionPRIDDUnitTest.java   |    9 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |    9 +-
 ...artitionedRegionRedundancyZoneDUnitTest.java |    9 +-
 ...tionedRegionSerializableObjectJUnitTest.java |    2 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |    9 +-
 ...RegionSingleHopWithServerGroupDUnitTest.java |    9 +-
 .../cache/PartitionedRegionSizeDUnitTest.java   |   13 +-
 .../cache/PartitionedRegionStatsDUnitTest.java  |    7 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |    5 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |   14 +-
 .../internal/cache/PutAllDAckDUnitTest.java     |   16 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   25 +-
 .../cache/RemoteTransactionDUnitTest.java       |   13 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   12 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   10 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   23 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |    3 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |    7 +-
 .../internal/cache/SizingFlagDUnitTest.java     |    9 +-
 .../internal/cache/SystemFailureDUnitTest.java  |    7 +-
 .../cache/TXReservationMgrJUnitTest.java        |    3 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |    7 +-
 .../control/RebalanceOperationDUnitTest.java    |   11 +-
 ...egionOverflowAsyncRollingOpLogJUnitTest.java |    5 +-
 ...RegionOverflowSyncRollingOpLogJUnitTest.java |    5 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |    3 +-
 .../cache/execute/Bug51193DUnitTest.java        |    7 +-
 .../ClientServerFunctionExecutionDUnitTest.java |    5 +-
 .../execute/ColocationFailoverDUnitTest.java    |    9 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |    9 +-
 .../FunctionExecution_ExceptionDUnitTest.java   |    9 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |   11 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |   11 +-
 .../execute/LocalDataSetIndexingDUnitTest.java  |    5 +-
 .../LocalFunctionExecutionDUnitTest.java        |    9 +-
 .../MemberFunctionExecutionDUnitTest.java       |    9 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |    7 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |    9 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |    7 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |   11 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |    5 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |    5 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |    5 +-
 .../cache/execute/PRClientServerTestBase.java   |   11 +-
 .../cache/execute/PRColocationDUnitTest.java    |   12 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |    7 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |   13 +-
 .../PRFunctionExecutionTimeOutDUnitTest.java    |    7 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |    7 +-
 .../execute/PRPerformanceTestDUnitTest.java     |    7 +-
 .../cache/execute/PRTransactionDUnitTest.java   |    3 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |    3 +-
 .../functions/DistributedRegionFunction.java    |    5 +-
 .../internal/cache/functions/TestFunction.java  |    5 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |    3 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |    5 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |    5 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |    7 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |    7 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |    7 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |    7 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |    7 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |    7 +-
 .../cache/ha/HAConflationDUnitTest.java         |    7 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |    7 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |    7 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |    9 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   11 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |    9 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |    3 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |    7 +-
 .../internal/cache/ha/HARegionDUnitTest.java    |    7 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |    7 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |    3 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |    6 +-
 .../ha/OperationsPropagationDUnitTest.java      |    7 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |    7 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |    7 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   29 +-
 .../cache/partitioned/Bug39356DUnitTest.java    |    9 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |    9 +-
 .../partitioned/ElidedPutAllDUnitTest.java      |    7 +-
 .../partitioned/PartitionResolverDUnitTest.java |    7 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |    4 +-
 ...rtitionedRegionMetaDataCleanupDUnitTest.java |    9 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |    9 +-
 ...tentColocatedPartitionedRegionDUnitTest.java |   11 +-
 .../PersistentPartitionedRegionDUnitTest.java   |   15 +-
 .../PersistentPartitionedRegionTestBase.java    |    9 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |    9 +-
 .../cache/partitioned/ShutdownAllDUnitTest.java |   15 +-
 ...treamingPartitionOperationManyDUnitTest.java |   29 +-
 ...StreamingPartitionOperationOneDUnitTest.java |   34 +-
 .../fixed/FixedPartitioningDUnitTest.java       |    7 +-
 .../fixed/FixedPartitioningTestBase.java        |    9 +-
 ...ngWithColocationAndPersistenceDUnitTest.java |    5 +-
 .../PersistentRVVRecoveryDUnitTest.java         |   11 +-
 .../PersistentRecoveryOrderDUnitTest.java       |   11 +-
 ...rsistentRecoveryOrderOldConfigDUnitTest.java |    7 +-
 .../PersistentReplicatedTestBase.java           |    7 +-
 .../internal/cache/tier/Bug40396DUnitTest.java  |    9 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |    7 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |    7 +-
 .../CacheServerMaxConnectionsJUnitTest.java     |    5 +-
 .../cache/tier/sockets/CacheServerTestUtil.java |    3 +-
 .../CacheServerTransactionsDUnitTest.java       |    7 +-
 .../tier/sockets/ClearPropagationDUnitTest.java |    7 +-
 .../tier/sockets/ClientConflationDUnitTest.java |    7 +-
 .../sockets/ClientHealthMonitorJUnitTest.java   |    5 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |    7 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   11 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |    7 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |    5 +-
 .../DataSerializerPropogationDUnitTest.java     |    7 +-
 .../DestroyEntryPropagationDUnitTest.java       |    7 +-
 .../sockets/DurableClientBug39997DUnitTest.java |    7 +-
 .../DurableClientQueueSizeDUnitTest.java        |    7 +-
 .../DurableClientReconnectAutoDUnitTest.java    |    5 +-
 .../DurableClientReconnectDUnitTest.java        |    7 +-
 .../sockets/DurableClientStatsDUnitTest.java    |    7 +-
 .../sockets/DurableRegistrationDUnitTest.java   |    7 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |    7 +-
 .../sockets/EventIDVerificationDUnitTest.java   |    7 +-
 .../EventIDVerificationInP2PDUnitTest.java      |    7 +-
 .../ForceInvalidateEvictionDUnitTest.java       |    7 +-
 ...ForceInvalidateOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |    7 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |    2 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |    5 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |    7 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |    7 +-
 .../InstantiatorPropagationDUnitTest.java       |    7 +-
 .../tier/sockets/InterestListDUnitTest.java     |  210 +-
 .../sockets/InterestListEndpointDUnitTest.java  |    9 +-
 .../sockets/InterestListFailoverDUnitTest.java  |    7 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |    6 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |    7 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |    7 +-
 .../sockets/NewRegionAttributesDUnitTest.java   |    7 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |    5 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |    7 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |    7 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |    7 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |    7 +-
 .../sockets/ReliableMessagingDUnitTest.java     |    7 +-
 .../sockets/UnregisterInterestDUnitTest.java    |    7 +-
 .../sockets/UpdatePropagationDUnitTest.java     |    7 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |    7 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |    7 +-
 .../versions/RegionVersionVectorJUnitTest.java  |    3 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |    7 +-
 .../AsyncEventQueueStatsDUnitTest.java          |    3 +-
 .../ConcurrentAsyncEventQueueDUnitTest.java     |    3 +-
 .../CompressionCacheConfigDUnitTest.java        |    7 +-
 .../CompressionCacheListenerDUnitTest.java      |    9 +-
 ...ompressionCacheListenerOffHeapDUnitTest.java |    3 +-
 .../CompressionRegionConfigDUnitTest.java       |   11 +-
 .../CompressionRegionFactoryDUnitTest.java      |    9 +-
 .../CompressionRegionOperationsDUnitTest.java   |    9 +-
 ...ressionRegionOperationsOffHeapDUnitTest.java |    3 +-
 .../compression/CompressionStatsDUnitTest.java  |    9 +-
 .../internal/jta/dunit/CommitThread.java        |   28 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   42 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |   44 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   11 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |   43 +-
 .../internal/jta/dunit/RollbackThread.java      |   28 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   26 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   51 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |   31 +-
 .../DistributedSystemLogFileJUnitTest.java      |    5 +-
 .../logging/LocatorLogFileJUnitTest.java        |    5 +-
 .../logging/MergeLogFilesJUnitTest.java         |    3 +-
 .../offheap/OffHeapHelperJUnitTest.java         |  314 ++
 .../internal/offheap/OffHeapRegionBase.java     |    5 +-
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    |    5 +-
 .../process/LocalProcessLauncherDUnitTest.java  |    7 +-
 .../statistics/StatisticsDUnitTest.java         |    9 +-
 .../statistics/ValueMonitorJUnitTest.java       |    4 +-
 .../management/CacheManagementDUnitTest.java    |    8 +-
 .../management/ClientHealthStatsDUnitTest.java  |   13 +-
 .../management/CompositeTypeTestDUnitTest.java  |    5 +-
 .../management/DLockManagementDUnitTest.java    |    5 +-
 .../management/DiskManagementDUnitTest.java     |    9 +-
 .../management/DistributedSystemDUnitTest.java  |   12 +-
 .../management/LocatorManagementDUnitTest.java  |    7 +-
 .../gemstone/gemfire/management/MBeanUtil.java  |    5 +-
 .../gemfire/management/ManagementTestBase.java  |   13 +-
 .../MemberMBeanAttributesDUnitTest.java         |    5 +-
 .../management/OffHeapManagementDUnitTest.java  |    9 +-
 .../gemfire/management/QueryDataDUnitTest.java  |    8 +-
 .../management/RegionManagementDUnitTest.java   |    5 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |    7 +-
 .../stats/DistributedSystemStatsDUnitTest.java  |    5 +-
 .../internal/cli/CliUtilDUnitTest.java          |   11 +-
 .../cli/commands/CliCommandTestBase.java        |    7 +-
 .../cli/commands/ConfigCommandsDUnitTest.java   |   11 +-
 ...eateAlterDestroyRegionCommandsDUnitTest.java |   10 +-
 .../cli/commands/DeployCommandsDUnitTest.java   |    8 +-
 .../commands/DiskStoreCommandsDUnitTest.java    |   11 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |   10 +-
 .../commands/GemfireDataCommandsDUnitTest.java  |   11 +-
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |   21 +-
 .../cli/commands/IndexCommandsDUnitTest.java    |   10 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |   15 +-
 .../ListAndDescribeRegionDUnitTest.java         |    6 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |   33 +-
 .../cli/commands/MemberCommandsDUnitTest.java   |    6 +-
 .../MiscellaneousCommandsDUnitTest.java         |    9 +-
 ...laneousCommandsExportLogsPart1DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart2DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart4DUnitTest.java |    6 +-
 .../cli/commands/QueueCommandsDUnitTest.java    |    8 +-
 .../SharedConfigurationCommandsDUnitTest.java   |   11 +-
 .../cli/commands/ShowDeadlockDUnitTest.java     |    8 +-
 .../cli/commands/ShowMetricsDUnitTest.java      |    8 +-
 .../cli/commands/ShowStackTraceDUnitTest.java   |    6 +-
 .../cli/commands/UserCommandsDUnitTest.java     |    5 +-
 .../SharedConfigurationDUnitTest.java           |   11 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |   13 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |    4 +-
 .../internal/pulse/TestHeapDUnitTest.java       |    3 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |   10 +-
 .../ClientsWithVersioningRetryDUnitTest.java    |    9 +-
 .../pdx/DistributedSystemIdDUnitTest.java       |    9 +-
 .../pdx/JSONPdxClientServerDUnitTest.java       |    8 +-
 .../pdx/PDXAsyncEventQueueDUnitTest.java        |    7 +-
 .../gemfire/pdx/PdxClientServerDUnitTest.java   |    9 +-
 .../pdx/PdxDeserializationDUnitTest.java        |    9 +-
 .../gemfire/pdx/PdxSerializableDUnitTest.java   |    9 +-
 .../gemfire/pdx/PdxTypeExportDUnitTest.java     |    5 +-
 .../gemfire/pdx/VersionClassLoader.java         |   16 +-
 .../gemfire/redis/RedisDistDUnitTest.java       |   11 +-
 .../web/controllers/RestAPITestBase.java        |    7 +-
 .../security/ClientAuthenticationDUnitTest.java |    6 +-
 .../security/ClientAuthorizationDUnitTest.java  |    6 +-
 .../security/ClientAuthorizationTestBase.java   |    4 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |    3 +-
 .../DeltaClientAuthorizationDUnitTest.java      |    3 +-
 .../DeltaClientPostAuthorizationDUnitTest.java  |    5 +-
 .../security/P2PAuthenticationDUnitTest.java    |    7 +-
 .../gemfire/security/SecurityTestUtil.java      |    3 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |  215 +
 .../gemstone/gemfire/test/dunit/DUnitEnv.java   |   79 +
 .../gemfire/test/dunit/DistributedTestCase.java | 1435 +++++
 .../com/gemstone/gemfire/test/dunit/Host.java   |  212 +
 .../gemfire/test/dunit/RMIException.java        |  170 +
 .../gemfire/test/dunit/RepeatableRunnable.java  |   29 +
 .../test/dunit/SerializableCallable.java        |   70 +
 .../test/dunit/SerializableCallableIF.java      |   24 +
 .../test/dunit/SerializableRunnable.java        |   92 +
 .../test/dunit/SerializableRunnableIF.java      |   23 +
 .../com/gemstone/gemfire/test/dunit/VM.java     | 1345 +++++
 .../test/dunit/standalone/DUnitLauncher.java    |    9 +-
 .../test/dunit/standalone/RemoteDUnitVM.java    |   41 +-
 .../dunit/standalone/StandAloneDUnitEnv.java    |    3 +-
 .../test/dunit/tests/BasicDUnitTest.java        |   37 +-
 .../gemfire/test/dunit/tests/VMDUnitTest.java   |   12 +-
 .../src/test/java/dunit/AsyncInvocation.java    |  217 -
 gemfire-core/src/test/java/dunit/DUnitEnv.java  |   80 -
 .../test/java/dunit/DistributedTestCase.java    | 1438 -----
 gemfire-core/src/test/java/dunit/Host.java      |  210 -
 .../src/test/java/dunit/RMIException.java       |  170 -
 .../src/test/java/dunit/RepeatableRunnable.java |   29 -
 .../test/java/dunit/SerializableCallable.java   |   70 -
 .../test/java/dunit/SerializableRunnable.java   |   92 -
 gemfire-core/src/test/java/dunit/VM.java        | 1347 -----
 .../src/test/java/hydra/MethExecutor.java       |    2 +-
 gemfire-cq/build.gradle                         |   22 +
 .../cache/client/internal/CloseCQOp.java        |   72 +
 .../cache/client/internal/CreateCQOp.java       |  163 +
 .../cache/client/internal/CreateCQWithIROp.java |   92 +
 .../cache/client/internal/GetDurableCQsOp.java  |  135 +
 .../client/internal/ServerCQProxyImpl.java      |  111 +
 .../gemfire/cache/client/internal/StopCQOp.java |   72 +
 .../cache/query/internal/cq/ClientCQImpl.java   |  615 +++
 .../internal/cq/CqAttributesMutatorImpl.java    |   68 +
 .../cache/query/internal/cq/CqConflatable.java  |  223 +
 .../cache/query/internal/cq/CqEventImpl.java    |  162 +
 .../cache/query/internal/cq/CqListenerImpl.java |   56 +
 .../cache/query/internal/cq/CqQueryImpl.java    |  383 ++
 .../query/internal/cq/CqServiceFactoryImpl.java |   69 +
 .../cache/query/internal/cq/CqServiceImpl.java  | 2087 +++++++
 .../internal/cq/CqServiceStatisticsImpl.java    |  100 +
 .../query/internal/cq/CqServiceVsdStats.java    |  411 ++
 .../query/internal/cq/CqStatisticsImpl.java     |   75 +
 .../cache/query/internal/cq/ServerCQImpl.java   |  655 +++
 .../tier/sockets/command/BaseCQCommand.java     |   59 +
 .../cache/tier/sockets/command/CloseCQ.java     |  131 +
 .../cache/tier/sockets/command/ExecuteCQ.java   |  168 +
 .../cache/tier/sockets/command/ExecuteCQ61.java |  220 +
 .../cache/tier/sockets/command/GetCQStats.java  |  100 +
 .../tier/sockets/command/GetDurableCQs.java     |  143 +
 .../cache/tier/sockets/command/MonitorCQ.java   |  100 +
 .../cache/tier/sockets/command/StopCQ.java      |  135 +
 ...cache.query.internal.cq.spi.CqServiceFactory |   15 +
 .../gemfire/cache/query/cq/CQJUnitTest.java     |  150 +
 .../cache/query/cq/dunit/CqDataDUnitTest.java   | 1162 ++++
 .../dunit/CqDataOptimizedExecuteDUnitTest.java  |   54 +
 .../cq/dunit/CqDataUsingPoolDUnitTest.java      | 1567 ++++++
 ...qDataUsingPoolOptimizedExecuteDUnitTest.java |   53 +
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   | 1044 ++++
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      | 1004 ++++
 .../cache/query/cq/dunit/CqQueryDUnitTest.java  | 4004 ++++++++++++++
 .../dunit/CqQueryOptimizedExecuteDUnitTest.java |  311 ++
 .../cq/dunit/CqQueryUsingPoolDUnitTest.java     | 3322 +++++++++++
 ...QueryUsingPoolOptimizedExecuteDUnitTest.java |   50 +
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java | 1139 ++++
 ...ltSetUsingPoolOptimizedExecuteDUnitTest.java |  231 +
 .../cache/query/cq/dunit/CqStateDUnitTest.java  |  134 +
 .../cache/query/cq/dunit/CqStatsDUnitTest.java  |  441 ++
 .../dunit/CqStatsOptimizedExecuteDUnitTest.java |   51 +
 .../cq/dunit/CqStatsUsingPoolDUnitTest.java     |  452 ++
 ...StatsUsingPoolOptimizedExecuteDUnitTest.java |   51 +
 .../query/cq/dunit/CqTimeTestListener.java      |  266 +
 .../PartitionedRegionCqQueryDUnitTest.java      | 1788 ++++++
 ...dRegionCqQueryOptimizedExecuteDUnitTest.java |  246 +
 .../query/cq/dunit/PrCqUsingPoolDUnitTest.java  | 2029 +++++++
 .../PrCqUsingPoolOptimizedExecuteDUnitTest.java |   50 +
 .../cache/query/dunit/PdxQueryCQDUnitTest.java  |  702 +++
 .../cache/query/dunit/PdxQueryCQTestBase.java   |  494 ++
 .../dunit/QueryIndexUpdateRIDUnitTest.java      |  819 +++
 .../query/dunit/QueryMonitorDUnitTest.java      | 1296 +++++
 .../cache/snapshot/ClientSnapshotDUnitTest.java |  284 +
 .../AnalyzeCQSerializablesJUnitTest.java        |   79 +
 .../cache/PRDeltaPropagationDUnitTest.java      | 1212 ++++
 .../internal/cache/PutAllCSDUnitTest.java       | 4419 +++++++++++++++
 .../cache/RemoteCQTransactionDUnitTest.java     | 1121 ++++
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  820 +++
 .../cache/ha/HADispatcherDUnitTest.java         |  695 +++
 .../sockets/ClientToServerDeltaDUnitTest.java   | 1037 ++++
 .../DeltaPropagationWithCQDUnitTest.java        |  341 ++
 ...ToRegionRelationCQRegistrationDUnitTest.java |  786 +++
 .../sockets/DurableClientCrashDUnitTest.java    |   99 +
 .../sockets/DurableClientNetDownDUnitTest.java  |   80 +
 .../sockets/DurableClientSimpleDUnitTest.java   | 3404 ++++++++++++
 .../tier/sockets/DurableClientTestCase.java     | 2089 +++++++
 .../CacheServerManagementDUnitTest.java         |  571 ++
 .../cli/commands/ClientCommandsDUnitTest.java   | 1443 +++++
 .../DurableClientCommandsDUnitTest.java         |  433 ++
 .../internal/pulse/TestCQDUnitTest.java         |  147 +
 .../internal/pulse/TestClientsDUnitTest.java    |  108 +
 .../internal/pulse/TestServerDUnitTest.java     |   99 +
 .../ClientAuthorizationTwoDUnitTest.java        |  245 +
 .../security/ClientAuthzObjectModDUnitTest.java |  416 ++
 .../ClientCQPostAuthorizationDUnitTest.java     |  522 ++
 .../ClientPostAuthorizationDUnitTest.java       |  398 ++
 .../gemfire/security/MultiuserAPIDUnitTest.java |  391 ++
 .../MultiuserDurableCQAuthzDUnitTest.java       |  489 ++
 .../gemfire/codeAnalysis/excludedClasses.txt    |    2 +
 .../gemstone/gemfire/codeAnalysis/openBugs.txt  |   21 +
 .../sanctionedDataSerializables.txt             |    4 +
 .../codeAnalysis/sanctionedSerializables.txt    |    1 +
 .../tier/sockets/durablecq-client-cache.xml     |   37 +
 .../tier/sockets/durablecq-server-cache.xml     |   32 +
 .../LuceneFunctionReadPathDUnitTest.java        |    7 +-
 gemfire-pulse/build.gradle                      |   62 +-
 .../pulse/internal/data/PulseConstants.java     |    4 +-
 .../tools/pulse/testbed/driver/PulseUITest.java |    5 -
 .../gemfire/tools/pulse/tests/PulseTest.java    |   32 +-
 .../website/content/community/index.html        |   40 +-
 gemfire-wan/build.gradle                        |   22 +
 .../client/internal/GatewaySenderBatchOp.java   |  313 ++
 .../cache/client/internal/SenderProxy.java      |   43 +
 .../internal/locator/wan/LocatorDiscovery.java  |  227 +
 .../internal/locator/wan/LocatorHelper.java     |  143 +
 .../locator/wan/LocatorJoinMessage.java         |  105 +
 .../wan/LocatorMembershipListenerImpl.java      |  230 +
 .../locator/wan/RemoteLocatorJoinRequest.java   |   87 +
 .../locator/wan/RemoteLocatorJoinResponse.java  |   89 +
 .../locator/wan/RemoteLocatorPingRequest.java   |   56 +
 .../locator/wan/RemoteLocatorPingResponse.java  |   55 +
 .../locator/wan/RemoteLocatorRequest.java       |   66 +
 .../locator/wan/RemoteLocatorResponse.java      |   74 +
 .../internal/locator/wan/WANFactoryImpl.java    |   74 +
 .../locator/wan/WanLocatorDiscovererImpl.java   |  138 +
 .../cache/wan/AbstractRemoteGatewaySender.java  |  169 +
 .../cache/wan/GatewayReceiverFactoryImpl.java   |  147 +
 .../internal/cache/wan/GatewayReceiverImpl.java |  253 +
 .../wan/GatewaySenderEventRemoteDispatcher.java |  767 +++
 .../cache/wan/GatewaySenderFactoryImpl.java     |  389 ++
 .../wan/parallel/ParallelGatewaySenderImpl.java |  267 +
 ...rentParallelGatewaySenderEventProcessor.java |   67 +
 ...moteParallelGatewaySenderEventProcessor.java |  122 +
 ...urrentSerialGatewaySenderEventProcessor.java |   45 +
 ...RemoteSerialGatewaySenderEventProcessor.java |   50 +
 .../wan/serial/SerialGatewaySenderImpl.java     |  260 +
 ...ternal.locator.wan.LocatorMembershipListener |   15 +
 ...ne.gemfire.internal.cache.wan.spi.WANFactory |   15 +
 .../cache/CacheXml70GatewayDUnitTest.java       |  243 +
 .../cache/CacheXml80GatewayDUnitTest.java       |   77 +
 .../AnalyzeWANSerializablesJUnitTest.java       |   91 +
 .../internal/cache/UpdateVersionDUnitTest.java  |  960 ++++
 .../gemfire/internal/cache/wan/WANTestBase.java | 5178 ++++++++++++++++++
 ...oncurrentParallelGatewaySenderDUnitTest.java |  860 +++
 ...ntParallelGatewaySenderOffHeapDUnitTest.java |   32 +
 ...allelGatewaySenderOperation_1_DUnitTest.java |  848 +++
 ...allelGatewaySenderOperation_2_DUnitTest.java |  579 ++
 ...tSerialGatewaySenderOperationsDUnitTest.java |  111 +
 ...GatewaySenderOperationsOffHeapDUnitTest.java |   32 +
 .../ConcurrentWANPropogation_1_DUnitTest.java   |  608 ++
 .../ConcurrentWANPropogation_2_DUnitTest.java   |  485 ++
 .../cache/wan/disttx/DistTXWANDUnitTest.java    |  209 +
 .../CommonParallelGatewaySenderDUnitTest.java   |  481 ++
 ...onParallelGatewaySenderOffHeapDUnitTest.java |   32 +
 ...wWANConcurrencyCheckForDestroyDUnitTest.java |  526 ++
 .../cache/wan/misc/PDXNewWanDUnitTest.java      |  787 +++
 ...dRegion_ParallelWANPersistenceDUnitTest.java |  752 +++
 ...dRegion_ParallelWANPropogationDUnitTest.java | 1132 ++++
 .../SenderWithTransportFilterDUnitTest.java     |  274 +
 ...downAllPersistentGatewaySenderDUnitTest.java |  205 +
 .../wan/misc/WANConfigurationJUnitTest.java     |  617 +++
 .../wan/misc/WANLocatorServerDUnitTest.java     |  193 +
 .../cache/wan/misc/WANSSLDUnitTest.java         |  151 +
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |  557 ++
 .../cache/wan/misc/WanValidationsDUnitTest.java | 1678 ++++++
 ...GatewaySenderOperationsOffHeapDUnitTest.java |   34 +
 ...ewaySenderQueueOverflowOffHeapDUnitTest.java |   34 +
 .../ParallelWANConflationOffHeapDUnitTest.java  |   34 +
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   34 +
 ...ropogationConcurrentOpsOffHeapDUnitTest.java |   34 +
 .../ParallelWANPropogationOffHeapDUnitTest.java |   34 +
 ...erialGatewaySenderQueueOffHeapDUnitTest.java |   34 +
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   34 +
 .../SerialWANPropogationOffHeapDUnitTest.java   |   34 +
 ...ation_PartitionedRegionOffHeapDUnitTest.java |   34 +
 ...arallelGatewaySenderOperationsDUnitTest.java | 1984 +++++++
 ...llelGatewaySenderQueueOverflowDUnitTest.java |  531 ++
 .../ParallelWANConflationDUnitTest.java         |  496 ++
 ...ersistenceEnabledGatewaySenderDUnitTest.java | 1823 ++++++
 ...llelWANPropagationClientServerDUnitTest.java |  114 +
 ...lelWANPropagationConcurrentOpsDUnitTest.java |  290 +
 .../ParallelWANPropagationDUnitTest.java        | 1448 +++++
 ...ParallelWANPropagationLoopBackDUnitTest.java |  425 ++
 .../wan/parallel/ParallelWANStatsDUnitTest.java |  632 +++
 ...tewaySenderDistributedDeadlockDUnitTest.java |  407 ++
 ...rialGatewaySenderEventListenerDUnitTest.java |  390 ++
 .../SerialGatewaySenderOperationsDUnitTest.java |  602 ++
 .../SerialGatewaySenderQueueDUnitTest.java      |  337 ++
 ...ersistenceEnabledGatewaySenderDUnitTest.java |  602 ++
 .../SerialWANPropagationLoopBackDUnitTest.java  |  538 ++
 .../serial/SerialWANPropogationDUnitTest.java   | 1602 ++++++
 ...NPropogation_PartitionedRegionDUnitTest.java |  439 ++
 .../SerialWANPropogationsFeatureDUnitTest.java  |  373 ++
 .../wan/serial/SerialWANStatsDUnitTest.java     |  596 ++
 .../wan/wancommand/WANCommandTestBase.java      |  513 ++
 ...anCommandCreateGatewayReceiverDUnitTest.java |  699 +++
 .../WanCommandCreateGatewaySenderDUnitTest.java |  763 +++
 ...WanCommandGatewayReceiverStartDUnitTest.java |  327 ++
 .../WanCommandGatewayReceiverStopDUnitTest.java |  332 ++
 .../WanCommandGatewaySenderStartDUnitTest.java  |  416 ++
 .../WanCommandGatewaySenderStopDUnitTest.java   |  367 ++
 .../wan/wancommand/WanCommandListDUnitTest.java |  403 ++
 .../WanCommandPauseResumeDUnitTest.java         |  716 +++
 .../wancommand/WanCommandStatusDUnitTest.java   |  582 ++
 .../management/WANManagementDUnitTest.java      |  525 ++
 .../ClusterConfigurationDUnitTest.java          | 1055 ++++
 .../pulse/TestRemoteClusterDUnitTest.java       |  274 +
 .../gemfire/codeAnalysis/excludedClasses.txt    |    2 +
 .../gemstone/gemfire/codeAnalysis/openBugs.txt  |   21 +
 .../sanctionedDataSerializables.txt             |   28 +
 .../codeAnalysis/sanctionedSerializables.txt    |    0
 gradle/dependency-versions.properties           |    1 +
 gradle/rat.gradle                               |    1 -
 settings.gradle                                 |    2 +
 777 files changed, 103442 insertions(+), 7041 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/cd3d95fd/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java
----------------------------------------------------------------------



[26/52] [abbrv] incubator-geode git commit: GEODE-787: MemoryIndexStore needs unit tests

Posted by ds...@apache.org.
GEODE-787: MemoryIndexStore needs unit tests

Minor refactoring and adding of unit tests
Long term plan is to remove the reference to the cache


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/45d5eda8
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/45d5eda8
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/45d5eda8

Branch: refs/heads/feature/GEODE-831
Commit: 45d5eda8f536734470ea82924679ed5e9e05b2c1
Parents: 2757f63
Author: Jason Huynh <hu...@gmail.com>
Authored: Mon Jan 18 17:03:30 2016 -0800
Committer: Jason Huynh <hu...@gmail.com>
Committed: Tue Jan 26 10:46:09 2016 -0800

----------------------------------------------------------------------
 .../query/internal/index/MemoryIndexStore.java  |  67 ++--
 .../internal/cache/GemFireCacheImpl.java        |   7 +
 .../index/MemoryIndexStoreJUnitTest.java        | 396 +++++++++++++++++++
 ...exStoreWithInplaceModificationJUnitTest.java |  54 +++
 4 files changed, 501 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/45d5eda8/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStore.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStore.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStore.java
index 41de5ea..20a7a4f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStore.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStore.java
@@ -27,6 +27,7 @@ import java.util.concurrent.ConcurrentNavigableMap;
 import java.util.concurrent.ConcurrentSkipListMap;
 import java.util.concurrent.atomic.AtomicInteger;
 
+import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.EntryDestroyedException;
 import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.RegionAttributes;
@@ -66,6 +67,7 @@ public class MemoryIndexStore implements IndexStore {
 
   private InternalIndexStatistics internalIndexStats;
 
+  private Cache cache;
   private Region region;
   private boolean indexOnRegionKeys;
   private boolean indexOnValues;
@@ -80,16 +82,22 @@ public class MemoryIndexStore implements IndexStore {
   
   public MemoryIndexStore(Region region,
       InternalIndexStatistics internalIndexStats) {
-    this.region = region;
-    RegionAttributes ra = region.getAttributes();
-    // Initialize the reverse-map if in-place modification is set by the
-    // application.
-    if (IndexManager.isObjectModificationInplace()) {
-      this.entryToValuesMap = new ConcurrentHashMap(ra.getInitialCapacity(),
-          ra.getLoadFactor(), ra.getConcurrencyLevel());
-    }
-    this.internalIndexStats = internalIndexStats;
+    this(region, internalIndexStats, GemFireCacheImpl.getInstance());
   }
+  
+  public MemoryIndexStore(Region region,
+	      InternalIndexStatistics internalIndexStats, Cache cache) {
+	    this.region = region;
+	    RegionAttributes ra = region.getAttributes();
+	    // Initialize the reverse-map if in-place modification is set by the
+	    // application.
+	    if (IndexManager.isObjectModificationInplace()) {
+	      this.entryToValuesMap = new ConcurrentHashMap(ra.getInitialCapacity(),
+	          ra.getLoadFactor(), ra.getConcurrencyLevel());
+	    }
+	    this.internalIndexStats = internalIndexStats;
+	    this.cache = cache;
+	  }
 
   @Override
   public void updateMapping(Object newKey, Object oldKey, RegionEntry entry, Object oldValue)
@@ -285,20 +293,13 @@ public class MemoryIndexStore implements IndexStore {
     }
   }
 
-  public boolean basicRemoveMapping(Object key, RegionEntry entry, boolean findOldKey)
+  protected boolean basicRemoveMapping(Object key, RegionEntry entry, boolean findOldKey)
       throws IMQException {
     boolean found = false;
     boolean possiblyAlreadyRemoved = false;
     try {
       boolean retry = false;
-      Object newKey;
-      if (IndexManager.isObjectModificationInplace()
-          && this.entryToValuesMap.containsKey(entry)) {
-        newKey = this.entryToValuesMap.get(entry);
-      }
-      else {
-        newKey = TypeUtils.indexKeyFor(key);
-      }
+      Object newKey = convertToIndexKey(key, entry);
       if (DefaultQuery.testHook != null) {
         DefaultQuery.testHook.doTestHook("ATTEMPT_REMOVE");
       }
@@ -392,6 +393,19 @@ public class MemoryIndexStore implements IndexStore {
     return found;
   }
 
+private Object convertToIndexKey(Object key, RegionEntry entry)
+		throws TypeMismatchException {
+	Object newKey;
+	if (IndexManager.isObjectModificationInplace()
+          && this.entryToValuesMap.containsKey(entry)) {
+        newKey = this.entryToValuesMap.get(entry);
+      }
+      else {
+        newKey = TypeUtils.indexKeyFor(key);
+      }
+	return newKey;
+}
+
   /**
    * Convert a RegionEntry or THashSet<RegionEntry> to be consistently a
    * Collection
@@ -589,15 +603,22 @@ public class MemoryIndexStore implements IndexStore {
     protected Iterator valuesIterator;
     protected Object currKey;
     protected Object currValue; //RegionEntry
-    final long iteratorStartTime = GemFireCacheImpl.getInstance().cacheTimeMillis();
-    protected MemoryIndexStoreEntry currentEntry = new MemoryIndexStoreEntry(iteratorStartTime);
+    final long iteratorStartTime;
+    protected MemoryIndexStoreEntry currentEntry;
     
     private MemoryIndexStoreIterator(Map submap,
                                      Object indexKey, Collection keysToRemove) {
-      this.map = submap;
-      this.indexKey = indexKey;
-      this.keysToRemove = keysToRemove;
+      this (submap, indexKey, keysToRemove, GemFireCacheImpl.getInstance().cacheTimeMillis());
     }
+    
+    private MemoryIndexStoreIterator(Map submap,
+            Object indexKey, Collection keysToRemove, long iteratorStartTime) {
+		this.map = submap;
+		this.indexKey = indexKey;
+		this.keysToRemove = keysToRemove;
+		this.iteratorStartTime = iteratorStartTime;
+		currentEntry = new MemoryIndexStoreEntry(iteratorStartTime);
+	}
 
     /**
      * This iterator iterates over the CSL map as well as on the collection of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/45d5eda8/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index 7565871..4e8f0c9 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -707,6 +707,13 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   public static GemFireCacheImpl getInstance() {
     return instance;
   }
+  
+  /* Used for testing, retain the old instance in the test and re-set the value when test completes*/
+  public static GemFireCacheImpl setInstanceForTests(GemFireCacheImpl cache) {
+    GemFireCacheImpl oldInstance = instance;
+	  instance = cache;
+	  return oldInstance;
+  }
 
   /**
    * Returns an existing instance. If a cache does not exist

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/45d5eda8/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreJUnitTest.java
new file mode 100644
index 0000000..0a4a13e
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreJUnitTest.java
@@ -0,0 +1,396 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.cache.query.internal.index;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+import static org.junit.Assert.fail;
+import static org.mockito.Matchers.any;
+import static org.mockito.Mockito.mock;
+import static org.mockito.Mockito.when;
+
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.Set;
+import java.util.stream.IntStream;
+
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.query.QueryService;
+import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
+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.test.junit.categories.UnitTest;
+
+@Category(UnitTest.class)
+public class MemoryIndexStoreJUnitTest {
+
+	Region region;
+	GemFireCacheImpl cache;
+	InternalIndexStatistics mockStats;
+	MemoryIndexStore store;
+	RegionEntry[] mockEntries;
+	int numMockEntries = 10;
+  GemFireCacheImpl actualInstance;
+  
+	public void subclassPreSetup() {
+		
+	}
+	
+	protected Region createRegion() {
+		return mock(LocalRegion.class);
+	}
+	
+	@Before
+	public void setup() {
+		subclassPreSetup();
+		region = createRegion();
+		cache = mock(GemFireCacheImpl.class);
+		actualInstance = GemFireCacheImpl.setInstanceForTests(cache);
+		mockStats = mock(AbstractIndex.InternalIndexStatistics.class);
+		
+		store = new MemoryIndexStore(region, mockStats);
+		store.setIndexOnValues(true);
+		mockEntries = new RegionEntry[numMockEntries];
+		IntStream.range(0, numMockEntries).forEach(i-> {
+			mockEntries[i] = createRegionEntry(i, new Object());
+		});
+	}
+	
+	@After
+	public void teardown() {
+	  GemFireCacheImpl.setInstanceForTests(actualInstance);
+	}
+	
+	@Test
+	public void testSizeOfStoreReturnsNumberOfKeysAndNotActualNumberOfValues() {
+		IntStream.range(0, 150).forEach(i -> {
+			try {
+				store.addMapping(i % 3, createRegionEntry(i, new Object()));
+			}
+			catch (Exception e) {
+				fail();
+			}
+		});
+		assertEquals(150, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testAddEnoughEntriesToCreateAConcurrentHashSet() {
+		IntStream.range(0, 150).forEach(i -> {
+			try {
+				store.addMapping(1, createRegionEntry(i, new Object()));
+			}
+			catch (Exception e) {
+				fail();
+			}
+		});
+		assertEquals(150, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testUpdateAgainstAConcurrentHashSet() throws Exception{
+		IntStream.range(0, 150).forEach(i -> {
+			try {
+				store.addMapping(1, createRegionEntry(1, new Object()));
+			}
+			catch (Exception e) {
+				fail();
+			}
+		});
+		RegionEntry entry = createRegionEntry(1, new Object());	
+		store.addMapping(1, entry);
+		store.updateMapping(2, 1, entry, entry.getValue(null));
+		assertEquals(151, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testCanAddObjectWithUndefinedKey() throws Exception {
+		store.addMapping(QueryService.UNDEFINED, mockEntries[0]);
+		assertEquals(1, numObjectsIterated(store.get(QueryService.UNDEFINED)));
+		assertEquals(0, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testCanAddManyObjectsWithUndefinedKey() throws Exception {
+		for (int i = 0; i < mockEntries.length; i++) {
+			store.addMapping(QueryService.UNDEFINED, mockEntries[i]);
+		}
+		assertEquals(mockEntries.length, numObjectsIterated(store.get(QueryService.UNDEFINED)));
+		//Undefined will not return without an explicit get for UNDEFINED);
+		assertEquals(0, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testIteratorWithStartInclusiveAndNoKeysToRemoveReturnsCorrectNumberOfResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(2, numObjectsIterated(store.iterator(numMockEntries - 2, true, null)));
+	}
+	
+	@Test
+	public void testIteratorWithStartExclusiveAndNoKeysToRemoveReturnsCorrectNumberOfResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(1, numObjectsIterated(store.iterator(numMockEntries - 2, false, null)));
+	}
+	
+	
+	@Test
+	public void testIteratorWithStartInclusiveAndKeyToRemoveReturnsCorrectNumberOfResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		Set keysToRemove = new HashSet();
+		keysToRemove.add("1");
+		assertEquals(9, numObjectsIterated(store.iterator(1, true, keysToRemove)));
+	}
+	
+	@Test
+	public void testIteratorWithStartExclusiveAndKeyToRemoveReturnsCorrectNumberOfResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		Set keysToRemove = new HashSet();
+		keysToRemove.add("1");
+		assertEquals(8, numObjectsIterated(store.iterator(1, false, keysToRemove)));
+	}
+	
+	@Test
+	public void testStartAndEndInclusiveReturnsCorrectResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(6, numObjectsIterated(store.iterator(1, true, 6, true, null)));
+	}
+	
+	@Test
+	public void testStartInclusiveAndEndExclusiveReturnsCorrectResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(5, numObjectsIterated(store.iterator(1, true, 6, false, null)));
+	}
+	
+	@Test
+	public void testStartExclusiveAndEndExclusiveReturnsCorrectResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(4, numObjectsIterated(store.iterator(1, false, 6, false, null)));
+	}
+	
+	@Test
+	public void testStartExclusiveAndEndInclusiveReturnsCorrectResults() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(5, numObjectsIterated(store.iterator(1, false, 6, true, null)));
+	}
+	
+	@Test
+	public void testStartIsNull() throws Exception {
+		addMockedEntries(numMockEntries);
+		assertEquals(6, numObjectsIterated(store.iterator(null, false, 6, false, null)));
+	}
+	
+	@Test
+	public void testDescendingIteratorReturnsExpectedOrderOfEntries() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		Iterator iteratorFirst = store.descendingIterator(null);
+		assertEquals(2, numObjectsIterated(iteratorFirst));
+		
+		Iterator iterator = store.descendingIterator(null);
+		iterator.hasNext();
+		assertEquals(mockEntry2, ((MemoryIndexStore.MemoryIndexStoreEntry)iterator.next()).getRegionEntry());
+		iterator.hasNext();
+		assertEquals(mockEntry1, ((MemoryIndexStore.MemoryIndexStoreEntry)iterator.next()).getRegionEntry());
+	}
+	
+	@Test
+	public void testDescendingIteratorWithRemovedKeysReturnsExpectedOrderOfEntries() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		RegionEntry mockEntry3 = mockEntries[2];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		store.addMapping("3", mockEntry3);
+		Set keysToRemove = new HashSet();
+		keysToRemove.add("2");
+		Iterator iteratorFirst = store.descendingIterator(keysToRemove);
+		assertEquals(2, numObjectsIterated(iteratorFirst));
+		
+		//keysToRemove has been modified by the store, we need to readd the key to remove
+		keysToRemove.add("2");
+		Iterator iterator = store.descendingIterator(keysToRemove);
+		iterator.hasNext();
+		assertEquals(mockEntry3, ((MemoryIndexStore.MemoryIndexStoreEntry)iterator.next()).getRegionEntry());
+		iterator.hasNext();
+		assertEquals(mockEntry1, ((MemoryIndexStore.MemoryIndexStoreEntry)iterator.next()).getRegionEntry());
+		assertFalse(iterator.hasNext());
+	}
+	
+	@Test
+	public void testDescendingIteratorWithMultipleRemovedKeysReturnsExpectedOrderOfEntries() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		RegionEntry mockEntry3 = mockEntries[2];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		store.addMapping("3", mockEntry3);
+		Set keysToRemove = new HashSet();
+		keysToRemove.add("2");
+		keysToRemove.add("1");
+		Iterator iteratorFirst = store.descendingIterator(keysToRemove);
+		assertEquals(1, numObjectsIterated(iteratorFirst));
+		
+		//keysToRemove has been modified by the store, we need to readd the key to remove
+		keysToRemove.add("2");
+		keysToRemove.add("1");
+		Iterator iterator = store.descendingIterator(keysToRemove);
+		iterator.hasNext();
+		assertEquals(mockEntry3, ((MemoryIndexStore.MemoryIndexStoreEntry)iterator.next()).getRegionEntry());
+		assertFalse(iterator.hasNext());
+	}
+	
+	@Test
+	public void testSizeWithKeyArgumentReturnsCorrectSize() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		assertEquals(1, store.size("1"));
+	}
+	
+	 @Test
+	  public void testGetReturnsExpectedIteratorValue() throws Exception {
+	    RegionEntry mockEntry1 = mockEntries[0];
+	    RegionEntry mockEntry2 = mockEntries[1];
+	    store.addMapping("1", mockEntry1);
+	    store.addMapping("2", mockEntry2);
+	    assertEquals(1, numObjectsIterated(store.get("1")));
+	  }
+	
+	@Test
+	public void testGetReturnsExpectedIteratorWithMultipleValues() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		RegionEntry mockEntry3 = mockEntries[2];
+		RegionEntry mockEntry4 = mockEntries[3];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("1", mockEntry2);
+		store.addMapping("1", mockEntry3);
+		store.addMapping("2", mockEntry4);
+		assertEquals(3, numObjectsIterated(store.get("1")));
+		assertEquals(4, numObjectsInStore(store));
+	}
+	
+	@Test
+	public void testGetWithIndexOnKeysReturnsExpectedIteratorValues() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.setIndexOnValues(false);
+		store.setIndexOnRegionKeys(true);
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		assertEquals(1, numObjectsIterated(store.get("1")));
+	}
+
+	@Test
+	public void testCorrectlyRemovesEntryProvidedTheWrongKey() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		store.removeMapping("1", mockEntry2);
+		assertEquals(1, numObjectsInStore(store));
+		assertTrue(objectContainedIn(store, mockEntry1));
+	}
+
+	@Test
+	public void testRemoveMappingRemovesFromBackingMap() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		store.removeMapping("1", mockEntry1);
+		assertEquals(1, numObjectsInStore(store));
+		assertTrue(objectContainedIn(store, mockEntry2));
+	}
+
+	@Test
+	public void testAddMappingAddsToBackingMap() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("2", mockEntry2);
+		assertEquals(2, numObjectsInStore(store));
+		assertTrue(objectContainedIn(store, mockEntry1));
+		assertTrue(objectContainedIn(store, mockEntry2));
+	}
+	
+	@Test
+	public void testClear() throws Exception {
+		RegionEntry mockEntry1 = mockEntries[0];
+		RegionEntry mockEntry2 = mockEntries[1];
+		store.addMapping("1", mockEntry1);
+		store.addMapping("1", mockEntry2);
+		store.clear();
+		assertEquals(0, numObjectsInStore(store));
+	}
+
+	private int numObjectsInStore(MemoryIndexStore store) {
+		Iterator iterator = store.iterator(null);
+		return numObjectsIterated(iterator);
+	}
+
+	private int numObjectsIterated(Iterator iterator) {
+		int count = 0;
+		while (iterator.hasNext()) {
+			iterator.next();
+			count++;
+		}
+		return count;
+	}
+
+	private boolean objectContainedIn(MemoryIndexStore store, Object o) {
+		Iterator iterator = store.valueToEntriesMap.values().iterator();
+		return objectContainedIn(iterator, o);
+	}
+	
+	private boolean objectContainedIn(Iterator iterator, Object o) {
+		while (iterator.hasNext()) {
+			if (iterator.next().equals(o)) {
+				return true;
+			}
+		}
+		return false;
+	}
+	
+	private void addMockedEntries(int numEntriesToAdd) {
+		IntStream.range(0, numEntriesToAdd).forEach(i -> {
+			try {
+				store.addMapping(mockEntries[i].getKey(), mockEntries[i]);
+			}
+			catch (Exception e) {
+				fail();
+			}
+		});
+	}
+	
+	private RegionEntry createRegionEntry(Object key, Object value) {
+		RegionEntry mockEntry = mock(RegionEntry.class);
+		when(mockEntry.getValue(any())).thenReturn(value);
+		when(mockEntry.getKey()).thenReturn(key);
+		return mockEntry;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/45d5eda8/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreWithInplaceModificationJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreWithInplaceModificationJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreWithInplaceModificationJUnitTest.java
new file mode 100644
index 0000000..79f8616
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/internal/index/MemoryIndexStoreWithInplaceModificationJUnitTest.java
@@ -0,0 +1,54 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.cache.query.internal.index;
+
+import static org.mockito.Mockito.mock;
+
+import static org.mockito.Mockito.when;
+
+import org.junit.After;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.internal.cache.LocalRegion;
+import com.gemstone.gemfire.test.junit.categories.UnitTest;
+
+@Category(UnitTest.class)
+public class MemoryIndexStoreWithInplaceModificationJUnitTest extends MemoryIndexStoreJUnitTest {
+	
+	public void subclassPreSetup() {
+		IndexManager.INPLACE_OBJECT_MODIFICATION_FOR_TEST = true;
+	}
+	
+	protected Region createRegion() {
+		Region region = mock(LocalRegion.class);
+		RegionAttributes ra = mock(RegionAttributes.class);
+		when(region.getAttributes()).thenReturn(ra);
+		when(ra.getInitialCapacity()).thenReturn(16);
+		when(ra.getLoadFactor()).thenReturn(.75f);
+		when(ra.getConcurrencyLevel()).thenReturn(16);
+		return region;
+	}
+	
+	@After
+	public void resetInplaceModification() {
+		IndexManager.INPLACE_OBJECT_MODIFICATION_FOR_TEST = false;
+	}
+	
+	
+}


[47/52] [abbrv] incubator-geode git commit: GEODE-862: Suppress suspect log statement

Posted by ds...@apache.org.
GEODE-862: Suppress suspect log statement

Added a TODO to the code to clean this up further. I believe the removeNotificationListener was being called as a form of tearDown near the end of the test but there are no registered NotificationListeners and that's not what the test is testing.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/a5437b2f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/a5437b2f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/a5437b2f

Branch: refs/heads/feature/GEODE-831
Commit: a5437b2fb1f379cd7713ef708095ba7b0ca2cfb9
Parents: c194f76
Author: Kirk Lund <kl...@pivotal.io>
Authored: Thu Jan 28 10:43:41 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Thu Jan 28 10:48:27 2016 -0800

----------------------------------------------------------------------
 .../gemstone/gemfire/management/DistributedSystemDUnitTest.java   | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a5437b2f/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
index 1a52f9b..f234e34 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
@@ -452,7 +452,8 @@ public class DistributedSystemDUnitTest extends ManagementTestBase {
           } catch (InstanceNotFoundException e) {
             getLogWriter().error(e);
           } catch (ListenerNotFoundException e) {
-            getLogWriter().error(e);
+            // TODO: apparently there is never a notification listener on any these mbeans at this point 
+            // fix this test so it doesn't hit these unexpected exceptions -- getLogWriter().error(e);
           }
         }
       }


[42/52] [abbrv] incubator-geode git commit: GEODE-852: copyGemFireVersionFile needs to make sure gemfire-core builds first

Posted by ds...@apache.org.
GEODE-852: copyGemFireVersionFile needs to make sure gemfire-core builds first

* This closes #81 (klund)
* Renamed copyPulsePropFile to copyGemFireVersionFile (klund)


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/6df4b8ff
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/6df4b8ff
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/6df4b8ff

Branch: refs/heads/feature/GEODE-831
Commit: 6df4b8ffd54dfc0ab191740fcebcb11ad14f0d7a
Parents: c01506b
Author: Jinmei Liao <ji...@pivotal.io>
Authored: Wed Jan 27 10:45:47 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Thu Jan 28 09:35:08 2016 -0800

----------------------------------------------------------------------
 gemfire-pulse/build.gradle | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/6df4b8ff/gemfire-pulse/build.gradle
----------------------------------------------------------------------
diff --git a/gemfire-pulse/build.gradle b/gemfire-pulse/build.gradle
index 78043cd..3d694e5 100755
--- a/gemfire-pulse/build.gradle
+++ b/gemfire-pulse/build.gradle
@@ -83,6 +83,7 @@ sourceSets {
 }
 
 task copyGemFireVersionFile(type: Copy) {
+  inputs.dir project(':gemfire-core').sourceSets.main.output
   from project(':gemfire-core').buildDir.absolutePath + "/generated-resources/main/com/gemstone/gemfire/internal/GemFireVersion.properties"
   into generatedResources
 }


[50/52] [abbrv] incubator-geode git commit: added copyright

Posted by ds...@apache.org.
added copyright


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/7f267337
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/7f267337
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/7f267337

Branch: refs/heads/feature/GEODE-831
Commit: 7f267337abbe870cc43d7441dce5f6c2314e614d
Parents: 0964395
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Jan 28 11:46:04 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Jan 28 11:46:04 2016 -0800

----------------------------------------------------------------------
 .../internal/offheap/FreeListManagerTest.java       | 16 ++++++++++++++++
 1 file changed, 16 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/7f267337/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
index 3b519a0..bdd97fc 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.internal.offheap;
 
 import static org.junit.Assert.*;


[52/52] [abbrv] incubator-geode git commit: more test coverage

Posted by ds...@apache.org.
more test coverage


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/4c951aff
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/4c951aff
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/4c951aff

Branch: refs/heads/feature/GEODE-831
Commit: 4c951aff4403275b4af6b9de11cb97d9d1af8235
Parents: cd3d95f
Author: Darrel Schneider <ds...@pivotal.io>
Authored: Thu Jan 28 17:15:20 2016 -0800
Committer: Darrel Schneider <ds...@pivotal.io>
Committed: Thu Jan 28 17:15:20 2016 -0800

----------------------------------------------------------------------
 .../internal/offheap/FreeListManager.java       |  19 +-
 .../internal/offheap/FreeListManagerTest.java   | 186 ++++++++++++++++++-
 .../offheap/OffHeapHelperJUnitTest.java         |   2 +-
 3 files changed, 192 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4c951aff/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
index 586689f..951e8a8 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/offheap/FreeListManager.java
@@ -132,7 +132,7 @@ public class FreeListManager {
     long total = 0;
     Fragment[] tmp = new Fragment[slabs.length];
     for (int i=0; i < slabs.length; i++) {
-      tmp[i] = new Fragment(slabs[i].getMemoryAddress(), slabs[i].getSize());
+      tmp[i] = createFragment(slabs[i].getMemoryAddress(), slabs[i].getSize());
       total += slabs[i].getSize();
     }
     this.fragmentList = new CopyOnWriteArrayList<Fragment>(tmp);
@@ -142,6 +142,14 @@ public class FreeListManager {
   }
 
   /**
+   * Create and return a Fragment.
+   * This method exists so that tests can override it.
+   */
+  protected Fragment createFragment(long addr, int size) {
+    return new Fragment(addr, size);
+  }
+  
+  /**
    * Fills all fragments with a fill used for data integrity validation 
    * if fill validation is enabled.
    */
@@ -404,7 +412,7 @@ public class FreeListManager {
           long addr = sorted[i];
           if (addr == 0L) continue;
           int addrSize = Chunk.getSize(addr);
-          Fragment f = new Fragment(addr, addrSize);
+          Fragment f = createFragment(addr, addrSize);
           if (addrSize >= chunkSize) {
             result = true;
           }
@@ -425,7 +433,7 @@ public class FreeListManager {
 
         this.ma.getStats().setLargestFragment(largestFragment);
         this.ma.getStats().setFragments(tmp.size());        
-        updateFragmentation();
+        updateFragmentation(largestFragment);
 
         return result;
       } // sync
@@ -455,12 +463,11 @@ public class FreeListManager {
     }
   }
   
-  private void updateFragmentation() {      
-    long freeSize = this.ma.getStats().getFreeMemory();
+  private void updateFragmentation(long largestFragment) {      
+    long freeSize = getFreeMemory();
 
     // Calculate free space fragmentation only if there is free space available.
     if(freeSize > 0) {
-      long largestFragment = this.ma.getStats().getLargestFragment();
       long numerator = freeSize - largestFragment;
 
       double percentage = (double) numerator / (double) freeSize;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4c951aff/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
index bdd97fc..5f3a546 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/FreeListManagerTest.java
@@ -22,6 +22,7 @@ import static com.googlecode.catchexception.CatchException.*;
 import static org.assertj.core.api.Assertions.assertThat;
 
 import java.util.ArrayList;
+import java.util.List;
 
 import org.junit.After;
 import org.junit.AfterClass;
@@ -42,7 +43,6 @@ public class FreeListManagerTest {
 
   private final int DEFAULT_SLAB_SIZE = 1024*1024*5;
   private final SimpleMemoryAllocatorImpl ma = mock(SimpleMemoryAllocatorImpl.class);
-  private final UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
   private final OffHeapMemoryStats stats = mock(OffHeapMemoryStats.class);
   private FreeListManager freeListManager;
   
@@ -67,8 +67,13 @@ public class FreeListManagerTest {
     }
   }
   
+  private static FreeListManager createFreeListManager(SimpleMemoryAllocatorImpl ma, AddressableMemoryChunk[] slabs) {
+    return new TestableFreeListManager(ma, slabs);
+  }
+  
   private void setUpSingleSlabManager() {
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {slab});
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {slab});
   }
 
   @Test
@@ -238,7 +243,8 @@ public class FreeListManagerTest {
   public void allocateFromMultipleSlabs() {
     int SMALL_SLAB = 16;
     int MEDIUM_SLAB = 128;
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(MEDIUM_SLAB), 
@@ -255,7 +261,8 @@ public class FreeListManagerTest {
   public void compactWithLargeChunkSizeReturnsFalse() {
     int SMALL_SLAB = 16;
     int MEDIUM_SLAB = 128;
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(MEDIUM_SLAB), 
@@ -276,7 +283,8 @@ public class FreeListManagerTest {
   public void compactWithChunkSizeOfMaxSlabReturnsTrue() {
     int SMALL_SLAB = 16;
     int MEDIUM_SLAB = 128;
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(MEDIUM_SLAB), 
@@ -291,14 +299,15 @@ public class FreeListManagerTest {
     }
     
     assertThat(this.freeListManager.compact(DEFAULT_SLAB_SIZE)).isTrue();
-    assertThat(this.freeListManager.getFragmentList()).hasSize(4);
+    //assertThat(this.freeListManager.getFragmentList()).hasSize(4); // TODO intermittently fails because Fragments may be merged
   }
   
   @Test
   public void compactWithLiveChunks() {
     int SMALL_SLAB = 16;
     int MEDIUM_SLAB = 128;
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(MEDIUM_SLAB), 
@@ -345,7 +354,8 @@ public class FreeListManagerTest {
   public void allocationsThatLeaveLessThanMinChunkSizeFreeInAFragment() {
     int SMALL_SLAB = 16;
     int MEDIUM_SLAB = 128;
-    this.freeListManager = new FreeListManager(ma, new UnsafeMemoryChunk[] {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(SMALL_SLAB), 
         new UnsafeMemoryChunk(MEDIUM_SLAB), 
@@ -459,4 +469,164 @@ public class FreeListManagerTest {
   public void offHeapAlignmentOf256IsLegal() {
     FreeListManager.verifyOffHeapAlignment(256);
   }
+  
+  @Test
+  public void okToReuseNull() {
+    setUpSingleSlabManager();
+    assertThat(this.freeListManager.okToReuse(null)).isTrue();
+  }
+  
+  @Test
+  public void okToReuseSameSlabs() {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    UnsafeMemoryChunk[] slabs = new UnsafeMemoryChunk[] {slab};
+    this.freeListManager = createFreeListManager(ma, slabs);
+    assertThat(this.freeListManager.okToReuse(slabs)).isTrue();
+  }
+  @Test
+  public void notOkToReuseDifferentSlabs() {
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    UnsafeMemoryChunk[] slabs = new UnsafeMemoryChunk[] {slab};
+    this.freeListManager = createFreeListManager(ma, slabs);
+    UnsafeMemoryChunk[] slabs2 = new UnsafeMemoryChunk[] {slab};
+    assertThat(this.freeListManager.okToReuse(slabs2)).isFalse();
+  }
+  @Test
+  public void firstSlabAlwaysLargest() {
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {
+        new UnsafeMemoryChunk(10), 
+        new UnsafeMemoryChunk(100)});
+    assertThat(this.freeListManager.getLargestSlabSize()).isEqualTo(10);
+  }
+
+  @Test
+  public void findSlab() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    assertThat(this.freeListManager.findSlab(address)).isEqualTo(0);
+    assertThat(this.freeListManager.findSlab(address+9)).isEqualTo(0);
+    catchException(this.freeListManager).findSlab(address-1);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage("could not find a slab for addr " + (address-1));
+    catchException(this.freeListManager).findSlab(address+10);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage("could not find a slab for addr " + (address+10));
+  }
+  
+  @Test
+  public void findSecondSlab() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    UnsafeMemoryChunk slab = new UnsafeMemoryChunk(DEFAULT_SLAB_SIZE);
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {slab, chunk});
+    assertThat(this.freeListManager.findSlab(address)).isEqualTo(1);
+    assertThat(this.freeListManager.findSlab(address+9)).isEqualTo(1);
+    catchException(this.freeListManager).findSlab(address-1);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage("could not find a slab for addr " + (address-1));
+    catchException(this.freeListManager).findSlab(address+10);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage("could not find a slab for addr " + (address+10));
+  }
+  
+  @Test
+  public void validateAddressWithinSlab() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address, -1)).isTrue();
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address+9, -1)).isTrue();
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address-1, -1)).isFalse();
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address+10, -1)).isFalse();
+  }
+  
+  @Test
+  public void validateAddressAndSizeWithinSlab() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address, 1)).isTrue();
+    assertThat(this.freeListManager.validateAddressAndSizeWithinSlab(address, 10)).isTrue();
+    catchException(this.freeListManager).validateAddressAndSizeWithinSlab(address, 0);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage(" address 0x" + Long.toString(address+0-1, 16) + " does not address the original slab memory");
+    catchException(this.freeListManager).validateAddressAndSizeWithinSlab(address, 11);
+    assertThat((Exception)caughtException())
+    .isExactlyInstanceOf(IllegalStateException.class)
+    .hasMessage(" address 0x" + Long.toString(address+11-1, 16) + " does not address the original slab memory");
+  }
+  
+  @Test
+  public void descriptionOfOneSlab() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    long endAddress = address+10;
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    StringBuilder sb = new StringBuilder();
+    this.freeListManager.getSlabDescriptions(sb);
+    assertThat(sb.toString()).isEqualTo("[" + Long.toString(address, 16) + ".." + Long.toString(endAddress, 16) + "] ");
+  }
+
+  @Test
+  public void orderBlocksContainsFragment() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(10);
+    long address = chunk.getMemoryAddress();
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    List<MemoryBlock> ob = this.freeListManager.getOrderedBlocks();
+    assertThat(ob).hasSize(1);
+    assertThat(ob.get(0).getMemoryAddress()).isEqualTo(address);
+    assertThat(ob.get(0).getBlockSize()).isEqualTo(10);
+  }
+  
+  @Test
+  public void orderBlocksContainsTinyFree() {
+    UnsafeMemoryChunk chunk = new UnsafeMemoryChunk(64);
+    long address = chunk.getMemoryAddress();
+    this.freeListManager = createFreeListManager(ma, new UnsafeMemoryChunk[] {chunk});
+    Chunk c = this.freeListManager.allocate(24);
+    Chunk c2 = this.freeListManager.allocate(24);
+    Chunk.release(c.getMemoryAddress(), this.freeListManager);
+
+    List<MemoryBlock> ob = this.freeListManager.getOrderedBlocks();
+    assertThat(ob).hasSize(3);
+//    assertThat(ob.get(0).getMemoryAddress()).isEqualTo(address);
+  }
+
+  /**
+   * Just like Fragment except that the first time allocate is called
+   * it returns false indicating that the allocate failed.
+   * In a real system this would only happen if a concurrent allocate
+   * happened. This allows better code coverage.
+   */
+  private static class TestableFragment extends Fragment {
+    private boolean allocateCalled = false;
+    public TestableFragment(long addr, int size) {
+      super(addr, size);
+    }
+    @Override
+    public boolean allocate(int oldOffset, int newOffset) {
+      if (!allocateCalled) {
+        allocateCalled = true;
+        return false;
+      }
+      return super.allocate(oldOffset, newOffset);
+    }
+  }
+  private static class TestableFreeListManager extends FreeListManager {
+    @Override
+    protected Fragment createFragment(long addr, int size) {
+      return new TestableFragment(addr, size);
+    }
+
+    public TestableFreeListManager(SimpleMemoryAllocatorImpl ma, AddressableMemoryChunk[] slabs) {
+      super(ma, slabs);
+    }
+    
+  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4c951aff/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
index fd0eb4f..6c037e1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapHelperJUnitTest.java
@@ -129,7 +129,7 @@ public class OffHeapHelperJUnitTest extends AbstractStoredObjectTestBase {
   }
 
   private GemFireChunk createChunk(byte[] v, boolean isSerialized, boolean isCompressed) {
-    GemFireChunk chunk = (GemFireChunk) ma.allocateAndInitialize(v, isSerialized, isCompressed, GemFireChunk.TYPE);
+    GemFireChunk chunk = (GemFireChunk) ma.allocateAndInitialize(v, isSerialized, isCompressed);
     return chunk;
   }
 


[22/52] [abbrv] incubator-geode git commit: GEODE-781: Check for existence of settings.xml

Posted by ds...@apache.org.
GEODE-781: Check for existence of settings.xml

If the jenkins user does not have a settings.xml file the build
will fail.  This adds a check to only read values from the file
if it is present on the filesystem.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/42dd4a79
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/42dd4a79
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/42dd4a79

Branch: refs/heads/feature/GEODE-831
Commit: 42dd4a79b8e2e60e9d05fd065c63da2247b86d5c
Parents: ed31351
Author: Anthony Baker <ab...@apache.org>
Authored: Mon Jan 25 11:40:38 2016 -0800
Committer: Anthony Baker <ab...@apache.org>
Committed: Mon Jan 25 12:38:58 2016 -0800

----------------------------------------------------------------------
 build.gradle | 20 +++++++++++---------
 1 file changed, 11 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/42dd4a79/build.gradle
----------------------------------------------------------------------
diff --git a/build.gradle b/build.gradle
index 4222275..28519dd 100755
--- a/build.gradle
+++ b/build.gradle
@@ -557,15 +557,17 @@ subprojects {
   afterEvaluate {
     if (!isReleaseVersion && System.env.USER == 'jenkins') {
       def settingsXml = new File(System.getProperty('user.home'), '.m2/settings.xml')
-      def snapshotCreds = new XmlSlurper().parse(settingsXml).servers.server.find { server ->
-        server.id.text() == 'apache.snapshots.https'
-      }
-
-      if (snapshotCreds != null) {
-        tasks.uploadArchives.doFirst {
-          repositories().withType(MavenDeployer).each { repo ->
-            repo.snapshotRepository.authentication.userName = snapshotCreds.username.text()
-            repo.snapshotRepository.authentication.password = snapshotCreds.password.text()
+      if (settingsXml.exists()) {
+        def snapshotCreds = new XmlSlurper().parse(settingsXml).servers.server.find { server ->
+          server.id.text() == 'apache.snapshots.https'
+        }
+  
+        if (snapshotCreds != null) {
+          tasks.uploadArchives.doFirst {
+            repositories().withType(MavenDeployer).each { repo ->
+              repo.snapshotRepository.authentication.userName = snapshotCreds.username.text()
+              repo.snapshotRepository.authentication.password = snapshotCreds.password.text()
+            }
           }
         }
       }


[41/52] [abbrv] incubator-geode git commit: GEODE-871: build-up of sockets in TIME_WAIT on locator machine

Posted by ds...@apache.org.
GEODE-871: build-up of sockets in TIME_WAIT on locator machine

This change-set alters the client to abort its TCP/IP connection to
the locator by enabling SO_LINGER and setting the timeout to zero
before it closes the connection.  The Locator closes its connection
first, which puts it into TIME_WAIT.  The client then aborts the
connection, which cleans up the Locator's TIME_WAIT connection.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/c01506b2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/c01506b2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/c01506b2

Branch: refs/heads/feature/GEODE-831
Commit: c01506b27e233538ecc2ca5a81ca113c15cc388a
Parents: 8a8571f
Author: Bruce Schuchardt <bs...@pivotal.io>
Authored: Thu Jan 28 08:31:19 2016 -0800
Committer: Bruce Schuchardt <bs...@pivotal.io>
Committed: Thu Jan 28 08:33:13 2016 -0800

----------------------------------------------------------------------
 .../distributed/internal/tcpserver/TcpClient.java  |  8 +++++---
 .../distributed/internal/tcpserver/TcpServer.java  | 17 +----------------
 2 files changed, 6 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c01506b2/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpClient.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpClient.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpClient.java
index 47f50b3..836416b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpClient.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpClient.java
@@ -167,14 +167,15 @@ public class TcpClient {
       }
       return null;
     } finally {
-      if (out != null) {
-        out.close();
-      }
       try {
+        sock.setSoLinger(true, 0); // initiate an abort on close to shut down the locator's socket
         sock.close();
       } catch(Exception e) {
         logger.error("Error closing socket ", e);
       }
+      if (out != null) {
+        out.close();
+      }
     }
   }
 
@@ -223,6 +224,7 @@ public class TcpClient {
       }
     } finally {
       try {
+        sock.setSoLinger(true, 0); // initiate an abort on close to shut down the server's socket
         sock.close();
       } catch(Exception e) {
         logger.error("Error closing socket ", e);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c01506b2/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServer.java
index f52b9ab..e5ad416 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/tcpserver/TcpServer.java
@@ -398,7 +398,6 @@ public class TcpServer {
             DataSerializer.writeObject(response, output);
 
             output.flush();
-            output.close();
           }
 
           handler.endResponse(request,startTime);
@@ -467,24 +466,10 @@ public class TcpServer {
             t.printStackTrace();
           }
         } finally {
-          // Normal path closes input first, so let's do that here...
-          if (input != null) {
-            try {
-              input.close();
-            } catch (IOException e) {
-              log.warn(
-                "Exception closing input stream", e);
-            }
-          }
-
-          // Closing the ObjectInputStream is supposed to close
-          // the underlying InputStream, but we do it here just for
-          // good measure. Closing a closed socket is a no-op.
           try {
             sock.close();
           } catch (IOException e) {
-            log.warn(
-                "Exception closing socket", e);
+            // ignore
           }
         }
       }


[27/52] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into wan_cq_donation

Posted by ds...@apache.org.
Merge remote-tracking branch 'origin/develop' into wan_cq_donation


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/8d8b5736
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/8d8b5736
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/8d8b5736

Branch: refs/heads/feature/GEODE-831
Commit: 8d8b5736d5c0d0307142cc86de7ecbfde095770d
Parents: 0979936 45d5eda
Author: Dan Smith <up...@apache.org>
Authored: Tue Jan 26 11:02:12 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 11:02:12 2016 -0800

----------------------------------------------------------------------
 LICENSE                                         |   80 +-
 NOTICE                                          |    2 +-
 README.md                                       |    7 +-
 build.gradle                                    |   22 +-
 gemfire-assembly/src/main/dist/LICENSE          |   81 +-
 gemfire-assembly/src/main/dist/NOTICE           |    2 +-
 .../SharedConfigurationEndToEndDUnitTest.java   |    9 +-
 gemfire-core/build.gradle                       |    4 +-
 .../cache/client/ClientCacheFactory.java        |    2 +-
 .../cache/client/internal/ConnectionImpl.java   |    5 +-
 .../query/internal/index/MemoryIndexStore.java  |   67 +-
 .../internal/membership/NetView.java            |   10 +
 .../gms/messenger/JGroupsMessenger.java         |   38 +-
 .../membership/gms/messenger/Transport.java     |   34 +-
 .../gemfire/internal/cache/AbstractRegion.java  |    5 +-
 .../internal/cache/GemFireCacheImpl.java        |  103 +-
 .../gemfire/internal/cache/LocalRegion.java     |    3 +-
 .../gemfire/internal/cache/PoolManagerImpl.java |    4 +-
 .../internal/i18n/ParentLocalizedStrings.java   |    9 +-
 .../com/gemstone/gemfire/TXExpiryJUnitTest.java |    5 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |    7 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |    7 +-
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |    9 +-
 .../ClientServerRegisterInterestsDUnitTest.java |   13 +-
 .../internal/AutoConnectionSourceDUnitTest.java |   11 +-
 .../CacheServerSSLConnectionDUnitTest.java      |    7 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |   16 +-
 .../cache/client/internal/LocatorTestBase.java  |   11 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |    7 +-
 .../pooling/ConnectionManagerJUnitTest.java     |    5 +-
 .../management/MemoryThresholdsDUnitTest.java   |   13 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |   13 +-
 .../management/ResourceManagerDUnitTest.java    |    9 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |    3 +-
 .../PartitionRegionHelperDUnitTest.java         |   11 +-
 .../gemfire/cache/query/QueryTestUtils.java     |    5 +-
 .../query/cq/dunit/CqQueryTestListener.java     |    5 +-
 .../query/dunit/CompactRangeIndexDUnitTest.java |   11 +-
 .../cache/query/dunit/CqTimeTestListener.java   |    5 +-
 .../cache/query/dunit/GroupByDUnitImpl.java     |    7 +-
 .../dunit/GroupByPartitionedQueryDUnitTest.java |    7 +-
 .../query/dunit/GroupByQueryDUnitTest.java      |    7 +-
 .../cache/query/dunit/HashIndexDUnitTest.java   |    9 +-
 .../cache/query/dunit/HelperTestCase.java       |    9 +-
 .../dunit/NonDistinctOrderByDUnitImpl.java      |    7 +-
 .../NonDistinctOrderByPartitionedDUnitTest.java |    7 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    |   13 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   11 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |   13 +-
 .../QueryParamsAuthorizationDUnitTest.java      |    7 +-
 .../QueryUsingFunctionContextDUnitTest.java     |    7 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |    7 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   34 +-
 ...esourceManagerWithQueryMonitorDUnitTest.java |   11 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |    7 +-
 .../IndexCreationDeadLockJUnitTest.java         |    3 +-
 .../IndexMaintenanceAsynchJUnitTest.java        |    5 +-
 .../functional/LikePredicateJUnitTest.java      |    3 +-
 .../internal/ExecutionContextJUnitTest.java     |    3 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |    5 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |    9 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |    9 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |   12 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |   12 +-
 .../index/CopyOnReadIndexDUnitTest.java         |   11 +-
 .../index/IndexCreationInternalsJUnitTest.java  |    3 +-
 .../index/IndexMaintainceJUnitTest.java         |    3 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |    9 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |    9 +-
 .../index/MemoryIndexStoreJUnitTest.java        |  396 +++++
 ...exStoreWithInplaceModificationJUnitTest.java |   54 +
 .../index/MultiIndexCreationDUnitTest.java      |   11 +-
 .../index/PutAllWithIndexPerfDUnitTest.java     |    5 +-
 .../PRBasicIndexCreationDUnitTest.java          |   11 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   11 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |    9 +-
 .../partitioned/PRBasicQueryDUnitTest.java      |    5 +-
 .../PRBasicRemoveIndexDUnitTest.java            |    5 +-
 .../PRColocatedEquiJoinDUnitTest.java           |    5 +-
 .../partitioned/PRInvalidQueryDUnitTest.java    |    5 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |    9 +-
 .../PRQueryCacheClosedJUnitTest.java            |    3 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |   16 +-
 .../query/partitioned/PRQueryDUnitTest.java     |    7 +-
 .../query/partitioned/PRQueryPerfDUnitTest.java |    5 +-
 .../PRQueryRegionCloseDUnitTest.java            |    9 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |    9 +-
 .../PRQueryRegionDestroyedJUnitTest.java        |    3 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    |   11 +-
 .../snapshot/ParallelSnapshotDUnitTest.java     |    7 +-
 .../snapshot/SnapshotByteArrayDUnitTest.java    |    5 +-
 .../cache/snapshot/SnapshotDUnitTest.java       |    5 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |    5 +-
 .../gemfire/cache30/Bug34387DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug34948DUnitTest.java      |   26 +-
 .../gemfire/cache30/Bug35214DUnitTest.java      |   19 +-
 .../gemfire/cache30/Bug38013DUnitTest.java      |   25 +-
 .../gemfire/cache30/Bug38741DUnitTest.java      |    7 +-
 .../gemfire/cache30/CacheCloseDUnitTest.java    |   16 +-
 .../gemfire/cache30/CacheLoaderTestCase.java    |   14 +-
 .../gemfire/cache30/CacheMapTxnDUnitTest.java   |   26 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |    7 +-
 .../cache30/CacheSerializableRunnable.java      |   10 +-
 .../cache30/CacheStatisticsDUnitTest.java       |   13 +-
 .../gemstone/gemfire/cache30/CacheTestCase.java |    7 +-
 .../gemfire/cache30/CacheXml30DUnitTest.java    |   12 +-
 .../gemfire/cache30/CacheXml41DUnitTest.java    |   34 +-
 .../gemfire/cache30/CacheXml45DUnitTest.java    |    7 +-
 .../gemfire/cache30/CacheXml51DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml57DUnitTest.java    |   18 +-
 .../gemfire/cache30/CacheXml60DUnitTest.java    |   16 +-
 .../gemfire/cache30/CacheXml61DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml66DUnitTest.java    |    5 +-
 .../gemfire/cache30/CacheXml81DUnitTest.java    |    2 +-
 .../gemfire/cache30/CacheXml90DUnitTest.java    |   17 +-
 .../cache30/CachedAllEventsDUnitTest.java       |   16 +-
 .../gemfire/cache30/CallbackArgDUnitTest.java   |   29 +-
 .../cache30/CertifiableTestCacheListener.java   |    5 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   27 +-
 .../gemfire/cache30/ClearMultiVmDUnitTest.java  |   33 +-
 .../cache30/ClientMembershipDUnitTest.java      |   11 +-
 .../ClientRegisterInterestDUnitTest.java        |    7 +-
 .../cache30/ClientServerCCEDUnitTest.java       |    9 +-
 .../gemfire/cache30/ClientServerTestCase.java   |    3 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   11 +-
 .../gemfire/cache30/DiskRegionDUnitTest.java    |   45 +-
 .../gemfire/cache30/DiskRegionTestImpl.java     |   19 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   37 +-
 ...tedAckOverflowRegionCCEOffHeapDUnitTest.java |    3 +-
 ...tributedAckPersistentRegionCCEDUnitTest.java |   15 +-
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedAckRegionCCEDUnitTest.java       |   15 +-
 ...DistributedAckRegionCCEOffHeapDUnitTest.java |    3 +-
 ...istributedAckRegionCompressionDUnitTest.java |    3 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   34 +-
 .../DistributedAckRegionOffHeapDUnitTest.java   |    3 +-
 .../DistributedMulticastRegionDUnitTest.java    |   11 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |   11 +-
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java |    3 +-
 .../DistributedNoAckRegionDUnitTest.java        |   17 +-
 .../DistributedNoAckRegionOffHeapDUnitTest.java |    3 +-
 .../gemfire/cache30/DynamicRegionDUnitTest.java |   21 +-
 .../gemfire/cache30/GlobalLockingDUnitTest.java |   15 +-
 .../cache30/GlobalRegionCCEDUnitTest.java       |    7 +-
 .../GlobalRegionCCEOffHeapDUnitTest.java        |    3 +-
 .../gemfire/cache30/GlobalRegionDUnitTest.java  |   25 +-
 .../cache30/GlobalRegionOffHeapDUnitTest.java   |    3 +-
 .../cache30/LRUEvictionControllerDUnitTest.java |    5 +-
 .../gemfire/cache30/LocalRegionDUnitTest.java   |   17 +-
 .../gemfire/cache30/MultiVMRegionTestCase.java  |   17 +-
 .../OffHeapLRUEvictionControllerDUnitTest.java  |    3 +-
 .../PRBucketSynchronizationDUnitTest.java       |    7 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   22 +-
 ...tionedRegionMembershipListenerDUnitTest.java |    3 +-
 .../PartitionedRegionOffHeapDUnitTest.java      |    3 +-
 .../cache30/PreloadedRegionTestCase.java        |   14 +-
 .../gemfire/cache30/ProxyDUnitTest.java         |   34 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |   23 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   28 +-
 .../gemfire/cache30/PutAllMultiVmDUnitTest.java |   25 +-
 .../gemfire/cache30/QueueMsgDUnitTest.java      |   28 +-
 .../cache30/RRSynchronizationDUnitTest.java     |    7 +-
 .../gemfire/cache30/ReconnectDUnitTest.java     |   13 +-
 .../cache30/RegionExpirationDUnitTest.java      |   14 +-
 .../RegionMembershipListenerDUnitTest.java      |   28 +-
 .../RegionReliabilityListenerDUnitTest.java     |   26 +-
 .../cache30/RegionReliabilityTestCase.java      |   64 +-
 .../gemfire/cache30/RegionTestCase.java         |    9 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |   22 +-
 .../gemfire/cache30/RequiredRolesDUnitTest.java |   28 +-
 .../cache30/RolePerformanceDUnitTest.java       |   15 +-
 .../gemfire/cache30/SearchAndLoadDUnitTest.java |   22 +-
 .../gemfire/cache30/SlowRecDUnitTest.java       |   35 +-
 .../gemfire/cache30/TXDistributedDUnitTest.java |   11 +-
 .../gemfire/cache30/TXOrderDUnitTest.java       |   41 +-
 .../cache30/TXRestrictionsDUnitTest.java        |   14 +-
 .../gemfire/cache30/TestCacheCallback.java      |    5 +-
 .../distributed/DistributedMemberDUnitTest.java |   26 +-
 .../distributed/DistributedSystemDUnitTest.java |    7 +-
 .../distributed/HostedLocatorsDUnitTest.java    |    9 +-
 .../gemfire/distributed/LocatorDUnitTest.java   |   13 +-
 .../gemfire/distributed/LocatorJUnitTest.java   |    5 +-
 .../gemfire/distributed/RoleDUnitTest.java      |   16 +-
 .../distributed/SystemAdminDUnitTest.java       |    5 +-
 .../distributed/internal/Bug40751DUnitTest.java |    9 +-
 .../ConsoleDistributionManagerDUnitTest.java    |    9 +-
 .../internal/DistributionAdvisorDUnitTest.java  |   13 +-
 .../internal/DistributionManagerDUnitTest.java  |    9 +-
 .../internal/ProductUseLogDUnitTest.java        |   11 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   11 +-
 .../internal/locks/CollaborationJUnitTest.java  |    5 +-
 .../internal/membership/NetViewJUnitTest.java   |   19 +-
 .../membership/gms/MembershipManagerHelper.java |    5 +-
 .../gms/fd/GMSHealthMonitorJUnitTest.java       |   26 +-
 .../gms/membership/GMSJoinLeaveJUnitTest.java   |   36 +-
 .../messenger/GMSQuorumCheckerJUnitTest.java    |    4 +-
 .../messenger/JGroupsMessengerJUnitTest.java    |   61 +-
 .../gms/mgr/GMSMembershipManagerJUnitTest.java  |   21 +-
 .../StreamingOperationManyDUnitTest.java        |   20 +-
 .../StreamingOperationOneDUnitTest.java         |   23 +-
 .../TcpServerBackwardCompatDUnitTest.java       |    7 +-
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java |    5 +-
 .../gemfire/disttx/DistTXDebugDUnitTest.java    |    9 +-
 .../disttx/DistTXPersistentDebugDUnitTest.java  |    2 +-
 .../disttx/DistributedTransactionDUnitTest.java |    7 +-
 .../ClassNotFoundExceptionDUnitTest.java        |    9 +-
 .../gemfire/internal/JSSESocketJUnitTest.java   |    3 +-
 .../gemfire/internal/JarDeployerDUnitTest.java  |    7 +-
 .../internal/PdxDeleteFieldDUnitTest.java       |    7 +-
 .../gemfire/internal/PdxRenameDUnitTest.java    |    7 +-
 .../gemfire/internal/SocketCloserJUnitTest.java |    5 +-
 .../gemfire/internal/cache/BackupDUnitTest.java |   13 +-
 .../internal/cache/Bug33359DUnitTest.java       |    8 +-
 .../internal/cache/Bug33726DUnitTest.java       |    8 +-
 .../internal/cache/Bug37241DUnitTest.java       |    8 +-
 .../internal/cache/Bug37377DUnitTest.java       |   11 +-
 .../internal/cache/Bug39079DUnitTest.java       |    7 +-
 .../internal/cache/Bug40299DUnitTest.java       |   11 +-
 .../internal/cache/Bug40632DUnitTest.java       |    9 +-
 .../internal/cache/Bug41091DUnitTest.java       |    7 +-
 .../internal/cache/Bug41733DUnitTest.java       |   15 +-
 .../internal/cache/Bug41957DUnitTest.java       |   29 +-
 .../internal/cache/Bug42055DUnitTest.java       |    9 +-
 .../internal/cache/Bug45164DUnitTest.java       |    7 +-
 .../internal/cache/Bug45934DUnitTest.java       |    7 +-
 .../internal/cache/Bug47667DUnitTest.java       |    7 +-
 .../internal/cache/CacheAdvisorDUnitTest.java   |   30 +-
 .../internal/cache/ClearDAckDUnitTest.java      |   11 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |    6 +-
 .../cache/ClientServerGetAllDUnitTest.java      |   33 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |  995 ++++++------
 .../ClientServerTransactionCCEDUnitTest.java    |    5 +-
 .../cache/ClientServerTransactionDUnitTest.java |   11 +-
 .../ConcurrentDestroySubRegionDUnitTest.java    |    9 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |   11 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |    3 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |    3 +-
 .../cache/ConnectDisconnectDUnitTest.java       |   13 +-
 .../internal/cache/DeltaFaultInDUnitTest.java   |    9 +-
 .../cache/DeltaPropagationDUnitTest.java        |    9 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |    7 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |    9 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   15 +-
 .../cache/DiskRegionClearJUnitTest.java         |    3 +-
 .../internal/cache/DiskRegionJUnitTest.java     |    5 +-
 ...DistrbutedRegionProfileOffHeapDUnitTest.java |    5 +-
 .../cache/DistributedCacheTestCase.java         |   23 +-
 .../internal/cache/EventTrackerDUnitTest.java   |    7 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |    7 +-
 .../internal/cache/EvictionTestBase.java        |   11 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |    9 +-
 .../internal/cache/GIIDeltaDUnitTest.java       |   13 +-
 .../internal/cache/GIIFlowControlDUnitTest.java |    9 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |   25 +-
 .../internal/cache/HABug36773DUnitTest.java     |    7 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |    7 +-
 .../cache/IncrementalBackupDUnitTest.java       |   11 +-
 .../cache/InterruptClientServerDUnitTest.java   |    9 +-
 .../internal/cache/InterruptsDUnitTest.java     |    9 +-
 .../internal/cache/IteratorDUnitTest.java       |    7 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   14 +-
 .../internal/cache/MapInterface2JUnitTest.java  |    3 +-
 .../cache/NetSearchMessagingDUnitTest.java      |   11 +-
 .../cache/OffHeapEvictionDUnitTest.java         |    7 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |    3 +-
 .../gemfire/internal/cache/OplogJUnitTest.java  |    5 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |    7 +-
 .../internal/cache/PRBadToDataDUnitTest.java    |    9 +-
 .../cache/PartitionListenerDUnitTest.java       |    9 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |    7 +-
 .../PartitionedRegionAsSubRegionDUnitTest.java  |    5 +-
 ...gionBucketCreationDistributionDUnitTest.java |   22 +-
 .../PartitionedRegionCacheCloseDUnitTest.java   |    9 +-
 ...rtitionedRegionCacheXMLExampleDUnitTest.java |    5 +-
 .../PartitionedRegionCreationDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionDUnitTestCase.java   |    5 +-
 ...rtitionedRegionDelayedRecoveryDUnitTest.java |    9 +-
 .../PartitionedRegionDestroyDUnitTest.java      |   11 +-
 .../PartitionedRegionEntryCountDUnitTest.java   |    9 +-
 .../PartitionedRegionEvictionDUnitTest.java     |   11 +-
 .../cache/PartitionedRegionHADUnitTest.java     |   13 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |   22 +-
 .../PartitionedRegionInvalidateDUnitTest.java   |    7 +-
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |    7 +-
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java |    3 +-
 .../PartitionedRegionMultipleDUnitTest.java     |    8 +-
 ...rtitionedRegionOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/PartitionedRegionPRIDDUnitTest.java   |    9 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |    9 +-
 ...artitionedRegionRedundancyZoneDUnitTest.java |    9 +-
 ...tionedRegionSerializableObjectJUnitTest.java |    2 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |    9 +-
 ...RegionSingleHopWithServerGroupDUnitTest.java |    9 +-
 .../cache/PartitionedRegionSizeDUnitTest.java   |   13 +-
 .../cache/PartitionedRegionStatsDUnitTest.java  |    7 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |    5 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |   14 +-
 .../internal/cache/PutAllDAckDUnitTest.java     |   16 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   25 +-
 .../cache/RemoteTransactionDUnitTest.java       |   13 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   12 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   10 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   23 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |    3 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |    7 +-
 .../internal/cache/SizingFlagDUnitTest.java     |    9 +-
 .../internal/cache/SystemFailureDUnitTest.java  |    7 +-
 .../cache/TXReservationMgrJUnitTest.java        |    3 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |    7 +-
 .../control/RebalanceOperationDUnitTest.java    |   11 +-
 ...egionOverflowAsyncRollingOpLogJUnitTest.java |    5 +-
 ...RegionOverflowSyncRollingOpLogJUnitTest.java |    5 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |    3 +-
 .../cache/execute/Bug51193DUnitTest.java        |    7 +-
 .../ClientServerFunctionExecutionDUnitTest.java |    5 +-
 .../execute/ColocationFailoverDUnitTest.java    |    9 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |    9 +-
 .../FunctionExecution_ExceptionDUnitTest.java   |    9 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |   11 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |   11 +-
 .../execute/LocalDataSetIndexingDUnitTest.java  |    5 +-
 .../LocalFunctionExecutionDUnitTest.java        |    9 +-
 .../MemberFunctionExecutionDUnitTest.java       |    9 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |    7 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |    9 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |    7 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |   11 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |    5 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |    5 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |    5 +-
 .../cache/execute/PRClientServerTestBase.java   |   11 +-
 .../cache/execute/PRColocationDUnitTest.java    |   12 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |    7 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |   13 +-
 .../PRFunctionExecutionTimeOutDUnitTest.java    |    7 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |    7 +-
 .../execute/PRPerformanceTestDUnitTest.java     |    7 +-
 .../cache/execute/PRTransactionDUnitTest.java   |    3 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |    3 +-
 .../functions/DistributedRegionFunction.java    |    5 +-
 .../internal/cache/functions/TestFunction.java  |    5 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |    3 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |    5 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |    5 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |    7 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |    7 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |    7 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |    7 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |    7 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |    7 +-
 .../cache/ha/HAConflationDUnitTest.java         |    7 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |    7 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |    7 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |    9 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   11 +-
 .../internal/cache/ha/HAGIIDUnitTest.java       |    9 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |    3 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |    7 +-
 .../internal/cache/ha/HARegionDUnitTest.java    |    7 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |    7 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |    3 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |    6 +-
 .../ha/OperationsPropagationDUnitTest.java      |    7 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |    7 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |    7 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   29 +-
 .../cache/partitioned/Bug39356DUnitTest.java    |    9 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |    7 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |    9 +-
 .../partitioned/ElidedPutAllDUnitTest.java      |    7 +-
 .../partitioned/PartitionResolverDUnitTest.java |    7 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |    4 +-
 ...rtitionedRegionMetaDataCleanupDUnitTest.java |    9 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |    9 +-
 ...tentColocatedPartitionedRegionDUnitTest.java |   11 +-
 .../PersistentPartitionedRegionDUnitTest.java   |   15 +-
 .../PersistentPartitionedRegionTestBase.java    |    9 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |    9 +-
 .../cache/partitioned/ShutdownAllDUnitTest.java |   15 +-
 ...treamingPartitionOperationManyDUnitTest.java |   29 +-
 ...StreamingPartitionOperationOneDUnitTest.java |   34 +-
 .../fixed/FixedPartitioningDUnitTest.java       |    7 +-
 .../fixed/FixedPartitioningTestBase.java        |    9 +-
 ...ngWithColocationAndPersistenceDUnitTest.java |    5 +-
 .../PersistentRVVRecoveryDUnitTest.java         |   11 +-
 .../PersistentRecoveryOrderDUnitTest.java       |   11 +-
 ...rsistentRecoveryOrderOldConfigDUnitTest.java |    7 +-
 .../PersistentReplicatedTestBase.java           |    7 +-
 .../internal/cache/tier/Bug40396DUnitTest.java  |    9 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |    7 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |    7 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |    7 +-
 .../CacheServerMaxConnectionsJUnitTest.java     |    5 +-
 .../cache/tier/sockets/CacheServerTestUtil.java |    3 +-
 .../CacheServerTransactionsDUnitTest.java       |    7 +-
 .../tier/sockets/ClearPropagationDUnitTest.java |    7 +-
 .../tier/sockets/ClientConflationDUnitTest.java |    7 +-
 .../sockets/ClientHealthMonitorJUnitTest.java   |    5 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |    7 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   11 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |    7 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |    5 +-
 .../DataSerializerPropogationDUnitTest.java     |    7 +-
 .../DestroyEntryPropagationDUnitTest.java       |    7 +-
 .../sockets/DurableClientBug39997DUnitTest.java |    7 +-
 .../DurableClientQueueSizeDUnitTest.java        |    7 +-
 .../DurableClientReconnectAutoDUnitTest.java    |    5 +-
 .../DurableClientReconnectDUnitTest.java        |    7 +-
 .../sockets/DurableClientStatsDUnitTest.java    |    7 +-
 .../sockets/DurableRegistrationDUnitTest.java   |    7 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |    7 +-
 .../sockets/EventIDVerificationDUnitTest.java   |    7 +-
 .../EventIDVerificationInP2PDUnitTest.java      |    7 +-
 .../ForceInvalidateEvictionDUnitTest.java       |    7 +-
 ...ForceInvalidateOffHeapEvictionDUnitTest.java |    3 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |    7 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |    2 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |    5 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |    7 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |    7 +-
 .../InstantiatorPropagationDUnitTest.java       |    7 +-
 .../tier/sockets/InterestListDUnitTest.java     |    9 +-
 .../sockets/InterestListEndpointDUnitTest.java  |    9 +-
 .../sockets/InterestListFailoverDUnitTest.java  |    7 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |    6 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |    7 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |    7 +-
 .../sockets/NewRegionAttributesDUnitTest.java   |    7 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |    4 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |    5 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |    7 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |    7 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |    7 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |    7 +-
 .../sockets/ReliableMessagingDUnitTest.java     |    7 +-
 .../sockets/UnregisterInterestDUnitTest.java    |    7 +-
 .../sockets/UpdatePropagationDUnitTest.java     |    7 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |    7 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |    7 +-
 .../versions/RegionVersionVectorJUnitTest.java  |    3 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |    7 +-
 .../AsyncEventQueueStatsDUnitTest.java          |    3 +-
 .../ConcurrentAsyncEventQueueDUnitTest.java     |    3 +-
 .../CompressionCacheConfigDUnitTest.java        |    7 +-
 .../CompressionCacheListenerDUnitTest.java      |    9 +-
 ...ompressionCacheListenerOffHeapDUnitTest.java |    3 +-
 .../CompressionRegionConfigDUnitTest.java       |   11 +-
 .../CompressionRegionFactoryDUnitTest.java      |    9 +-
 .../CompressionRegionOperationsDUnitTest.java   |    9 +-
 ...ressionRegionOperationsOffHeapDUnitTest.java |    3 +-
 .../compression/CompressionStatsDUnitTest.java  |    9 +-
 .../internal/jta/dunit/CommitThread.java        |   28 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   42 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |   44 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   11 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |   43 +-
 .../internal/jta/dunit/RollbackThread.java      |   28 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   26 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   51 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |   31 +-
 .../DistributedSystemLogFileJUnitTest.java      |    5 +-
 .../logging/LocatorLogFileJUnitTest.java        |    5 +-
 .../logging/MergeLogFilesJUnitTest.java         |    3 +-
 .../internal/offheap/OffHeapRegionBase.java     |    5 +-
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    |    5 +-
 .../process/LocalProcessLauncherDUnitTest.java  |    7 +-
 .../statistics/StatisticsDUnitTest.java         |    9 +-
 .../statistics/ValueMonitorJUnitTest.java       |    4 +-
 .../management/CacheManagementDUnitTest.java    |    8 +-
 .../management/ClientHealthStatsDUnitTest.java  |   13 +-
 .../management/CompositeTypeTestDUnitTest.java  |    5 +-
 .../management/DLockManagementDUnitTest.java    |    5 +-
 .../management/DiskManagementDUnitTest.java     |    9 +-
 .../management/DistributedSystemDUnitTest.java  |    9 +-
 .../management/LocatorManagementDUnitTest.java  |    7 +-
 .../gemstone/gemfire/management/MBeanUtil.java  |    5 +-
 .../gemfire/management/ManagementTestBase.java  |   13 +-
 .../MemberMBeanAttributesDUnitTest.java         |    5 +-
 .../management/OffHeapManagementDUnitTest.java  |    9 +-
 .../gemfire/management/QueryDataDUnitTest.java  |    8 +-
 .../management/RegionManagementDUnitTest.java   |    5 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |    7 +-
 .../stats/DistributedSystemStatsDUnitTest.java  |    5 +-
 .../internal/cli/CliUtilDUnitTest.java          |   11 +-
 .../cli/commands/CliCommandTestBase.java        |    7 +-
 .../cli/commands/ConfigCommandsDUnitTest.java   |   11 +-
 ...eateAlterDestroyRegionCommandsDUnitTest.java |   10 +-
 .../cli/commands/DeployCommandsDUnitTest.java   |    8 +-
 .../commands/DiskStoreCommandsDUnitTest.java    |   11 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |   10 +-
 .../commands/GemfireDataCommandsDUnitTest.java  |   11 +-
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |   21 +-
 .../cli/commands/IndexCommandsDUnitTest.java    |   10 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |   15 +-
 .../ListAndDescribeRegionDUnitTest.java         |    6 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |   33 +-
 .../cli/commands/MemberCommandsDUnitTest.java   |    6 +-
 .../MiscellaneousCommandsDUnitTest.java         |    9 +-
 ...laneousCommandsExportLogsPart1DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart2DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |    6 +-
 ...laneousCommandsExportLogsPart4DUnitTest.java |    6 +-
 .../cli/commands/QueueCommandsDUnitTest.java    |    8 +-
 .../SharedConfigurationCommandsDUnitTest.java   |   11 +-
 .../cli/commands/ShowDeadlockDUnitTest.java     |    8 +-
 .../cli/commands/ShowMetricsDUnitTest.java      |    8 +-
 .../cli/commands/ShowStackTraceDUnitTest.java   |    6 +-
 .../cli/commands/UserCommandsDUnitTest.java     |    5 +-
 .../SharedConfigurationDUnitTest.java           |   11 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |   13 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |    4 +-
 .../internal/pulse/TestHeapDUnitTest.java       |    3 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |   10 +-
 .../ClientsWithVersioningRetryDUnitTest.java    |    9 +-
 .../pdx/DistributedSystemIdDUnitTest.java       |    9 +-
 .../pdx/JSONPdxClientServerDUnitTest.java       |    8 +-
 .../pdx/PDXAsyncEventQueueDUnitTest.java        |    7 +-
 .../gemfire/pdx/PdxClientServerDUnitTest.java   |    9 +-
 .../pdx/PdxDeserializationDUnitTest.java        |    9 +-
 .../gemfire/pdx/PdxSerializableDUnitTest.java   |    9 +-
 .../gemfire/pdx/PdxTypeExportDUnitTest.java     |    5 +-
 .../gemfire/pdx/VersionClassLoader.java         |   16 +-
 .../gemfire/redis/RedisDistDUnitTest.java       |   11 +-
 .../web/controllers/RestAPITestBase.java        |    7 +-
 .../security/ClientAuthenticationDUnitTest.java |    6 +-
 .../security/ClientAuthorizationDUnitTest.java  |    6 +-
 .../security/ClientAuthorizationTestBase.java   |    4 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |    3 +-
 .../DeltaClientAuthorizationDUnitTest.java      |    3 +-
 .../DeltaClientPostAuthorizationDUnitTest.java  |    5 +-
 .../security/P2PAuthenticationDUnitTest.java    |    7 +-
 .../gemfire/security/SecurityTestUtil.java      |    3 +-
 .../gemfire/test/dunit/AsyncInvocation.java     |  215 +++
 .../gemstone/gemfire/test/dunit/DUnitEnv.java   |   79 +
 .../gemfire/test/dunit/DistributedTestCase.java | 1435 +++++++++++++++++
 .../com/gemstone/gemfire/test/dunit/Host.java   |  212 +++
 .../gemfire/test/dunit/RMIException.java        |  170 +++
 .../gemfire/test/dunit/RepeatableRunnable.java  |   29 +
 .../test/dunit/SerializableCallable.java        |   70 +
 .../test/dunit/SerializableCallableIF.java      |   24 +
 .../test/dunit/SerializableRunnable.java        |   92 ++
 .../test/dunit/SerializableRunnableIF.java      |   23 +
 .../com/gemstone/gemfire/test/dunit/VM.java     | 1345 ++++++++++++++++
 .../test/dunit/standalone/DUnitLauncher.java    |    9 +-
 .../test/dunit/standalone/RemoteDUnitVM.java    |   41 +-
 .../dunit/standalone/StandAloneDUnitEnv.java    |    3 +-
 .../test/dunit/tests/BasicDUnitTest.java        |   37 +-
 .../gemfire/test/dunit/tests/VMDUnitTest.java   |   12 +-
 .../src/test/java/dunit/AsyncInvocation.java    |  217 ---
 gemfire-core/src/test/java/dunit/DUnitEnv.java  |   80 -
 .../test/java/dunit/DistributedTestCase.java    | 1438 ------------------
 gemfire-core/src/test/java/dunit/Host.java      |  210 ---
 .../src/test/java/dunit/RMIException.java       |  170 ---
 .../src/test/java/dunit/RepeatableRunnable.java |   29 -
 .../test/java/dunit/SerializableCallable.java   |   70 -
 .../test/java/dunit/SerializableRunnable.java   |   92 --
 gemfire-core/src/test/java/dunit/VM.java        | 1347 ----------------
 .../src/test/java/hydra/MethExecutor.java       |    2 +-
 .../LuceneFunctionReadPathDUnitTest.java        |    7 +-
 gemfire-pulse/build.gradle                      |   16 +-
 .../tools/pulse/testbed/driver/PulseUITest.java |    5 -
 .../website/content/community/index.html        |   40 +-
 gradle/dependency-versions.properties           |    1 +
 gradle/rat.gradle                               |    1 -
 571 files changed, 7891 insertions(+), 6903 deletions(-)
----------------------------------------------------------------------



[45/52] [abbrv] incubator-geode git commit: Merge remote-tracking branch 'origin/wan_cq_donation' into develop

Posted by ds...@apache.org.
Merge remote-tracking branch 'origin/wan_cq_donation' into develop


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/46ae4ef5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/46ae4ef5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/46ae4ef5

Branch: refs/heads/feature/GEODE-831
Commit: 46ae4ef56d3548de033d3e20ff1e786520528b28
Parents: c01506b 441c29c
Author: Dan Smith <up...@apache.org>
Authored: Thu Jan 28 09:56:14 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Thu Jan 28 09:56:14 2016 -0800

----------------------------------------------------------------------
 gemfire-assembly/build.gradle                   |   10 +
 gemfire-cq/build.gradle                         |   22 +
 .../cache/client/internal/CloseCQOp.java        |   72 +
 .../cache/client/internal/CreateCQOp.java       |  163 +
 .../cache/client/internal/CreateCQWithIROp.java |   92 +
 .../cache/client/internal/GetDurableCQsOp.java  |  135 +
 .../client/internal/ServerCQProxyImpl.java      |  111 +
 .../gemfire/cache/client/internal/StopCQOp.java |   72 +
 .../cache/query/internal/cq/ClientCQImpl.java   |  615 +++
 .../internal/cq/CqAttributesMutatorImpl.java    |   68 +
 .../cache/query/internal/cq/CqConflatable.java  |  223 +
 .../cache/query/internal/cq/CqEventImpl.java    |  162 +
 .../cache/query/internal/cq/CqListenerImpl.java |   56 +
 .../cache/query/internal/cq/CqQueryImpl.java    |  383 ++
 .../query/internal/cq/CqServiceFactoryImpl.java |   69 +
 .../cache/query/internal/cq/CqServiceImpl.java  | 2087 +++++++
 .../internal/cq/CqServiceStatisticsImpl.java    |  100 +
 .../query/internal/cq/CqServiceVsdStats.java    |  411 ++
 .../query/internal/cq/CqStatisticsImpl.java     |   75 +
 .../cache/query/internal/cq/ServerCQImpl.java   |  655 +++
 .../tier/sockets/command/BaseCQCommand.java     |   59 +
 .../cache/tier/sockets/command/CloseCQ.java     |  131 +
 .../cache/tier/sockets/command/ExecuteCQ.java   |  168 +
 .../cache/tier/sockets/command/ExecuteCQ61.java |  220 +
 .../cache/tier/sockets/command/GetCQStats.java  |  100 +
 .../tier/sockets/command/GetDurableCQs.java     |  143 +
 .../cache/tier/sockets/command/MonitorCQ.java   |  100 +
 .../cache/tier/sockets/command/StopCQ.java      |  135 +
 ...cache.query.internal.cq.spi.CqServiceFactory |   15 +
 .../gemfire/cache/query/cq/CQJUnitTest.java     |  150 +
 .../cache/query/cq/dunit/CqDataDUnitTest.java   | 1162 ++++
 .../dunit/CqDataOptimizedExecuteDUnitTest.java  |   54 +
 .../cq/dunit/CqDataUsingPoolDUnitTest.java      | 1567 ++++++
 ...qDataUsingPoolOptimizedExecuteDUnitTest.java |   53 +
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   | 1044 ++++
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      | 1004 ++++
 .../cache/query/cq/dunit/CqQueryDUnitTest.java  | 4004 ++++++++++++++
 .../dunit/CqQueryOptimizedExecuteDUnitTest.java |  311 ++
 .../cq/dunit/CqQueryUsingPoolDUnitTest.java     | 3322 +++++++++++
 ...QueryUsingPoolOptimizedExecuteDUnitTest.java |   50 +
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java | 1139 ++++
 ...ltSetUsingPoolOptimizedExecuteDUnitTest.java |  231 +
 .../cache/query/cq/dunit/CqStateDUnitTest.java  |  134 +
 .../cache/query/cq/dunit/CqStatsDUnitTest.java  |  441 ++
 .../dunit/CqStatsOptimizedExecuteDUnitTest.java |   51 +
 .../cq/dunit/CqStatsUsingPoolDUnitTest.java     |  452 ++
 ...StatsUsingPoolOptimizedExecuteDUnitTest.java |   51 +
 .../query/cq/dunit/CqTimeTestListener.java      |  266 +
 .../PartitionedRegionCqQueryDUnitTest.java      | 1788 ++++++
 ...dRegionCqQueryOptimizedExecuteDUnitTest.java |  246 +
 .../query/cq/dunit/PrCqUsingPoolDUnitTest.java  | 2029 +++++++
 .../PrCqUsingPoolOptimizedExecuteDUnitTest.java |   50 +
 .../cache/query/dunit/PdxQueryCQDUnitTest.java  |  702 +++
 .../cache/query/dunit/PdxQueryCQTestBase.java   |  494 ++
 .../dunit/QueryIndexUpdateRIDUnitTest.java      |  819 +++
 .../query/dunit/QueryMonitorDUnitTest.java      | 1296 +++++
 .../cache/snapshot/ClientSnapshotDUnitTest.java |  284 +
 .../AnalyzeCQSerializablesJUnitTest.java        |   79 +
 .../cache/PRDeltaPropagationDUnitTest.java      | 1212 ++++
 .../internal/cache/PutAllCSDUnitTest.java       | 4419 +++++++++++++++
 .../cache/RemoteCQTransactionDUnitTest.java     | 1121 ++++
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  820 +++
 .../cache/ha/HADispatcherDUnitTest.java         |  695 +++
 .../sockets/ClientToServerDeltaDUnitTest.java   | 1037 ++++
 .../DeltaPropagationWithCQDUnitTest.java        |  341 ++
 ...ToRegionRelationCQRegistrationDUnitTest.java |  786 +++
 .../sockets/DurableClientCrashDUnitTest.java    |   99 +
 .../sockets/DurableClientNetDownDUnitTest.java  |   80 +
 .../sockets/DurableClientSimpleDUnitTest.java   | 3404 ++++++++++++
 .../tier/sockets/DurableClientTestCase.java     | 2089 +++++++
 .../CacheServerManagementDUnitTest.java         |  571 ++
 .../cli/commands/ClientCommandsDUnitTest.java   | 1443 +++++
 .../DurableClientCommandsDUnitTest.java         |  433 ++
 .../internal/pulse/TestCQDUnitTest.java         |  147 +
 .../internal/pulse/TestClientsDUnitTest.java    |  108 +
 .../internal/pulse/TestServerDUnitTest.java     |   99 +
 .../ClientAuthorizationTwoDUnitTest.java        |  245 +
 .../security/ClientAuthzObjectModDUnitTest.java |  416 ++
 .../ClientCQPostAuthorizationDUnitTest.java     |  522 ++
 .../ClientPostAuthorizationDUnitTest.java       |  398 ++
 .../gemfire/security/MultiuserAPIDUnitTest.java |  391 ++
 .../MultiuserDurableCQAuthzDUnitTest.java       |  489 ++
 .../gemfire/codeAnalysis/excludedClasses.txt    |    2 +
 .../gemstone/gemfire/codeAnalysis/openBugs.txt  |   21 +
 .../sanctionedDataSerializables.txt             |    4 +
 .../codeAnalysis/sanctionedSerializables.txt    |    1 +
 .../tier/sockets/durablecq-client-cache.xml     |   37 +
 .../tier/sockets/durablecq-server-cache.xml     |   32 +
 gemfire-wan/build.gradle                        |   22 +
 .../client/internal/GatewaySenderBatchOp.java   |  313 ++
 .../cache/client/internal/SenderProxy.java      |   43 +
 .../internal/locator/wan/LocatorDiscovery.java  |  227 +
 .../internal/locator/wan/LocatorHelper.java     |  143 +
 .../locator/wan/LocatorJoinMessage.java         |  105 +
 .../wan/LocatorMembershipListenerImpl.java      |  230 +
 .../locator/wan/RemoteLocatorJoinRequest.java   |   87 +
 .../locator/wan/RemoteLocatorJoinResponse.java  |   89 +
 .../locator/wan/RemoteLocatorPingRequest.java   |   56 +
 .../locator/wan/RemoteLocatorPingResponse.java  |   55 +
 .../locator/wan/RemoteLocatorRequest.java       |   66 +
 .../locator/wan/RemoteLocatorResponse.java      |   74 +
 .../internal/locator/wan/WANFactoryImpl.java    |   74 +
 .../locator/wan/WanLocatorDiscovererImpl.java   |  138 +
 .../cache/wan/AbstractRemoteGatewaySender.java  |  169 +
 .../cache/wan/GatewayReceiverFactoryImpl.java   |  147 +
 .../internal/cache/wan/GatewayReceiverImpl.java |  253 +
 .../wan/GatewaySenderEventRemoteDispatcher.java |  767 +++
 .../cache/wan/GatewaySenderFactoryImpl.java     |  389 ++
 .../wan/parallel/ParallelGatewaySenderImpl.java |  267 +
 ...rentParallelGatewaySenderEventProcessor.java |   67 +
 ...moteParallelGatewaySenderEventProcessor.java |  122 +
 ...urrentSerialGatewaySenderEventProcessor.java |   45 +
 ...RemoteSerialGatewaySenderEventProcessor.java |   50 +
 .../wan/serial/SerialGatewaySenderImpl.java     |  260 +
 ...ternal.locator.wan.LocatorMembershipListener |   15 +
 ...ne.gemfire.internal.cache.wan.spi.WANFactory |   15 +
 .../cache/CacheXml70GatewayDUnitTest.java       |  243 +
 .../cache/CacheXml80GatewayDUnitTest.java       |   77 +
 .../AnalyzeWANSerializablesJUnitTest.java       |   91 +
 .../internal/cache/UpdateVersionDUnitTest.java  |  960 ++++
 .../gemfire/internal/cache/wan/WANTestBase.java | 5178 ++++++++++++++++++
 ...oncurrentParallelGatewaySenderDUnitTest.java |  860 +++
 ...ntParallelGatewaySenderOffHeapDUnitTest.java |   32 +
 ...allelGatewaySenderOperation_1_DUnitTest.java |  848 +++
 ...allelGatewaySenderOperation_2_DUnitTest.java |  579 ++
 ...tSerialGatewaySenderOperationsDUnitTest.java |  111 +
 ...GatewaySenderOperationsOffHeapDUnitTest.java |   32 +
 .../ConcurrentWANPropogation_1_DUnitTest.java   |  608 ++
 .../ConcurrentWANPropogation_2_DUnitTest.java   |  485 ++
 .../cache/wan/disttx/DistTXWANDUnitTest.java    |  209 +
 .../CommonParallelGatewaySenderDUnitTest.java   |  481 ++
 ...onParallelGatewaySenderOffHeapDUnitTest.java |   32 +
 ...wWANConcurrencyCheckForDestroyDUnitTest.java |  526 ++
 .../cache/wan/misc/PDXNewWanDUnitTest.java      |  787 +++
 ...dRegion_ParallelWANPersistenceDUnitTest.java |  752 +++
 ...dRegion_ParallelWANPropogationDUnitTest.java | 1132 ++++
 .../SenderWithTransportFilterDUnitTest.java     |  274 +
 ...downAllPersistentGatewaySenderDUnitTest.java |  205 +
 .../wan/misc/WANConfigurationJUnitTest.java     |  617 +++
 .../wan/misc/WANLocatorServerDUnitTest.java     |  193 +
 .../cache/wan/misc/WANSSLDUnitTest.java         |  151 +
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |  557 ++
 .../cache/wan/misc/WanValidationsDUnitTest.java | 1678 ++++++
 ...GatewaySenderOperationsOffHeapDUnitTest.java |   34 +
 ...ewaySenderQueueOverflowOffHeapDUnitTest.java |   34 +
 .../ParallelWANConflationOffHeapDUnitTest.java  |   34 +
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   34 +
 ...ropogationConcurrentOpsOffHeapDUnitTest.java |   34 +
 .../ParallelWANPropogationOffHeapDUnitTest.java |   34 +
 ...erialGatewaySenderQueueOffHeapDUnitTest.java |   34 +
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   34 +
 .../SerialWANPropogationOffHeapDUnitTest.java   |   34 +
 ...ation_PartitionedRegionOffHeapDUnitTest.java |   34 +
 ...arallelGatewaySenderOperationsDUnitTest.java | 1984 +++++++
 ...llelGatewaySenderQueueOverflowDUnitTest.java |  531 ++
 .../ParallelWANConflationDUnitTest.java         |  496 ++
 ...ersistenceEnabledGatewaySenderDUnitTest.java | 1823 ++++++
 ...llelWANPropagationClientServerDUnitTest.java |  114 +
 ...lelWANPropagationConcurrentOpsDUnitTest.java |  290 +
 .../ParallelWANPropagationDUnitTest.java        | 1448 +++++
 ...ParallelWANPropagationLoopBackDUnitTest.java |  425 ++
 .../wan/parallel/ParallelWANStatsDUnitTest.java |  632 +++
 ...tewaySenderDistributedDeadlockDUnitTest.java |  407 ++
 ...rialGatewaySenderEventListenerDUnitTest.java |  390 ++
 .../SerialGatewaySenderOperationsDUnitTest.java |  602 ++
 .../SerialGatewaySenderQueueDUnitTest.java      |  337 ++
 ...ersistenceEnabledGatewaySenderDUnitTest.java |  602 ++
 .../SerialWANPropagationLoopBackDUnitTest.java  |  538 ++
 .../serial/SerialWANPropogationDUnitTest.java   | 1602 ++++++
 ...NPropogation_PartitionedRegionDUnitTest.java |  439 ++
 .../SerialWANPropogationsFeatureDUnitTest.java  |  373 ++
 .../wan/serial/SerialWANStatsDUnitTest.java     |  596 ++
 .../wan/wancommand/WANCommandTestBase.java      |  513 ++
 ...anCommandCreateGatewayReceiverDUnitTest.java |  699 +++
 .../WanCommandCreateGatewaySenderDUnitTest.java |  763 +++
 ...WanCommandGatewayReceiverStartDUnitTest.java |  327 ++
 .../WanCommandGatewayReceiverStopDUnitTest.java |  332 ++
 .../WanCommandGatewaySenderStartDUnitTest.java  |  416 ++
 .../WanCommandGatewaySenderStopDUnitTest.java   |  367 ++
 .../wan/wancommand/WanCommandListDUnitTest.java |  403 ++
 .../WanCommandPauseResumeDUnitTest.java         |  716 +++
 .../wancommand/WanCommandStatusDUnitTest.java   |  582 ++
 .../management/WANManagementDUnitTest.java      |  525 ++
 .../ClusterConfigurationDUnitTest.java          | 1055 ++++
 .../pulse/TestRemoteClusterDUnitTest.java       |  274 +
 .../gemfire/codeAnalysis/excludedClasses.txt    |    2 +
 .../gemstone/gemfire/codeAnalysis/openBugs.txt  |   21 +
 .../sanctionedDataSerializables.txt             |   28 +
 .../codeAnalysis/sanctionedSerializables.txt    |    0
 settings.gradle                                 |    2 +
 190 files changed, 94367 insertions(+)
----------------------------------------------------------------------



[16/52] [abbrv] incubator-geode git commit: GEODE-819: Fix test that was missed because closed build ignores assembly

Posted by ds...@apache.org.
GEODE-819: Fix test that was missed because closed build ignores assembly


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/68e9ec22
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/68e9ec22
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/68e9ec22

Branch: refs/heads/feature/GEODE-831
Commit: 68e9ec2298bd7ccd3ed753d7ea915e1b871ce7d4
Parents: 80971d5
Author: Kirk Lund <kl...@pivotal.io>
Authored: Mon Jan 25 11:31:15 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Jan 25 11:33:11 2016 -0800

----------------------------------------------------------------------
 .../configuration/SharedConfigurationEndToEndDUnitTest.java | 9 +++++----
 1 file changed, 5 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/68e9ec22/gemfire-assembly/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-assembly/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java b/gemfire-assembly/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
index 26ada92..de75927 100644
--- a/gemfire-assembly/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
+++ b/gemfire-assembly/src/test/java/com/gemstone/gemfire/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
@@ -19,6 +19,7 @@ package com.gemstone.gemfire.management.internal.configuration;
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.cache.RegionShortcut;
+
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
@@ -37,10 +38,10 @@ import com.gemstone.gemfire.management.internal.cli.commands.CliCommandTestBase;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 import org.apache.commons.io.FileUtils;
 
 import java.io.File;


[03/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
new file mode 100644
index 0000000..ddc653b
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/VM.java
@@ -0,0 +1,1345 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire.test.dunit;
+
+import java.io.File;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.rmi.RemoteException;
+import java.util.concurrent.Callable;
+
+import com.gemstone.gemfire.test.dunit.standalone.BounceResult;
+import com.gemstone.gemfire.test.dunit.standalone.RemoteDUnitVMIF;
+
+import hydra.MethExecutorResult;
+
+/**
+ * This class represents a Java Virtual Machine that runs on a host.
+ *
+ * @author David Whitlock
+ *
+ */
+public class VM implements java.io.Serializable {
+
+  /** The host on which this VM runs */
+  private Host host;
+
+  /** The process id of this VM */
+  private int pid;
+
+  /** The hydra client for this VM */
+  private RemoteDUnitVMIF client;
+
+  /** The state of this VM */
+  private volatile boolean available;
+
+  ////////////////////  Constructors  ////////////////////
+
+  /**
+   * Creates a new <code>VM</code> that runs on a given host with a
+   * given process id.
+   */
+  public VM(Host host, int pid, RemoteDUnitVMIF client) {
+    this.host = host;
+    this.pid = pid;
+    this.client = client;
+    this.available = true;
+  }
+
+  //////////////////////  Accessors  //////////////////////
+
+  /**
+   * Returns the host on which this <code>VM</code> runs
+   */
+  public Host getHost() {
+    return this.host;
+  }
+
+  /**
+   * Returns the process id of this <code>VM</code>
+   */
+  public int getPid() {
+    return this.pid;
+  }
+
+  /////////////////  Remote Method Invocation  ///////////////
+
+  /**
+   * Invokes a static zero-arg method  with an {@link Object} or
+   * <code>void</code> return type in this VM.  If the return type of
+   * the method is <code>void</code>, <code>null</code> is returned.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public Object invoke(Class c, String methodName) {
+    return invoke(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Asynchronously invokes a static zero-arg method with an {@link
+   * Object} or <code>void</code> return type in this VM.  If the
+   * return type of the method is <code>void</code>, <code>null</code>
+   * is returned.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   */
+  public AsyncInvocation invokeAsync(Class c, String methodName) {
+    return invokeAsync(c, methodName, null);
+  }
+
+  /**
+   * Invokes a static method with an {@link Object} or
+   * <code>void</code> return type in this VM.  If the return type of
+   * the method is <code>void</code>, <code>null</code> is returned.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public Object invoke(Class c, String methodName, Object[] args) {
+    if (!this.available) {
+      String s = "VM not available: " + this;
+      throw new RMIException(this, c.getName(), methodName,
+            new IllegalStateException(s));
+    }
+    MethExecutorResult result = null;
+    int retryCount = 120;
+    do {
+    try {
+      result = this.client.executeMethodOnClass(c.getName(), methodName, args);
+      break; // out of while loop
+    } catch( RemoteException e ) {
+      boolean isWindows = false;
+      String os = System.getProperty("os.name");
+      if (os != null) {
+        if (os.indexOf("Windows") != -1) {
+          isWindows = true;
+        }
+      }
+      if (isWindows && retryCount-- > 0) {
+        boolean interrupted = Thread.interrupted();
+        try { Thread.sleep(1000); } catch (InterruptedException ignore) {interrupted = true;}
+        finally {
+          if (interrupted) {
+            Thread.currentThread().interrupt();
+          }
+        }
+      } else {
+        throw new RMIException(this, c.getName(), methodName, e );
+      }
+    }
+    } while (true);
+
+    if (!result.exceptionOccurred()) {
+      return result.getResult();
+
+    } else {
+      Throwable thr = result.getException();
+      throw new RMIException(this, c.getName(), methodName, thr,
+                             result.getStackTrace()); 
+    }
+  }
+
+  /**
+   * Asynchronously invokes a static method with an {@link Object} or
+   * <code>void</code> return type in this VM.  If the return type of
+   * the method is <code>void</code>, <code>null</code> is returned.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   */
+  public AsyncInvocation invokeAsync(final Class c, 
+                                     final String methodName,
+                                     final Object[] args) {
+    AsyncInvocation ai =
+      new AsyncInvocation(c, methodName, new Runnable() {
+        public void run() {
+          final Object o = invoke(c, methodName, args);
+          AsyncInvocation.setReturnValue(o);
+        }
+      });
+    ai.start();
+    return ai;
+  }
+
+  /**
+   * Asynchronously invokes an instance method with an {@link Object} or
+   * <code>void</code> return type in this VM.  If the return type of
+   * the method is <code>void</code>, <code>null</code> is returned.
+   *
+   * @param o
+   *        The object on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   */
+  public AsyncInvocation invokeAsync(final Object o, 
+                                     final String methodName,
+                                     final Object[] args) {
+    AsyncInvocation ai =
+      new AsyncInvocation(o, methodName, new Runnable() {
+        public void run() {
+          final Object ret = invoke(o, methodName, args);
+          AsyncInvocation.setReturnValue(ret);
+        }
+      });
+    ai.start();
+    return ai;
+  }
+
+  /**
+   * Invokes the <code>run</code> method of a {@link Runnable} in this
+   * VM.  Recall that <code>run</code> takes no arguments and has no
+   * return value.
+   *
+   * @param r
+   *        The <code>Runnable</code> to be run
+   *
+   * @see SerializableRunnable
+   */
+  public AsyncInvocation invokeAsync(Runnable r) {
+    return invokeAsync(r, "run", new Object[0]);
+  }
+  
+  /**
+   * Invokes the <code>call</code> method of a {@link Runnable} in this
+   * VM.  
+   *
+   * @param c
+   *        The <code>Callable</code> to be run
+   *
+   * @see SerializableCallable
+   */
+  public AsyncInvocation invokeAsync(Callable c) {
+    return invokeAsync(c, "call", new Object[0]);
+  }
+
+  /**
+   * Invokes the <code>run</code> method of a {@link Runnable} in this
+   * VM.  Recall that <code>run</code> takes no arguments and has no
+   * return value.
+   *
+   * @param r
+   *        The <code>Runnable</code> to be run
+   *
+   * @see SerializableRunnable
+   */
+  public void invoke(Runnable r) {
+    invoke(r, "run");
+  }
+  
+  /**
+   * Invokes the <code>run</code> method of a {@link Runnable} in this
+   * VM.  Recall that <code>run</code> takes no arguments and has no
+   * return value.
+   *
+   * @param c
+   *        The <code>Callable</code> to be run
+   *
+   * @see SerializableCallable
+   */
+  public Object invoke(Callable c) {
+    return invoke(c, "call");
+  }
+  
+  /**
+   * Invokes the <code>run</code method of a {@link Runnable} in this
+   * VM.  If the invocation throws AssertionFailedError, and repeatTimeoutMs
+   * is >0, the <code>run</code> method is invoked repeatedly until it
+   * either succeeds, or repeatTimeoutMs has passed.  The AssertionFailedError
+   * is thrown back to the sender of this method if <code>run</code> has not
+   * completed successfully before repeatTimeoutMs has passed.
+   */
+  public void invokeRepeatingIfNecessary(RepeatableRunnable o, long repeatTimeoutMs) {
+    invoke(o, "runRepeatingIfNecessary", new Object[] {new Long(repeatTimeoutMs)});
+  }
+
+  /**
+   * Invokes an instance method with no arguments on an object that is
+   * serialized into this VM.  The return type of the method can be
+   * either {@link Object} or <code>void</code>.  If the return type
+   * of the method is <code>void</code>, <code>null</code> is
+   * returned.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public Object invoke(Object o, String methodName) {
+    return invoke(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method can be either {@link
+   * Object} or <code>void</code>.  If the return type of the method
+   * is <code>void</code>, <code>null</code> is returned.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public Object invoke(Object o, String methodName, Object[] args) {
+    if (!this.available) {
+      String s = "VM not available: " + this;
+      throw new RMIException(this, o.getClass().getName(), methodName,
+            new IllegalStateException(s));
+    }
+    MethExecutorResult result = null;
+    int retryCount = 120;
+    do {
+    try {
+      if ( args == null )
+        result = this.client.executeMethodOnObject(o, methodName);
+      else
+        result = this.client.executeMethodOnObject(o, methodName, args);
+      break; // out of while loop
+    } catch( RemoteException e ) {
+      if (retryCount-- > 0) {
+        boolean interrupted = Thread.interrupted();
+        try { Thread.sleep(1000); } catch (InterruptedException ignore) {interrupted = true;}
+        finally {
+          if (interrupted) {
+            Thread.currentThread().interrupt();
+          }
+        }
+      } else {
+        throw new RMIException(this, o.getClass().getName(), methodName, e );
+      }
+    }
+    } while (true);
+
+    if (!result.exceptionOccurred()) {
+      return result.getResult();
+
+    } else {
+      Throwable thr = result.getException();
+      throw new RMIException(this, o.getClass().getName(), methodName, thr,
+                             result.getStackTrace()); 
+    }
+  }
+
+  /**
+   * Invokes the <code>main</code> method of a given class
+   *
+   * @param c
+   *        The class on which to invoke the <code>main</code> method
+   * @param args
+   *        The "command line" arguments to pass to the
+   *        <code>main</code> method
+   */
+  public void invokeMain(Class c, String[] args) {
+    Object[] stupid = new Object[] { args };
+    invoke(c, "main", stupid);
+  }
+
+  /**
+   * Asynchronously invokes the <code>main</code> method of a given
+   * class
+   *
+   * @param c
+   *        The class on which to invoke the <code>main</code> method
+   * @param args
+   *        The "command line" arguments to pass to the
+   *        <code>main</code> method
+   */
+  public AsyncInvocation invokeMainAsync(Class c, String[] args) {
+    Object[] stupid = new Object[] { args };
+    return invokeAsync(c, "main", stupid);
+  }
+
+  /**
+   * Invokes a static method with a <code>boolean</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>boolean</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public boolean invokeBoolean(Class c, String methodName) {
+    return invokeBoolean(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>boolean</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>boolean</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public boolean invokeBoolean(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a boolean";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Boolean) {
+      return ((Boolean) result).booleanValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a boolean";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>boolean</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>boolean</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public boolean invokeBoolean(Object o, String methodName) {
+    return invokeBoolean(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>boolean</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>boolean</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public boolean invokeBoolean(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a boolean";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Boolean) {
+      return ((Boolean) result).booleanValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a boolean";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>char</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>char</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public char invokeChar(Class c, String methodName) {
+    return invokeChar(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>char</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>char</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public char invokeChar(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a char";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Character) {
+      return ((Character) result).charValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a char";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>char</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>char</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public char invokeChar(Object o, String methodName) {
+    return invokeChar(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>char</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>char</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public char invokeChar(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a char";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Character) {
+      return ((Character) result).charValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a char";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>byte</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>byte</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public byte invokeByte(Class c, String methodName) {
+    return invokeByte(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>byte</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>byte</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public byte invokeByte(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a byte";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Byte) {
+      return ((Byte) result).byteValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a byte";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>byte</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>byte</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public byte invokeByte(Object o, String methodName) {
+    return invokeByte(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>byte</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>byte</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public byte invokeByte(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a byte";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Byte) {
+      return ((Byte) result).byteValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a byte";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>short</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>short</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public short invokeShort(Class c, String methodName) {
+    return invokeShort(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>short</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>short</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public short invokeShort(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a short";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Short) {
+      return ((Short) result).shortValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a short";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>short</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>short</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public short invokeShort(Object o, String methodName) {
+    return invokeShort(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>short</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>short</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public short invokeShort(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a short";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Short) {
+      return ((Short) result).shortValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a short";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>int</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>int</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public int invokeInt(Class c, String methodName) {
+    return invokeInt(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>int</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>int</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public int invokeInt(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a int";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Integer) {
+      return ((Integer) result).intValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a int";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>int</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>int</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public int invokeInt(Object o, String methodName) {
+    return invokeInt(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>int</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>int</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public int invokeInt(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a int";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Integer) {
+      return ((Integer) result).intValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a int";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>long</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>long</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public long invokeLong(Class c, String methodName) {
+    return invokeLong(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>long</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>long</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public long invokeLong(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a long";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Long) {
+      return ((Long) result).longValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a long";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>long</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>long</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public long invokeLong(Object o, String methodName) {
+    return invokeLong(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>long</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>long</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public long invokeLong(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a long";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Long) {
+      return ((Long) result).longValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a long";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>float</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>float</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public float invokeFloat(Class c, String methodName) {
+    return invokeFloat(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>float</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>float</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public float invokeFloat(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a float";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Float) {
+      return ((Float) result).floatValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a float";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>float</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>float</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public float invokeFloat(Object o, String methodName) {
+    return invokeFloat(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>float</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>float</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public float invokeFloat(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a float";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Float) {
+      return ((Float) result).floatValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a float";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes a static method with a <code>double</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>double</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public double invokeDouble(Class c, String methodName) {
+    return invokeDouble(c, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes a static method with a <code>double</code> return type
+   * in this VM.
+   *
+   * @param c
+   *        The class on which to invoke the method
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>double</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public double invokeDouble(Class c, String methodName, Object[] args) {
+    Object result = invoke(c, methodName, args);
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a double";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Double) {
+      return ((Double) result).doubleValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a double";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>double</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>double</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public double invokeDouble(Object o, String methodName) {
+    return invokeDouble(o, methodName, new Object[0]);
+  }
+
+  /**
+   * Invokes an instance method on an object that is serialized into
+   * this VM.  The return type of the method is <code>double</code>.
+   *
+   * @param o
+   *        The receiver of the method invocation
+   * @param methodName
+   *        The name of the method to invoke
+   * @param args
+   *        Arguments passed to the method call (must be {@link
+   *        java.io.Serializable}). 
+   *
+   * @throws IllegalArgumentException
+   *         The method does not return a <code>double</code>
+   * @throws RMIException
+   *         An exception occurred on while invoking the method in
+   *         this VM
+   */
+  public double invokeDouble(Object o, String methodName, Object[] args) {
+    Object result = invoke(o, methodName, args);
+    Class c = o.getClass();
+    if (result == null) {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned null, expected a double";
+      throw new IllegalArgumentException(s);
+
+    } else if (result instanceof Double) {
+      return ((Double) result).doubleValue();
+
+    } else {
+      String s = "Method \"" + methodName + "\" in class \"" +
+        c.getName() + "\" returned a \"" + result.getClass().getName()
+        + "\" expected a double";
+      throw new IllegalArgumentException(s);
+    }
+  }
+
+  /**
+   * Synchronously bounces (mean kills and restarts) this <code>VM</code>.
+   * Concurrent bounce attempts are synchronized but attempts to invoke
+   * methods on a bouncing VM will cause test failure.  Tests using bounce
+   * should be placed at the end of the dunit test suite, since an exception
+   * here will cause all tests using the unsuccessfully bounced VM to fail.
+   * 
+   * This method is currently not supported by the standalone dunit
+   * runner.
+   *
+   * @throws RMIException if an exception occurs while bouncing this VM, for
+   *  example a HydraTimeoutException if the VM fails to stop within {@link
+   *  hydra.Prms#maxClientShutdownWaitSec} or restart within {@link
+   *  hydra.Prms#maxClientStartupWaitSec}.
+   */
+  public synchronized void bounce() {
+    if (!this.available) {
+      String s = "VM not available: " + this;
+      throw new RMIException(this, this.getClass().getName(), "bounceVM",
+            new IllegalStateException(s));
+    }
+    this.available = false;
+    try {
+      BounceResult result = DUnitEnv.get().bounce(this.pid);
+      
+      this.pid = result.getNewPid();
+      this.client = result.getNewClient();
+      this.available = true;
+    } catch (UnsupportedOperationException e) {
+      this.available = true;
+      throw e;
+    } catch (RemoteException e) {
+      StringWriter sw = new StringWriter();
+      e.printStackTrace(new PrintWriter(sw, true));
+      RMIException rmie = new RMIException(this, this.getClass().getName(),
+        "bounceVM", e, sw.toString());
+      throw rmie;
+    }
+  }
+
+  /////////////////////  Utility Methods  ////////////////////
+
+  public String toString() {
+    return "VM " + this.getPid() + " running on " + this.getHost();
+  }
+
+  public static int getCurrentVMNum() {
+    return DUnitEnv.get().getVMID();
+  }
+  
+  public File getWorkingDirectory() {
+    return DUnitEnv.get().getWorkingDirectory(this.getPid());
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/DUnitLauncher.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/DUnitLauncher.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/DUnitLauncher.java
index 0a9d7c5..5e7fa0e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/DUnitLauncher.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/DUnitLauncher.java
@@ -56,11 +56,10 @@ import com.gemstone.gemfire.distributed.Locator;
 import com.gemstone.gemfire.distributed.internal.membership.gms.membership.GMSJoinLeave;
 import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.internal.logging.LogService;
-
-import dunit.DUnitEnv;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DUnitEnv;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * A class to build a fake test configuration and launch some DUnit VMS.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/StandAloneDUnitEnv.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/StandAloneDUnitEnv.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/StandAloneDUnitEnv.java
index eef24fe..2975dcb 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/StandAloneDUnitEnv.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/standalone/StandAloneDUnitEnv.java
@@ -20,10 +20,9 @@ import java.io.File;
 import java.rmi.RemoteException;
 import java.util.Properties;
 
+import com.gemstone.gemfire.test.dunit.DUnitEnv;
 import com.gemstone.gemfire.test.dunit.standalone.DUnitLauncher.MasterRemote;
 
-import dunit.DUnitEnv;
-
 public class StandAloneDUnitEnv extends DUnitEnv {
 
   private MasterRemote master;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
index 76faf93..2947f4b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/BasicDUnitTest.java
@@ -18,11 +18,11 @@ package com.gemstone.gemfire.test.dunit.tests;
 
 import java.util.Properties;
 
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class tests the basic functionality of the distributed unit

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
index 3562f86..78f7196 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/test/dunit/tests/VMDUnitTest.java
@@ -16,12 +16,15 @@
  */
 package com.gemstone.gemfire.test.dunit.tests;
 
-import dunit.*;
-
 import java.io.Serializable;
-
 import java.util.concurrent.atomic.AtomicInteger;
 
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.VM;
+
 /**
  * This class tests the functionality of the {@link VM} class.
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/AsyncInvocation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/AsyncInvocation.java b/gemfire-core/src/test/java/dunit/AsyncInvocation.java
deleted file mode 100644
index 9177a12..0000000
--- a/gemfire-core/src/test/java/dunit/AsyncInvocation.java
+++ /dev/null
@@ -1,217 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package dunit;
-
-import java.util.concurrent.TimeoutException;
-
-import junit.framework.AssertionFailedError;
-
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-
-// @todo davidw Add the ability to get a return value back from the
-// async method call.  (Use a static ThreadLocal field that is
-// accessible from the Runnable used in VM#invoke)
-/**
- * <P>An <code>AsyncInvocation</code> represents the invocation of a
- * remote invocation that executes asynchronously from its caller.  An
- * instanceof <code>AsyncInvocation</code> provides information about
- * the invocation such as any exception that it may have thrown.</P>
- *
- * <P>Because it is a <code>Thread</code>, an
- * <code>AsyncInvocation</code> can be used as follows:</P>
- *
- * <PRE>
- *   AsyncInvocation ai1 = vm.invokeAsync(Test.class, "method1");
- *   AsyncInvocation ai2 = vm.invokeAsync(Test.class, "method2");
- *
- *   ai1.join();
- *   ai2.join();
- *
- *   assertTrue("Exception occurred while invoking " + ai1,
- *              !ai1.exceptionOccurred());
- *   if (ai2.exceptionOccurred()) {
- *     throw ai2.getException();
- *   }
- * </PRE>
- *
- * @see VM#invokeAsync(Class, String)
- */
-public class AsyncInvocation extends Thread {
-  
-  private static final ThreadLocal returnValue = new ThreadLocal();
-
-  /** The singleton the thread group */
-  private static final ThreadGroup GROUP = new AsyncInvocationGroup();
-
-  ///////////////////// Instance Fields  /////////////////////
-
-  /** An exception thrown while this async invocation ran */
-  protected volatile Throwable exception;
-
-  /** The object (or class) that is the receiver of this asyn method
-   * invocation */
-  private Object receiver;
-
-  /** The name of the method being invoked */
-  private String methodName;
-  
-  /** The returned object if any */
-  public volatile Object returnedObj = null;
-
-  //////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>AsyncInvocation</code>
-   *
-   * @param receiver
-   *        The object or {@link Class} on which the remote method was
-   *        invoked
-   * @param methodName
-   *        The name of the method being invoked
-   * @param work
-   *        The actual invocation of the method
-   */
-  public AsyncInvocation(Object receiver, String methodName, Runnable work) {
-    super(GROUP, work, getName(receiver, methodName));
-    this.receiver = receiver;
-    this.methodName = methodName;
-    this.exception = null;
-  }
-
-  //////////////////////  Static Methods  /////////////////////
-
-  /**
-   * Returns the name of a <code>AsyncInvocation</code> based on its
-   * receiver and method name.
-   */
-  private static String getName(Object receiver, String methodName) {
-    StringBuffer sb = new StringBuffer(methodName);
-    sb.append(" invoked on ");
-    if (receiver instanceof Class) {
-      sb.append("class ");
-      sb.append(((Class) receiver).getName());
-
-    } else {
-      sb.append("an instance of ");
-      sb.append(receiver.getClass().getName());
-    }
-
-    return sb.toString();
-  }
-
-  /////////////////////  Instance Methods  ////////////////////
-
-  /**
-   * Returns the receiver of this async method invocation
-   */
-  public Object getReceiver() {
-    return this.receiver;
-  }
-
-  /**
-   * Returns the name of the method being invoked remotely
-   */
-  public String getMethodName() {
-    return this.methodName;
-  }
-
-  /**
-   * Returns whether or not an exception occurred during this async
-   * method invocation.
-   */
-  public boolean exceptionOccurred() {
-    if (this.isAlive()) {
-      throw new InternalGemFireError("Exception status not available while thread is alive.");
-    }
-    return this.exception != null;
-  }
-
-  /**
-   * Returns the exception that was thrown during this async method
-   * invocation.
-   */
-  public Throwable getException() {
-    if (this.isAlive()) {
-      throw new InternalGemFireError("Exception status not available while thread is alive.");
-    }
-    if (this.exception instanceof RMIException) {
-      return ((RMIException) this.exception).getCause();
-
-    } else {
-      return this.exception;
-    }
-  }
-
-  //////////////////////  Inner Classes  //////////////////////
-
-  /**
-   * A <code>ThreadGroup</code> that notices when an exception occurrs
-   * during an <code>AsyncInvocation</code>.
-   */
-  private static class AsyncInvocationGroup extends ThreadGroup {
-    AsyncInvocationGroup() {
-      super("Async Invocations");
-    }
-
-    public void uncaughtException(Thread t, Throwable e) {
-      if (e instanceof VirtualMachineError) {
-        SystemFailure.setFailure((VirtualMachineError)e); // don't throw
-      }
-      if (t instanceof AsyncInvocation) {
-        ((AsyncInvocation) t).exception = e;
-      }
-    }
-  }
-  
-  public Object getResult() throws Throwable {
-    join();
-    if(this.exceptionOccurred()) {
-      throw new Exception("An exception occured during async invocation", this.exception);
-    }
-    return this.returnedObj;
-  }
-  
-  public Object getResult(long waitTime) throws Throwable {
-    join(waitTime);
-    if(this.isAlive()) {
-      throw new TimeoutException();
-    }
-    if(this.exceptionOccurred()) {
-      throw new Exception("An exception occured during async invocation", this.exception);
-    }
-    return this.returnedObj;
-  }
-
-  public Object getReturnValue() {
-    if (this.isAlive()) {
-      throw new InternalGemFireError("Return value not available while thread is alive.");
-    }
-    return this.returnedObj;
-  }
-  
-  public void run()
-  {
-    super.run();
-    this.returnedObj = returnValue.get();
-    returnValue.set(null);
-  }
-
-  static void setReturnValue(Object v) {
-    returnValue.set(v);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/dunit/DUnitEnv.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/dunit/DUnitEnv.java b/gemfire-core/src/test/java/dunit/DUnitEnv.java
deleted file mode 100644
index 54fe67f..0000000
--- a/gemfire-core/src/test/java/dunit/DUnitEnv.java
+++ /dev/null
@@ -1,80 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-/**
- * 
- */
-package dunit;
-
-import java.io.File;
-import java.rmi.RemoteException;
-import java.util.Properties;
-
-import com.gemstone.gemfire.test.dunit.standalone.BounceResult;
-
-
-/**
- * This class provides an abstraction over the environment
- * that is used to run dunit. This will delegate to the hydra
- * or to the standalone dunit launcher as needed.
- * 
- * Any dunit tests that rely on hydra configuration should go
- * through here, so that we can separate them out from depending on hydra
- * and run them on a different VM launching system.
- *   
- * @author dsmith
- *
- */
-public abstract class DUnitEnv {
-  
-  public static DUnitEnv instance = null;
-  
-  public static final DUnitEnv get() {
-    if (instance == null) {
-      try {
-        // for tests that are still being migrated to the open-source
-        // distributed unit test framework  we need to look for this
-        // old closed-source dunit environment
-        Class clazz = Class.forName("dunit.hydra.HydraDUnitEnv");
-        instance = (DUnitEnv)clazz.newInstance();
-      } catch (Exception e) {
-        throw new Error("Distributed unit test environment is not initialized");
-      }
-    }
-    return instance;
-  }
-  
-  public static void set(DUnitEnv dunitEnv) {
-    instance = dunitEnv;
-  }
-  
-  public abstract String getLocatorString();
-  
-  public abstract String getLocatorAddress();
-
-  public abstract int getLocatorPort();
-  
-  public abstract Properties getDistributedSystemProperties();
-
-  public abstract int getPid();
-
-  public abstract int getVMID();
-
-  public abstract BounceResult bounce(int pid) throws RemoteException;
-
-  public abstract File getWorkingDirectory(int pid);
-  
-}


[33/52] [abbrv] incubator-geode git commit: GEODE-863: Gfsh-started locator exits after a successful auto-reconnect

Posted by ds...@apache.org.
GEODE-863: Gfsh-started locator exits after a successful auto-reconnect

Modified InternalLocator.waitToStop() to work with auto-reconnect.
Modified InternalDistributedSystem to keep log appenders open during
auto-reconnect.
Added test of waitToStop to ReconnectDUnitTest.
Modified LocatorLauncher to show error details.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/4e211e2c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/4e211e2c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/4e211e2c

Branch: refs/heads/feature/GEODE-831
Commit: 4e211e2c2f771a4c399ce2be8dd0eb85f9b63740
Parents: 1ccf226
Author: Bruce Schuchardt <bs...@pivotal.io>
Authored: Wed Jan 27 08:24:42 2016 -0800
Committer: Bruce Schuchardt <bs...@pivotal.io>
Committed: Wed Jan 27 08:28:11 2016 -0800

----------------------------------------------------------------------
 .../gemfire/distributed/LocatorLauncher.java    | 13 +++++++
 .../internal/InternalDistributedSystem.java     | 26 +++++++------
 .../distributed/internal/InternalLocator.java   | 14 ++++---
 .../gemfire/cache30/ReconnectDUnitTest.java     | 39 ++++++++++++++++++++
 4 files changed, 76 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4e211e2c/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/LocatorLauncher.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/LocatorLauncher.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/LocatorLauncher.java
index 6846905..d13dae5 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/LocatorLauncher.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/LocatorLauncher.java
@@ -35,6 +35,8 @@ import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
 import java.util.concurrent.atomic.AtomicBoolean;
 import java.util.concurrent.atomic.AtomicReference;
+import java.util.logging.Level;
+
 import javax.management.MalformedObjectNameException;
 import javax.management.ObjectName;
 
@@ -667,6 +669,13 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @param cause the Throwable thrown during the startup or wait operation on the Locator.
    */
   private void failOnStart(final Throwable cause) {
+
+    if (cause != null) {
+      logger.log(Level.INFO, "locator is exiting due to an exception", cause);
+    } else {
+      logger.log(Level.INFO, "locator is exiting normally");
+    }
+    
     if (this.locator != null) {
       this.locator.stop();
       this.locator = null;
@@ -712,6 +721,10 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
       t = e;
       throw e;
     }
+    catch (Throwable e) {
+      t = e;
+      throw e;
+    }
     finally {
       failOnStart(t);
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4e211e2c/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
index 087407a..b3c636a 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
@@ -1326,12 +1326,14 @@ public class InternalDistributedSystem
           shutdownListeners = doDisconnects(attemptingToReconnect, reason);
         }
     
-        if (this.logWriterAppender != null) {
-          LogWriterAppenders.stop(LogWriterAppenders.Identifier.MAIN);
-        }
-        if (this.securityLogWriterAppender != null) {
-          // LOG:SECURITY: old code did NOT invoke this
-          LogWriterAppenders.stop(LogWriterAppenders.Identifier.SECURITY);
+        if (!this.attemptingToReconnect) {
+          if (this.logWriterAppender != null) {
+            LogWriterAppenders.stop(LogWriterAppenders.Identifier.MAIN);
+          }
+          if (this.securityLogWriterAppender != null) {
+            // LOG:SECURITY: old code did NOT invoke this
+            LogWriterAppenders.stop(LogWriterAppenders.Identifier.SECURITY);
+          }
         }
         
         AlertAppender.getInstance().shuttingDown();
@@ -1376,11 +1378,13 @@ public class InternalDistributedSystem
         this.sampler = null;
       }
 
-      if (this.logWriterAppender != null) {
-        LogWriterAppenders.destroy(LogWriterAppenders.Identifier.MAIN);
-      }
-      if (this.securityLogWriterAppender != null) {
-        LogWriterAppenders.destroy(LogWriterAppenders.Identifier.SECURITY);
+      if (!this.attemptingToReconnect) {
+        if (this.logWriterAppender != null) {
+          LogWriterAppenders.destroy(LogWriterAppenders.Identifier.MAIN);
+        }
+        if (this.securityLogWriterAppender != null) {
+          LogWriterAppenders.destroy(LogWriterAppenders.Identifier.SECURITY);
+        }
       }
 
       // NOTE: no logging after this point :-)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4e211e2c/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
index c346a45..0f27d36 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalLocator.java
@@ -923,6 +923,10 @@ public class InternalLocator extends Locator implements ConnectListener {
    */
   public void stop(boolean forcedDisconnect, boolean stopForReconnect, boolean waitForDisconnect) {
     final boolean isDebugEnabled = logger.isDebugEnabled();
+    
+    this.stoppedForReconnect = stopForReconnect;
+    this.forcedDisconnect = forcedDisconnect;
+    
     if (this.server.isShuttingDown()) {
       // fix for bug 46156
       // If we are already shutting down don't do all of this again.
@@ -949,9 +953,7 @@ public class InternalLocator extends Locator implements ConnectListener {
       }
       return;
     }
-    this.stoppedForReconnect = stopForReconnect;
-    this.forcedDisconnect = forcedDisconnect;
-    
+
     if (this.server.isAlive()) {
       logger.info(LocalizedMessage.create(LocalizedStrings.InternalLocator_STOPPING__0, this));
       try {
@@ -1041,15 +1043,16 @@ public class InternalLocator extends Locator implements ConnectListener {
   public void waitToStop() throws InterruptedException {
     boolean restarted;
     do {
+      DistributedSystem ds = this.myDs;
       restarted = false;
       this.server.join();
       if (this.stoppedForReconnect) {
         logger.info("waiting for distributed system to disconnect...");
-        while (this.myDs.isConnected()) {
+        while (ds.isConnected()) {
           Thread.sleep(5000);
         }
         logger.info("waiting for distributed system to reconnect...");
-        restarted = this.myDs.waitUntilReconnected(-1, TimeUnit.SECONDS);
+        restarted = ds.waitUntilReconnected(-1, TimeUnit.SECONDS);
         if (restarted) {
           logger.info("system restarted");
         } else {
@@ -1060,6 +1063,7 @@ public class InternalLocator extends Locator implements ConnectListener {
           logger.info("waiting for services to restart...");
           rs.join();
           this.restartThread = null;
+          logger.info("done waiting for services to restart");
         }
       }
     } while (restarted);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/4e211e2c/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
index b4a73bc..cdc3283 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/ReconnectDUnitTest.java
@@ -61,12 +61,14 @@ import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
 
+@SuppressWarnings("serial")
 public class ReconnectDUnitTest extends CacheTestCase
 {
   static int locatorPort;
   static Locator locator;
   static DistributedSystem savedSystem;
   static int locatorVMNumber = 3;
+  static Thread gfshThread;
   
   Properties dsProperties;
   
@@ -506,8 +508,10 @@ public class ReconnectDUnitTest extends CacheTestCase
     try {
       
       dm = getDMID(vm0);
+      createGfshWaitingThread(vm0);
       forceDisconnect(vm0);
       newdm = waitForReconnect(vm0);
+      assertGfshWaitingThreadAlive(vm0);
 
       boolean running = (Boolean)vm0.invoke(new SerializableCallable("check for running locator") {
         public Object call() {
@@ -551,6 +555,10 @@ public class ReconnectDUnitTest extends CacheTestCase
           if (loc != null) {
             loc.stop();
           }
+          if (gfshThread != null && gfshThread.isAlive()) {
+            gfshThread.interrupt();
+          }
+          gfshThread = null;
         }
       });
       deleteLocatorStateFile(locPort);
@@ -558,6 +566,37 @@ public class ReconnectDUnitTest extends CacheTestCase
     }
   }
   
+  @SuppressWarnings("serial")
+  private void createGfshWaitingThread(VM vm) {
+    vm.invoke(new SerializableRunnable("create Gfsh-like waiting thread") {
+      public void run() {
+        final Locator loc = Locator.getLocator();
+        assertNotNull(loc);
+        gfshThread = new Thread("ReconnectDUnitTest_Gfsh_thread") {
+          public void run() {
+            try {
+              ((InternalLocator)loc).waitToStop();
+            } catch (InterruptedException e) {
+              System.out.println(Thread.currentThread().getName() + " interrupted - exiting");
+            }
+          }
+        };
+        gfshThread.setDaemon(true);
+        gfshThread.start();
+        System.out.println("created gfsh thread: " + gfshThread);
+      }
+    });
+  }
+  
+  @SuppressWarnings("serial")
+  private void assertGfshWaitingThreadAlive(VM vm) {
+    vm.invoke(new SerializableRunnable("assert gfshThread is still waiting") {
+      public void run() {
+        assertTrue(gfshThread.isAlive());
+      }
+    });
+  }
+  
   /**
    * Test the reconnect behavior when the required roles are missing.
    * Reconnect is triggered as a Reliability policy. The test is to


[14/52] [abbrv] incubator-geode git commit: GEODE-819: Fix merge conflicts that were somehow undone

Posted by ds...@apache.org.
GEODE-819: Fix merge conflicts that were somehow undone


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/3e762a9e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/3e762a9e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/3e762a9e

Branch: refs/heads/feature/GEODE-831
Commit: 3e762a9ea082d4a7c3d2245baa1388c1d6c4cc36
Parents: d89038d
Author: Kirk Lund <kl...@pivotal.io>
Authored: Mon Jan 25 10:53:34 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Jan 25 10:53:34 2016 -0800

----------------------------------------------------------------------
 .../gemfire/cache30/CacheXml41DUnitTest.java    | 34 ++++++++++++++------
 .../gemfire/cache30/CacheXml57DUnitTest.java    | 11 ++-----
 .../gemfire/cache30/CacheXml60DUnitTest.java    | 15 +++------
 3 files changed, 31 insertions(+), 29 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e762a9e/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
index f6a0aa2..bc1f7e4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml41DUnitTest.java
@@ -16,19 +16,33 @@
  */
 package com.gemstone.gemfire.cache30;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.internal.cache.xmlcache.*;
-import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.File;
+import java.io.InputStream;
+import java.io.OutputStreamWriter;
+import java.io.PrintWriter;
 
-import java.io.*;
+import org.xml.sax.SAXException;
 
-<<<<<<< HEAD
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheException;
+import com.gemstone.gemfire.cache.CacheXmlException;
+import com.gemstone.gemfire.cache.DynamicRegionFactory;
+import com.gemstone.gemfire.cache.ExpirationAction;
+import com.gemstone.gemfire.cache.ExpirationAttributes;
+import com.gemstone.gemfire.cache.MirrorType;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.RegionAttributes;
+import com.gemstone.gemfire.cache.RegionExistsException;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.server.CacheServer;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
+import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import dunit.DistributedTestCase;
-=======
->>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
-import org.xml.sax.SAXException;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 
 /**
  * Tests the declarative caching functionality introduced in GemFire 4.1.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e762a9e/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
index 06ae560..be78e26 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml57DUnitTest.java
@@ -33,9 +33,9 @@ import com.gemstone.gemfire.cache.ExpirationAttributes;
 import com.gemstone.gemfire.cache.InterestPolicy;
 import com.gemstone.gemfire.cache.MirrorType;
 import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.cache.Region.Entry;
 import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.cache.SubscriptionAttributes;
-import com.gemstone.gemfire.cache.Region.Entry;
 import com.gemstone.gemfire.cache.client.Pool;
 import com.gemstone.gemfire.cache.client.PoolFactory;
 import com.gemstone.gemfire.cache.client.PoolManager;
@@ -52,19 +52,12 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionCreation;
-<<<<<<< HEAD
-
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
-=======
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.VM;
->>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
 
-import junit.framework.*;
+import junit.framework.Assert;
 
 /**
  * Tests 5.7 cache.xml features.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3e762a9e/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
index c54af3d..3a20c07 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheXml60DUnitTest.java
@@ -16,6 +16,11 @@
  */
 package com.gemstone.gemfire.cache30;
 
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+import java.io.Serializable;
+
 import com.gemstone.gemfire.DataSerializable;
 import com.gemstone.gemfire.DataSerializer;
 import com.gemstone.gemfire.cache.Cache;
@@ -31,18 +36,8 @@ import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
 import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.ResourceManagerCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.SerializerCreation;
-<<<<<<< HEAD
-
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import dunit.DistributedTestCase;
-=======
 import com.gemstone.gemfire.test.dunit.DistributedTestCase;
->>>>>>> f764f8d... GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.io.IOException;
-import java.io.Serializable;
 
 /**
  * Tests 6.0 cache.xml features.


[06/52] [abbrv] incubator-geode git commit: GEODE-819: Move dunit to com.gemstone.gemfire.test.dunit

Posted by ds...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/AsyncEventQueueTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/AsyncEventQueueTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/AsyncEventQueueTestBase.java
index ec38649..ce0f422 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/AsyncEventQueueTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/AsyncEventQueueTestBase.java
@@ -75,10 +75,9 @@ import com.gemstone.gemfire.internal.cache.ForceReattemptException;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.PartitionedRegion;
 import com.gemstone.gemfire.internal.cache.RegionQueue;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class AsyncEventQueueTestBase extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueStatsDUnitTest.java
index 30123a3..9258c49 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/asyncqueue/AsyncEventQueueStatsDUnitTest.java
@@ -20,8 +20,7 @@ import java.util.HashMap;
 import java.util.Map;
 
 import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 public class AsyncEventQueueStatsDUnitTest extends AsyncEventQueueTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentAsyncEventQueueDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentAsyncEventQueueDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentAsyncEventQueueDUnitTest.java
index fdcc6f6..0e6efa0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentAsyncEventQueueDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/wan/concurrent/ConcurrentAsyncEventQueueDUnitTest.java
@@ -19,8 +19,7 @@ package com.gemstone.gemfire.internal.cache.wan.concurrent;
 import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueFactoryImpl;
 import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
 import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueTestBase;
-
-import dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
 
 /**
  * @author skumar

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheConfigDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheConfigDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheConfigDUnitTest.java
index b7167bc..84c9193 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheConfigDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheConfigDUnitTest.java
@@ -26,8 +26,11 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.*;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * Tests configured and badly configured cache.xml files with regards to compression.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerDUnitTest.java
index 0d6a462..3ff3e9b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerDUnitTest.java
@@ -31,11 +31,10 @@ import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Asserts that values received in EntryEvents for CacheWriters and CacheListeners are not compressed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerOffHeapDUnitTest.java
index c617f2b..cf8583a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionCacheListenerOffHeapDUnitTest.java
@@ -21,8 +21,7 @@ import java.util.Properties;
 import com.gemstone.gemfire.compression.SnappyCompressor;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 @SuppressWarnings("serial")
 public class CompressionCacheListenerOffHeapDUnitTest extends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionConfigDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionConfigDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionConfigDUnitTest.java
index 1fb22c6..8061b3c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionConfigDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionConfigDUnitTest.java
@@ -27,14 +27,13 @@ import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.standalone.DUnitLauncher;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-
 /**
  * Sanity checks on a number of basic cluster configurations with compression turned on.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionFactoryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionFactoryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionFactoryDUnitTest.java
index 498c6fb..37dbddf 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionFactoryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionFactoryDUnitTest.java
@@ -21,11 +21,10 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache30.CacheTestCase;
 import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests that the compressor region attribute is properly set or rejected by a RegionFactory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsDUnitTest.java
index 7844a46..e8153e2 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsDUnitTest.java
@@ -28,11 +28,10 @@ import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
 import com.gemstone.gemfire.internal.cache.CachedDeserializableFactory;
 import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests basic region operations with compression enabled.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsOffHeapDUnitTest.java
index 2d3c59b..8c66f96 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionRegionOperationsOffHeapDUnitTest.java
@@ -22,8 +22,7 @@ import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.compression.SnappyCompressor;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
-
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 public class CompressionRegionOperationsOffHeapDUnitTest extends
     CompressionRegionOperationsDUnitTest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionStatsDUnitTest.java
index 0fc9baa..db1f636 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/compression/CompressionStatsDUnitTest.java
@@ -26,11 +26,10 @@ import com.gemstone.gemfire.compression.Compressor;
 import com.gemstone.gemfire.internal.cache.CachePerfStats;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.LocalRegion;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests compression statistics.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/CommitThread.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/CommitThread.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/CommitThread.java
index 6c0cf69..90ddd5f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/CommitThread.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/CommitThread.java
@@ -14,30 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-                                                                                                                             
 package com.gemstone.gemfire.internal.jta.dunit;
                                                                                                                              
-//import dunit.*;
-//import java.io.*;
-//import java.util.*;
-//import java.net.*;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.distributed.*;
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
+import java.sql.Connection;
+import java.sql.SQLException;
+import java.sql.Statement;
+
 import javax.naming.Context;
-import javax.sql.*;
-import javax.transaction.*;
-import java.sql.*;
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
 import javax.naming.NamingException;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.SystemException;
+import javax.sql.DataSource;
+import javax.transaction.UserTransaction;
+
+import com.gemstone.gemfire.LogWriter;
+import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
-//import com.gemstone.gemfire.internal.jta.JTAUtils;
                                                                                                                              
 /**
 *This is thread class

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/ExceptionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/ExceptionsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/ExceptionsDUnitTest.java
index b35d733..8015b6a 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/ExceptionsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/ExceptionsDUnitTest.java
@@ -16,35 +16,31 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
+import java.sql.SQLException;
+import java.util.Properties;
 
-import java.io.*;
-import java.util.*;
+import javax.naming.Context;
+import javax.naming.NamingException;
+import javax.sql.DataSource;
+import javax.transaction.UserTransaction;
 
-//import java.net.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-
-
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
-import javax.naming.Context;
-import javax.sql.*;
-import javax.transaction.*;
-
-import java.sql.*;
-
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
-import javax.naming.NamingException;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.*;
-
 public class ExceptionsDUnitTest extends DistributedTestCase {
 
   static DistributedSystem ds;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/IdleTimeOutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/IdleTimeOutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/IdleTimeOutDUnitTest.java
index 0fc5613..c340ae3 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/IdleTimeOutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/IdleTimeOutDUnitTest.java
@@ -16,35 +16,33 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
+import java.sql.Connection;
+import java.sql.SQLException;
+import java.sql.Statement;
+import java.util.Properties;
 
-import java.io.*;
-import java.util.*;
+import javax.naming.Context;
+import javax.naming.NamingException;
+import javax.sql.DataSource;
 
-//import java.net.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-
-
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
-import javax.naming.Context;
-import javax.sql.*;
-
-//import javax.transaction.*;
-import java.sql.*;
-
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
-import javax.naming.NamingException;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.SystemException;
-
 public class IdleTimeOutDUnitTest extends DistributedTestCase {
 
   static DistributedSystem ds;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/LoginTimeOutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/LoginTimeOutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/LoginTimeOutDUnitTest.java
index 6c0e531..6be7241 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/LoginTimeOutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/LoginTimeOutDUnitTest.java
@@ -40,14 +40,13 @@ import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
 import com.gemstone.gemfire.internal.logging.LogService;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.RMIException;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.RMIException;
-import dunit.VM;
-
 public class LoginTimeOutDUnitTest extends DistributedTestCase {
   private static final Logger logger = LogService.getLogger();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/MaxPoolSizeDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/MaxPoolSizeDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/MaxPoolSizeDUnitTest.java
index da4b578..5e31e12 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/MaxPoolSizeDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/MaxPoolSizeDUnitTest.java
@@ -16,34 +16,33 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
+import java.sql.Connection;
+import java.sql.SQLException;
+import java.sql.Statement;
+import java.util.Properties;
 
-import java.io.*;
-import java.util.*;
+import javax.naming.Context;
+import javax.naming.NamingException;
+import javax.sql.DataSource;
 
-//import java.net.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
-import javax.naming.Context;
-import javax.sql.*;
-
-//import javax.transaction.*;
-import java.sql.*;
-
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
-import javax.naming.NamingException;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.SystemException;
-
 public class MaxPoolSizeDUnitTest extends DistributedTestCase {
 
   static DistributedSystem ds;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/RollbackThread.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/RollbackThread.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/RollbackThread.java
index 9c45db7..f55ab17 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/RollbackThread.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/RollbackThread.java
@@ -14,30 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-                                                                                                                             
 package com.gemstone.gemfire.internal.jta.dunit;
                                                                                                                              
-//import dunit.*;
-//import java.io.*;
-//import java.util.*;
-//import java.net.*;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.distributed.*;
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
+import java.sql.Connection;
+import java.sql.SQLException;
+import java.sql.Statement;
+
 import javax.naming.Context;
-import javax.sql.*;
-import javax.transaction.*;
-import java.sql.*;
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
 import javax.naming.NamingException;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.SystemException;
+import javax.sql.DataSource;
+import javax.transaction.UserTransaction;
+
+import com.gemstone.gemfire.LogWriter;
+import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
-//import com.gemstone.gemfire.internal.jta.JTAUtils;
                                                                                                                              
 /**
 *This is thread class

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TransactionTimeOutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TransactionTimeOutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TransactionTimeOutDUnitTest.java
index 3ed2f91..22b8bff 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TransactionTimeOutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TransactionTimeOutDUnitTest.java
@@ -16,18 +16,24 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
-
-import javax.naming.Context;
-import javax.transaction.*;
-import javax.naming.NamingException;
-
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
 import java.sql.Connection;
 import java.sql.ResultSet;
 import java.sql.SQLException;
 import java.sql.Statement;
 import java.util.Properties;
 
+import javax.naming.Context;
+import javax.naming.NamingException;
+import javax.sql.DataSource;
+import javax.transaction.UserTransaction;
+
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.distributed.DistributedSystem;
@@ -35,12 +41,12 @@ import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.datasource.GemFireTransactionDataSource;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
 import com.gemstone.gemfire.internal.jta.UserTransactionImpl;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import javax.sql.DataSource;
-
-import java.io.*;
-
 /**
 *@author Mitul D Bid
 *This test tests TransactionTimeOut functionality

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnManagerMultiThreadDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnManagerMultiThreadDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnManagerMultiThreadDUnitTest.java
index 7662eef..83e29af 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnManagerMultiThreadDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnManagerMultiThreadDUnitTest.java
@@ -16,41 +16,38 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
+import java.sql.Connection;
+import java.sql.SQLException;
+import java.sql.Statement;
+import java.util.Properties;
 
-import java.io.*;
-import java.util.*;
-
-//import java.net.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
-
-//import java.util.Hashtable;
-//import javax.naming.InitialContext;
 import javax.naming.Context;
-import javax.sql.*;
-
-//import javax.sql.DataSource.*;
-//import javax.transaction.*;
-import java.sql.*;
-
-//import java.lang.Exception.*;
-//import java.lang.RuntimeException;
-//import java.sql.SQLException.*;
 import javax.naming.NamingException;
+import javax.sql.DataSource;
 
+import org.junit.FixMethodOrder;
+import org.junit.runners.MethodSorters;
 
-
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
-//import javax.naming.NoInitialContextException;
-//import javax.transaction.SystemException;
-import com.gemstone.gemfire.internal.jta.*;
+import com.gemstone.gemfire.internal.jta.CacheUtils;
+import com.gemstone.gemfire.internal.jta.JTAUtils;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-import org.junit.FixMethodOrder;
-import org.junit.runners.MethodSorters;
- 
-
 /**
  * This test case is to test the following test scenarios: 1) Behaviour of
  * Transaction Manager in multy threaded thransactions. We will have around five

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnTimeOutDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnTimeOutDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnTimeOutDUnitTest.java
index a736336..7e81aae 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnTimeOutDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/jta/dunit/TxnTimeOutDUnitTest.java
@@ -16,34 +16,31 @@
  */
 package com.gemstone.gemfire.internal.jta.dunit;
 
-import dunit.*;
+import java.io.BufferedReader;
+import java.io.BufferedWriter;
+import java.io.File;
+import java.io.FileOutputStream;
+import java.io.FileReader;
+import java.io.IOException;
+import java.io.OutputStreamWriter;
+import java.sql.SQLException;
+import java.util.Properties;
 
 import javax.naming.Context;
-import javax.transaction.*;
 import javax.naming.NamingException;
-
-
-
-//import java.sql.Connection;
-//import java.sql.ResultSet;
-import java.sql.SQLException;
-//import java.sql.Statement;
-import java.util.Properties;
+import javax.transaction.UserTransaction;
 
 import com.gemstone.gemfire.cache.Cache;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.distributed.DistributedSystem;
 import com.gemstone.gemfire.internal.OSProcess;
 import com.gemstone.gemfire.internal.jta.CacheUtils;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.VM;
 import com.gemstone.gemfire.util.test.TestUtil;
 
-
-
-//import com.gemstone.gemfire.internal.datasource.GemFireTransactionDataSource;
-//import com.gemstone.gemfire.internal.jta.UserTransactionImpl;
-//import javax.sql.DataSource;
-import java.io.*;
-
 /**
 *@author Mitul D Bid
 *This test sees if the TransactionTimeOut works properly

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/DistributedSystemLogFileJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/DistributedSystemLogFileJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/DistributedSystemLogFileJUnitTest.java
index d9bac84..a8b664e 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/DistributedSystemLogFileJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/DistributedSystemLogFileJUnitTest.java
@@ -43,11 +43,10 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.logging.log4j.FastLogger;
 import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Connects DistributedSystem and tests logging behavior at a high level.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/LocatorLogFileJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/LocatorLogFileJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/LocatorLogFileJUnitTest.java
index 7bb50fb..d817f74 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/LocatorLogFileJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/LocatorLogFileJUnitTest.java
@@ -35,11 +35,10 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.AvailablePort;
 import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * Creates Locator and tests logging behavior at a high level.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/MergeLogFilesJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/MergeLogFilesJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/MergeLogFilesJUnitTest.java
index 4577f62..e076d04 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/MergeLogFilesJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/logging/MergeLogFilesJUnitTest.java
@@ -41,10 +41,9 @@ import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.LogWriter;
 import com.gemstone.gemfire.SystemFailure;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-
 /**
  * This class tests the functionality of the (new multi-threaded)
  * {@link MergeLogFiles} utility.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java
index 2f539d5..1c3a33a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OffHeapRegionBase.java
@@ -44,8 +44,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Retained;
 import com.gemstone.gemfire.pdx.PdxReader;
 import com.gemstone.gemfire.pdx.PdxSerializable;
 import com.gemstone.gemfire.pdx.PdxWriter;
-
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * Basic test of regions that use off heap storage.
@@ -147,7 +146,7 @@ public abstract class OffHeapRegionBase {
           return "Waiting for disconnect to complete";
         }
       };
-      dunit.DistributedTestCase.waitForCriterion(waitForDisconnect, 10*1000, 100, true);
+      com.gemstone.gemfire.test.dunit.DistributedTestCase.waitForCriterion(waitForDisconnect, 10*1000, 100, true);
 
       assertTrue(gfc.isClosed());
     } finally {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OutOfOffHeapMemoryDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OutOfOffHeapMemoryDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OutOfOffHeapMemoryDUnitTest.java
index 2c351be..77814b0 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OutOfOffHeapMemoryDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/offheap/OutOfOffHeapMemoryDUnitTest.java
@@ -37,9 +37,8 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.OffHeapTestUtil;
 import com.gemstone.gemfire.internal.logging.LogService;
 import com.gemstone.gemfire.internal.util.StopWatch;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 
 /**
  * Test behavior of region when running out of off-heap memory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/process/LocalProcessLauncherDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/process/LocalProcessLauncherDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/process/LocalProcessLauncherDUnitTest.java
index daaa9ab..1a27437 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/process/LocalProcessLauncherDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/process/LocalProcessLauncherDUnitTest.java
@@ -25,12 +25,11 @@ import java.io.IOException;
 import org.junit.experimental.categories.Category;
 
 import com.gemstone.gemfire.internal.process.LocalProcessLauncher;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.junit.categories.UnitTest;
 
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-
 /**
  * Multi-process tests for ProcessLauncher.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/StatisticsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/StatisticsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/StatisticsDUnitTest.java
index befa7da..40aa750 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/StatisticsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/StatisticsDUnitTest.java
@@ -60,11 +60,10 @@ import com.gemstone.gemfire.internal.StatArchiveReader.StatSpec;
 import com.gemstone.gemfire.internal.StatSamplerStats;
 import com.gemstone.gemfire.internal.StatisticsTypeFactoryImpl;
 import com.gemstone.gemfire.internal.StatArchiveReader.StatValue;
-
-import dunit.AsyncInvocation;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Integration tests for Statistics. VM0 performs puts and VM1 receives

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/ValueMonitorJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/ValueMonitorJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/ValueMonitorJUnitTest.java
index 8eb4fdf..cc76ce2 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/ValueMonitorJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/statistics/ValueMonitorJUnitTest.java
@@ -39,10 +39,10 @@ import com.gemstone.gemfire.StatisticsType;
 import com.gemstone.gemfire.internal.NanoTimer;
 import com.gemstone.gemfire.internal.StatisticsManager;
 import com.gemstone.gemfire.internal.statistics.StatisticsNotification.Type;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
 
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
 import junit.framework.TestCase;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
index b9762a4..2698e2a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/CacheManagementDUnitTest.java
@@ -45,13 +45,13 @@ import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.ManagementConstants;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
 import com.gemstone.gemfire.management.internal.NotificationHub.NotificationHubListener;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import static com.jayway.awaitility.Awaitility.*;
 import static org.hamcrest.Matchers.*;
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.SerializableRunnable;
-import dunit.VM;
 
 /**
  * This class checks and verifies various data and operations exposed through

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
index 1bdb892..7f7c4fd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/ClientHealthStatsDUnitTest.java
@@ -46,13 +46,12 @@ import com.gemstone.gemfire.internal.cache.ha.Bug48571DUnitTest;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
 import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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.DistributedTestCase.WaitCriterion;
 
 /**
  * Client health stats check

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/CompositeTypeTestDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/CompositeTypeTestDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/CompositeTypeTestDUnitTest.java
index c6263d4..54078e8 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/CompositeTypeTestDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/CompositeTypeTestDUnitTest.java
@@ -24,9 +24,8 @@ import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.ManagementConstants;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class CompositeTypeTestDUnitTest extends ManagementTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/DLockManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DLockManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DLockManagementDUnitTest.java
index d00e3a4..793526c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DLockManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DLockManagementDUnitTest.java
@@ -29,9 +29,8 @@ import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedM
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 public class DLockManagementDUnitTest extends ManagementTestBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/DiskManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DiskManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DiskManagementDUnitTest.java
index 9749a59..c9a177a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DiskManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DiskManagementDUnitTest.java
@@ -41,11 +41,10 @@ import com.gemstone.gemfire.internal.cache.LocalRegion;
 import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
 import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
-
-import dunit.AsyncInvocation;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Test cases to cover all test cases which pertains to disk from Management

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
index 005ed1c..1a52f9b 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/DistributedSystemDUnitTest.java
@@ -49,11 +49,10 @@ import com.gemstone.gemfire.management.internal.NotificationHub.NotificationHubL
 import com.gemstone.gemfire.management.internal.SystemManagementService;
 import com.gemstone.gemfire.management.internal.beans.MemberMBean;
 import com.gemstone.gemfire.management.internal.beans.SequenceNumber;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Distributed System tests

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
index e799495..631c9d0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/LocatorManagementDUnitTest.java
@@ -31,10 +31,9 @@ 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 dunit.Host;
-import dunit.SerializableCallable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/MBeanUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/MBeanUtil.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/MBeanUtil.java
index f568d65..171204c 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/MBeanUtil.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/MBeanUtil.java
@@ -36,9 +36,8 @@ import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.ManagementConstants;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.DistributedTestCase;
-import dunit.DistributedTestCase.WaitCriterion;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
 
 /**
  * Utility test class to get various proxies

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
index 9656042..ab2f1ce 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/ManagementTestBase.java
@@ -42,13 +42,12 @@ import com.gemstone.gemfire.management.internal.LocalManager;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.ManagementStrings;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.AsyncInvocation;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.AsyncInvocation;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 public class ManagementTestBase extends DistributedTestCase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/MemberMBeanAttributesDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/MemberMBeanAttributesDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/MemberMBeanAttributesDUnitTest.java
index 3990595..50db569 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/MemberMBeanAttributesDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/MemberMBeanAttributesDUnitTest.java
@@ -26,9 +26,8 @@ import com.gemstone.gemfire.internal.NanoTimer;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.process.PidUnavailableException;
 import com.gemstone.gemfire.internal.process.ProcessUtils;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This test class checks around 89 attributes of Member MBeans

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
index 16a12ff..4e2c278 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/OffHeapManagementDUnitTest.java
@@ -40,11 +40,10 @@ import com.gemstone.gemfire.internal.offheap.OffHeapMemoryStats;
 import com.gemstone.gemfire.internal.offheap.OffHeapStorage;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.beans.MemberMBean;
-
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+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;
 
 /**
  * Tests the off-heap additions to the RegionMXBean and MemberMXBean JMX interfaces.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/QueryDataDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/QueryDataDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/QueryDataDUnitTest.java
index e8f691d..f55511f 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/QueryDataDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/QueryDataDUnitTest.java
@@ -53,14 +53,14 @@ import com.gemstone.gemfire.management.internal.cli.json.TypedJson;
 import com.gemstone.gemfire.pdx.PdxInstance;
 import com.gemstone.gemfire.pdx.PdxInstanceFactory;
 import com.gemstone.gemfire.pdx.internal.PdxInstanceFactoryImpl;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase.WaitCriterion;
+
 import org.json.JSONArray;
 import org.json.JSONException;
 import org.json.JSONObject;
 
-import dunit.DistributedTestCase;
-import dunit.SerializableRunnable;
-import dunit.DistributedTestCase.WaitCriterion;
-
 /**
  * 
  * @author rishim

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/RegionManagementDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/RegionManagementDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/RegionManagementDUnitTest.java
index 82bcf71..c148029 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/RegionManagementDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/RegionManagementDUnitTest.java
@@ -49,9 +49,8 @@ import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
 import com.gemstone.gemfire.internal.cache.partitioned.fixed.SingleHopQuarterPartitionResolver;
 import com.gemstone.gemfire.management.internal.MBeanJMXAdapter;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * This class checks and verifies various data and operations exposed through

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
index 695b88a..296d13d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/UniversalMembershipListenerAdapterDUnitTest.java
@@ -49,10 +49,9 @@ import com.gemstone.gemfire.management.membership.ClientMembershipListener;
 import com.gemstone.gemfire.management.membership.MembershipEvent;
 import com.gemstone.gemfire.management.membership.MembershipListener;
 import com.gemstone.gemfire.management.membership.UniversalMembershipListenerAdapter;
-
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * Tests the UniversalMembershipListenerAdapter.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/DistributedSystemStatsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/DistributedSystemStatsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/DistributedSystemStatsDUnitTest.java
index b53c305..b7b3a70 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/DistributedSystemStatsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/bean/stats/DistributedSystemStatsDUnitTest.java
@@ -29,9 +29,8 @@ import com.gemstone.gemfire.management.MemberMXBean;
 import com.gemstone.gemfire.management.internal.SystemManagementService;
 import com.gemstone.gemfire.management.internal.beans.MemberMBean;
 import com.gemstone.gemfire.management.internal.beans.MemberMBeanBridge;
-
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 /**
  * @author rishim

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
index ce76742..5c68915 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/CliUtilDUnitTest.java
@@ -37,12 +37,11 @@ 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 dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CliCommandTestBase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CliCommandTestBase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CliCommandTestBase.java
index a0fb8f8..4d8f8ff 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CliCommandTestBase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CliCommandTestBase.java
@@ -28,9 +28,10 @@ import com.gemstone.gemfire.management.internal.cli.parser.CommandTarget;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.shell.Gfsh;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableCallable;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+
 import util.TestException;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ConfigCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ConfigCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ConfigCommandsDUnitTest.java
index 81536db..37f7520 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ConfigCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ConfigCommandsDUnitTest.java
@@ -35,11 +35,12 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandProcessor;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 org.apache.commons.io.FileUtils;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CreateAlterDestroyRegionCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CreateAlterDestroyRegionCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CreateAlterDestroyRegionCommandsDUnitTest.java
index 18dfe67..9c0fa21 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CreateAlterDestroyRegionCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/CreateAlterDestroyRegionCommandsDUnitTest.java
@@ -40,11 +40,11 @@ import com.gemstone.gemfire.management.internal.ManagementConstants;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 javax.management.MBeanServer;
 import javax.management.MalformedObjectNameException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DeployCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DeployCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DeployCommandsDUnitTest.java
index eeb9896..2e2a2d5 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DeployCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DeployCommandsDUnitTest.java
@@ -29,10 +29,10 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandExecutionContext;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandProcessor;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.FilenameFilter;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DiskStoreCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DiskStoreCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DiskStoreCommandsDUnitTest.java
index 83264d5..b32a3a0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DiskStoreCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/DiskStoreCommandsDUnitTest.java
@@ -46,11 +46,12 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.shell.Gfsh;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 org.junit.Test;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/FunctionCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/FunctionCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/FunctionCommandsDUnitTest.java
index 8c3dd22..1698609 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/FunctionCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/FunctionCommandsDUnitTest.java
@@ -31,11 +31,11 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.json.GfJsonException;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 java.util.List;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GemfireDataCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GemfireDataCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GemfireDataCommandsDUnitTest.java
index 1a64faf..76f51de 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GemfireDataCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GemfireDataCommandsDUnitTest.java
@@ -55,11 +55,12 @@ import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData.S
 import com.gemstone.gemfire.management.internal.cli.result.ResultData;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 hydra.GsRandom;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
index 1e234c5..96cf859 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/GetCommandOnRegionWithCacheLoaderDuringCacheMissDUnitTest.java
@@ -34,10 +34,10 @@ import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData;
 import com.gemstone.gemfire.management.internal.cli.result.ResultData;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.Serializable;
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/IndexCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/IndexCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/IndexCommandsDUnitTest.java
index bb99dc2..99ba73d 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/IndexCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/IndexCommandsDUnitTest.java
@@ -35,11 +35,11 @@ import com.gemstone.gemfire.management.internal.cli.domain.Stock;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.DistributedTestCase;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.DistributedTestCase;
+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 java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
index e7bc575..1d1d491 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeDiskStoreCommandsDUnitTest.java
@@ -25,9 +25,9 @@ import com.gemstone.gemfire.cache.Scope;
 import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.Serializable;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeRegionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeRegionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeRegionDUnitTest.java
index 5c172cc..a81a085 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeRegionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListAndDescribeRegionDUnitTest.java
@@ -34,9 +34,9 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
 import com.gemstone.gemfire.management.internal.cli.util.RegionAttributesNames;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
index 22a38d2..1a611ec 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/ListIndexCommandDUnitTest.java
@@ -32,9 +32,9 @@ import com.gemstone.gemfire.internal.lang.StringUtils;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.domain.IndexDetails;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.Serializable;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MemberCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MemberCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MemberCommandsDUnitTest.java
index e6272a7..a000053 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MemberCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MemberCommandsDUnitTest.java
@@ -38,9 +38,9 @@ import com.gemstone.gemfire.management.internal.cli.CliUtil;
 import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.remote.CommandProcessor;
 import com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsDUnitTest.java
index ca3f94d..c449a18 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsDUnitTest.java
@@ -32,13 +32,14 @@ import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
 import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData;
 import com.gemstone.gemfire.management.internal.cli.result.CompositeResultData.SectionResultData;
+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.management.internal.cli.result.ResultBuilder;
 import com.gemstone.gemfire.management.internal.cli.result.ResultData;
 import com.gemstone.gemfire.management.internal.cli.result.TabularResultData;
-import dunit.Host;
-import dunit.SerializableCallable;
-import dunit.SerializableRunnable;
-import dunit.VM;
+
 import org.junit.Ignore;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart1DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart1DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart1DUnitTest.java
index 6afa7ee..1bd8999 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart1DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart1DUnitTest.java
@@ -24,9 +24,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.logging.LogWriterImpl;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/d89038db/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart2DUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart2DUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart2DUnitTest.java
index 6a1d86c..74aedd1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart2DUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/management/internal/cli/commands/MiscellaneousCommandsExportLogsPart2DUnitTest.java
@@ -24,9 +24,9 @@ import com.gemstone.gemfire.internal.FileUtil;
 import com.gemstone.gemfire.internal.logging.LogWriterImpl;
 import com.gemstone.gemfire.management.cli.Result;
 import com.gemstone.gemfire.management.internal.cli.result.CommandResult;
-import dunit.Host;
-import dunit.SerializableRunnable;
-import dunit.VM;
+import com.gemstone.gemfire.test.dunit.Host;
+import com.gemstone.gemfire.test.dunit.SerializableRunnable;
+import com.gemstone.gemfire.test.dunit.VM;
 
 import java.io.File;
 import java.io.IOException;



[31/52] [abbrv] incubator-geode git commit: GEODE-857: Fixing synchronization in SystemFailure.stopWatchDog

Posted by ds...@apache.org.
GEODE-857: Fixing synchronization in SystemFailure.stopWatchDog

Don't join the watchDog thread or the proctor thread while holding the
failureSync lock.

Adding a unit test for SystemFailure.stopThreads.


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/30d2d64d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/30d2d64d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/30d2d64d

Branch: refs/heads/feature/GEODE-831
Commit: 30d2d64d02c50df54d98aede41cdbbe56569dc43
Parents: 45d5eda
Author: Dan Smith <up...@apache.org>
Authored: Mon Jan 25 16:42:25 2016 -0800
Committer: Dan Smith <up...@apache.org>
Committed: Tue Jan 26 17:01:37 2016 -0800

----------------------------------------------------------------------
 .../com/gemstone/gemfire/SystemFailure.java     | 49 ++++++++++------
 .../gemfire/SystemFailureJUnitTest.java         | 60 ++++++++++++++++++++
 2 files changed, 93 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/30d2d64d/gemfire-core/src/main/java/com/gemstone/gemfire/SystemFailure.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/SystemFailure.java b/gemfire-core/src/main/java/com/gemstone/gemfire/SystemFailure.java
index 494f5f7..1775063 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/SystemFailure.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/SystemFailure.java
@@ -192,6 +192,11 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 public final class SystemFailure {
 
   /**
+   * Time to wait during stopWatchdog and stopProctor. Not final
+   * for tests
+   */
+  static int SHUTDOWN_WAIT = 1000;
+  /**
    * Preallocated error messages\
    * LocalizedStrings may use memory (in the form of an iterator)
    * so we must get the translated messages in advance.
@@ -384,23 +389,26 @@ public final class SystemFailure {
   }
   
   private static void stopWatchDog() {
+    Thread watchDogSnapshot = null;
     synchronized (failureSync) {
       stopping = true;
       if (watchDog != null && watchDog.isAlive()) {
         failureSync.notifyAll();
+        watchDogSnapshot = watchDog;
+      }
+    }
+    if(watchDogSnapshot != null) {
+      try {
+        watchDogSnapshot.join(100);
+      } catch (InterruptedException ignore) {
+      }
+      if (watchDogSnapshot.isAlive()) {
+        watchDogSnapshot.interrupt();
         try {
-          watchDog.join(100);
+          watchDogSnapshot.join(SHUTDOWN_WAIT);
         } catch (InterruptedException ignore) {
         }
-        if (watchDog.isAlive()) {
-          watchDog.interrupt();
-          try {
-            watchDog.join(1000);
-          } catch (InterruptedException ignore) {
-          }
-        }
       }
-      watchDog = null;
     }
   }
   
@@ -634,16 +642,17 @@ public final class SystemFailure {
   }
   
   private static void stopProctor() {
+    Thread proctorSnapshot = null;
     synchronized (failureSync) {
       stopping = true;
-      if (proctor != null && proctor.isAlive()) {
-        proctor.interrupt();
-        try {
-          proctor.join(1000);
-        } catch (InterruptedException ignore) {
-        }
+      proctorSnapshot = proctor;
+    }
+    if (proctorSnapshot != null && proctorSnapshot.isAlive()) {
+      proctorSnapshot.interrupt();
+      try {
+        proctorSnapshot.join(SHUTDOWN_WAIT);
+      } catch (InterruptedException ignore) {
       }
-      proctor = null;
     }
   }
   
@@ -1219,4 +1228,12 @@ public final class SystemFailure {
     stopProctor();
     stopWatchDog();
   }
+  
+  static Thread getWatchDogForTest() {
+    return watchDog;
+  }
+  
+  static Thread getProctorForTest() {
+    return proctor;
+  }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/30d2d64d/gemfire-core/src/test/java/com/gemstone/gemfire/SystemFailureJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/SystemFailureJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/SystemFailureJUnitTest.java
new file mode 100644
index 0000000..e33eba4
--- /dev/null
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/SystemFailureJUnitTest.java
@@ -0,0 +1,60 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package com.gemstone.gemfire;
+
+import static org.junit.Assert.*;
+
+import java.util.concurrent.TimeUnit;
+
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import com.gemstone.gemfire.test.junit.categories.UnitTest;
+
+@Category(UnitTest.class)
+public class SystemFailureJUnitTest {
+
+  private static final int LONG_WAIT = 30000;
+  private int oldWaitTime;
+  @Before
+  public void setWaitTime() {
+    oldWaitTime = SystemFailure.SHUTDOWN_WAIT;
+    SystemFailure.SHUTDOWN_WAIT = LONG_WAIT;
+  }
+  
+  @After
+  public void restoreWaitTime() {
+    SystemFailure.SHUTDOWN_WAIT = oldWaitTime;
+  }
+  @Test
+  public void testStopThreads() {
+    SystemFailure.startThreads();
+    long start = System.nanoTime();
+    Thread watchDog = SystemFailure.getWatchDogForTest();
+    Thread proctor= SystemFailure.getProctorForTest();
+    assertTrue(watchDog.isAlive());
+    assertTrue(proctor.isAlive());
+    SystemFailure.stopThreads();
+    long elapsed = System.nanoTime() - start;
+    assertTrue("Waited too long to shutdown: " + elapsed, elapsed < TimeUnit.MILLISECONDS.toNanos(LONG_WAIT));
+    assertFalse(watchDog.isAlive());
+    assertFalse(proctor.isAlive());
+  }
+
+}