You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by hi...@apache.org on 2016/09/09 21:42:58 UTC

[01/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-37_1 8fd8d79df -> eff7f2163


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpB2NRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpB2NRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpB2NRegion.java
index 1142265..56ec025 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpB2NRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpB2NRegion.java
@@ -16,7 +16,7 @@
  */
 
 
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,34 +28,34 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message used for debugging purposes. For example if a test fails it can
  * call 
- * {@link com.gemstone.gemfire.internal.cache.PartitionedRegion#sendDumpB2NRegionForBucket(int)}
+ * {@link org.apache.geode.internal.cache.PartitionedRegion#sendDumpB2NRegionForBucket(int)}
  * which sends this message to all VMs that have that PartitionedRegion defined.
  * 
- * @see com.gemstone.gemfire.internal.cache.PartitionedRegion#sendDumpB2NRegionForBucket(int)
+ * @see org.apache.geode.internal.cache.PartitionedRegion#sendDumpB2NRegionForBucket(int)
  */
 public final class DumpB2NRegion extends PartitionMessage
   {
@@ -322,7 +322,7 @@ public final class DumpB2NRegion extends PartitionMessage
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage#appendFields(java.lang.StringBuffer)
+   * @see org.apache.geode.internal.cache.partitioned.PartitionMessage#appendFields(java.lang.StringBuffer)
    */
   @Override
   protected void appendFields(StringBuffer buff) {


[48/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerSessionCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerSessionCache.java
index 2de43b4..333b355 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerSessionCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerSessionCache.java
@@ -14,29 +14,29 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
-
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.modules.session.catalina.callback.SessionExpirationCacheListener;
-import com.gemstone.gemfire.modules.util.BootstrappingFunction;
-import com.gemstone.gemfire.modules.util.CreateRegionFunction;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.RegionSizeFunction;
-import com.gemstone.gemfire.modules.util.RegionStatus;
-import com.gemstone.gemfire.modules.util.SessionCustomExpiry;
-import com.gemstone.gemfire.modules.util.TouchPartitionedRegionEntriesFunction;
-import com.gemstone.gemfire.modules.util.TouchReplicatedRegionEntriesFunction;
+package org.apache.geode.modules.session.catalina;
+
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.modules.session.catalina.callback.SessionExpirationCacheListener;
+import org.apache.geode.modules.util.BootstrappingFunction;
+import org.apache.geode.modules.util.CreateRegionFunction;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.RegionSizeFunction;
+import org.apache.geode.modules.util.RegionStatus;
+import org.apache.geode.modules.util.SessionCustomExpiry;
+import org.apache.geode.modules.util.TouchPartitionedRegionEntriesFunction;
+import org.apache.geode.modules.util.TouchReplicatedRegionEntriesFunction;
 
 import javax.servlet.http.HttpSession;
 import java.util.HashSet;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/CommitSessionValve.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/CommitSessionValve.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/CommitSessionValve.java
index 379fb18..a6568e6 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/CommitSessionValve.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/CommitSessionValve.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.Manager;
 import org.apache.catalina.connector.Request;
@@ -30,7 +30,7 @@ public class CommitSessionValve extends ValveBase {
 
   private static final Log log = LogFactory.getLog(CommitSessionValve.class);
 
-  protected static final String info = "com.gemstone.gemfire.modules.session.catalina.CommitSessionValve/1.0";
+  protected static final String info = "org.apache.geode.modules.session.catalina.CommitSessionValve/1.0";
 
   public CommitSessionValve() {
     log.info("Initialized");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession.java
index 754376a..8691829 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession.java
@@ -14,21 +14,21 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
-
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Delta;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.modules.gatewaydelta.GatewayDelta;
-import com.gemstone.gemfire.modules.gatewaydelta.GatewayDeltaEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionAttributeEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionAttributeEventBatch;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionDestroyAttributeEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionUpdateAttributeEvent;
+package org.apache.geode.modules.session.catalina;
+
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Delta;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.modules.gatewaydelta.GatewayDelta;
+import org.apache.geode.modules.gatewaydelta.GatewayDeltaEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionAttributeEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionAttributeEventBatch;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionDestroyAttributeEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionUpdateAttributeEvent;
 import org.apache.catalina.Manager;
 import org.apache.catalina.ha.session.SerializablePrincipal;
 import org.apache.catalina.realm.GenericPrincipal;
@@ -86,7 +86,7 @@ public class DeltaSession extends StandardSession implements DataSerializable, D
    * The string manager for this package.
    */
 //  protected static StringManager STRING_MANAGER =
-//    StringManager.getManager("com.gemstone.gemfire.modules.session.catalina");
+//    StringManager.getManager("org.apache.geode.modules.session.catalina");
 
   /**
    * Construct a new <code>Session</code> associated with no <code>Manager</code>. The <code>Manager</code> will be

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionFacade.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionFacade.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionFacade.java
index 2259ffe..a64e408 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionFacade.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionFacade.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.session.StandardSessionFacade;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionInterface.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionInterface.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionInterface.java
index a293432..cbcd569 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionInterface.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionInterface.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 
 
@@ -28,7 +28,7 @@ import java.util.List;
 import org.apache.catalina.Session;
 import org.apache.catalina.session.ManagerBase;
 
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionAttributeEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionAttributeEvent;
 
 public interface DeltaSessionInterface extends Session {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionManager.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionManager.java
index d1b6011..5e70c2f 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionManager.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/DeltaSessionManager.java
@@ -14,18 +14,18 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
-
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-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.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionStatistics;
-import com.gemstone.gemfire.modules.util.ContextMapper;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.RegionHelper;
+package org.apache.geode.modules.session.catalina;
+
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionStatistics;
+import org.apache.geode.modules.util.ContextMapper;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.RegionHelper;
 import org.apache.catalina.Container;
 import org.apache.catalina.Context;
 import org.apache.catalina.Lifecycle;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/JvmRouteBinderValve.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/JvmRouteBinderValve.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/JvmRouteBinderValve.java
index 98481c7..0254fb4 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/JvmRouteBinderValve.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/JvmRouteBinderValve.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.Manager;
 import org.apache.catalina.Session;
@@ -27,7 +27,7 @@ import java.io.IOException;
 
 public class JvmRouteBinderValve extends ValveBase {
 
-  protected static final String info = "com.gemstone.gemfire.modules.session.JvmRouteBinderValve/1.0";
+  protected static final String info = "org.apache.geode.modules.session.JvmRouteBinderValve/1.0";
 
   @Override
   public void invoke(Request request, Response response) throws IOException, ServletException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerCacheLifecycleListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerCacheLifecycleListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerCacheLifecycleListener.java
index a86486c..254e4d3 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerCacheLifecycleListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerCacheLifecycleListener.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
-import com.gemstone.gemfire.modules.session.bootstrap.PeerToPeerCache;
+import org.apache.geode.modules.session.bootstrap.PeerToPeerCache;
 
 /**
  * This is a thin wrapper around a peer-to-peer cache.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerSessionCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerSessionCache.java
index 2c76ca5..82bcc6f 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerSessionCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/PeerToPeerSessionCache.java
@@ -14,24 +14,24 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.modules.session.catalina.callback.LocalSessionCacheLoader;
-import com.gemstone.gemfire.modules.session.catalina.callback.LocalSessionCacheWriter;
-import com.gemstone.gemfire.modules.session.catalina.callback.SessionExpirationCacheListener;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.RegionHelper;
-import com.gemstone.gemfire.modules.util.SessionCustomExpiry;
-import com.gemstone.gemfire.modules.util.TouchPartitionedRegionEntriesFunction;
-import com.gemstone.gemfire.modules.util.TouchReplicatedRegionEntriesFunction;
+package org.apache.geode.modules.session.catalina;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.modules.session.catalina.callback.LocalSessionCacheLoader;
+import org.apache.geode.modules.session.catalina.callback.LocalSessionCacheWriter;
+import org.apache.geode.modules.session.catalina.callback.SessionExpirationCacheListener;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.RegionHelper;
+import org.apache.geode.modules.util.SessionCustomExpiry;
+import org.apache.geode.modules.util.TouchPartitionedRegionEntriesFunction;
+import org.apache.geode.modules.util.TouchReplicatedRegionEntriesFunction;
 
 import javax.servlet.http.HttpSession;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionCache.java
index b1128e7..fc6c3cd 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionCache.java
@@ -14,11 +14,11 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionStatistics;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionStatistics;
 import org.apache.catalina.Session;
 
 import javax.servlet.http.HttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionManager.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionManager.java
index e3d6c7e..6afd1ca 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionManager.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/SessionManager.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.juli.logging.Log;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/Tomcat6DeltaSessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/Tomcat6DeltaSessionManager.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/Tomcat6DeltaSessionManager.java
index c89b990..f35c088 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/Tomcat6DeltaSessionManager.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/Tomcat6DeltaSessionManager.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.LifecycleException;
 import org.apache.catalina.LifecycleListener;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheLoader.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheLoader.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheLoader.java
index a4afad4..ca86051 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheLoader.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheLoader.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.callback;
+package org.apache.geode.modules.session.catalina.callback;
 
-import com.gemstone.gemfire.cache.CacheLoader;
-import com.gemstone.gemfire.cache.CacheLoaderException;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.LoaderHelper;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.LoaderHelper;
+import org.apache.geode.cache.Region;
 
 import javax.servlet.http.HttpSession;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriter.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriter.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriter.java
index 0385ebf..a138f86 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriter.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/LocalSessionCacheWriter.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.callback;
-
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+package org.apache.geode.modules.session.catalina.callback;
+
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.util.CacheWriterAdapter;
 
 import javax.servlet.http.HttpSession;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/SessionExpirationCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/SessionExpirationCacheListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/SessionExpirationCacheListener.java
index da9fffc..fd2b472 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/SessionExpirationCacheListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/callback/SessionExpirationCacheListener.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.callback;
+package org.apache.geode.modules.session.catalina.callback;
 
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
-import com.gemstone.gemfire.modules.util.ContextMapper;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.modules.util.ContextMapper;
 
 import javax.servlet.http.HttpSession;
 import java.util.Properties;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEvent.java
index c930d6f..9bc9f7e 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEvent.java
@@ -14,11 +14,11 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.internal;
+package org.apache.geode.modules.session.catalina.internal;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSession;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.modules.session.catalina.DeltaSession;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
 
 public interface DeltaSessionAttributeEvent extends DataSerializable {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEventBatch.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEventBatch.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEventBatch.java
index 8e4c0c3..3ccd2d0 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEventBatch.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionAttributeEventBatch.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.internal;
+package org.apache.geode.modules.session.catalina.internal;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.gatewaydelta.AbstractGatewayDeltaEvent;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSession;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.gatewaydelta.AbstractGatewayDeltaEvent;
+import org.apache.geode.modules.session.catalina.DeltaSession;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionDestroyAttributeEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionDestroyAttributeEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionDestroyAttributeEvent.java
index dd96f49..021f2ef 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionDestroyAttributeEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionDestroyAttributeEvent.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.internal;
+package org.apache.geode.modules.session.catalina.internal;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSession;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.modules.session.catalina.DeltaSession;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionStatistics.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionStatistics.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionStatistics.java
index 99a3a83..ed0196f 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionStatistics.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionStatistics.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.internal;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.modules.session.catalina.internal;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 public class DeltaSessionStatistics {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionUpdateAttributeEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionUpdateAttributeEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionUpdateAttributeEvent.java
index 7b47280..0ea8635 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionUpdateAttributeEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/internal/DeltaSessionUpdateAttributeEvent.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina.internal;
+package org.apache.geode.modules.session.catalina.internal;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSession;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.modules.session.catalina.DeltaSession;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/Banner.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/Banner.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/Banner.java
index 413da07..7aeb9ff 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/Banner.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/Banner.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.internal.GemFireVersion;
+import org.apache.geode.internal.GemFireVersion;
 
 import java.io.IOException;
 import java.io.InputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/BootstrappingFunction.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/BootstrappingFunction.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/BootstrappingFunction.java
index 827c6f7..943a803 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/BootstrappingFunction.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/BootstrappingFunction.java
@@ -14,19 +14,19 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+package org.apache.geode.modules.util;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 import java.util.List;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ClassLoaderObjectInputStream.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ClassLoaderObjectInputStream.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ClassLoaderObjectInputStream.java
index 8cd600e..e0297bb 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ClassLoaderObjectInputStream.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ClassLoaderObjectInputStream.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
 import java.io.IOException;
 import java.io.InputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ContextMapper.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ContextMapper.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ContextMapper.java
index e539d89..505b797 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ContextMapper.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ContextMapper.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
+import org.apache.geode.modules.session.catalina.DeltaSessionManager;
 
 import java.util.HashMap;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/CreateRegionFunction.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/CreateRegionFunction.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/CreateRegionFunction.java
index a9c9322..21d11d9 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/CreateRegionFunction.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/CreateRegionFunction.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
 import java.io.File;
 import java.io.FileWriter;
@@ -22,27 +22,27 @@ import java.io.IOException;
 import java.io.PrintWriter;
 import java.util.Properties;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-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.client.ClientCache;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DistributedMemberLock;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.internal.locks.DistributedMemberLock;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.InternalRegionArguments;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlGenerator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class CreateRegionFunction implements Function, Declarable {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/DebugCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/DebugCacheListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/DebugCacheListener.java
index baca5b8..2882f58 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/DebugCacheListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/DebugCacheListener.java
@@ -14,11 +14,11 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.util.CacheListenerAdapter;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ModuleStatistics.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ModuleStatistics.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ModuleStatistics.java
index 48020a3..1c41ec9 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ModuleStatistics.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ModuleStatistics.java
@@ -14,15 +14,15 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.modules.util;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * Statistics for modules.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfiguration.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfiguration.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfiguration.java
index 55d2599..f8825d2 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfiguration.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfiguration.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.CustomExpiry;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CustomExpiry;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfigurationCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfigurationCacheListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfigurationCacheListener.java
index c25082b..c05d9d6 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfigurationCacheListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionConfigurationCacheListener.java
@@ -14,16 +14,16 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.util.CacheListenerAdapter;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionHelper.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionHelper.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionHelper.java
index 78e4423..dc338a1 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionHelper.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionHelper.java
@@ -14,27 +14,27 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
-
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.ExpirationAction;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.control.RebalanceFactory;
-import com.gemstone.gemfire.cache.control.RebalanceOperation;
-import com.gemstone.gemfire.cache.control.RebalanceResults;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.cache.partition.PartitionMemberInfo;
-import com.gemstone.gemfire.cache.partition.PartitionRebalanceInfo;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
-import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
-import com.gemstone.gemfire.modules.gatewaydelta.GatewayDeltaForwarderCacheListener;
-import com.gemstone.gemfire.modules.session.catalina.callback.SessionExpirationCacheListener;
+package org.apache.geode.modules.util;
+
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.ExpirationAction;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.control.RebalanceFactory;
+import org.apache.geode.cache.control.RebalanceOperation;
+import org.apache.geode.cache.control.RebalanceResults;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.cache.partition.PartitionMemberInfo;
+import org.apache.geode.cache.partition.PartitionRebalanceInfo;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlGenerator;
+import org.apache.geode.internal.cache.xmlcache.RegionAttributesCreation;
+import org.apache.geode.modules.gatewaydelta.GatewayDeltaForwarderCacheListener;
+import org.apache.geode.modules.session.catalina.callback.SessionExpirationCacheListener;
 
 import java.io.PrintWriter;
 import java.io.StringWriter;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionSizeFunction.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionSizeFunction.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionSizeFunction.java
index 13791a3..5cad86c 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionSizeFunction.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionSizeFunction.java
@@ -14,12 +14,12 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionStatus.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionStatus.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionStatus.java
index fec1fc1..d539a5c 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionStatus.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/RegionStatus.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
 public enum RegionStatus {
   VALID, INVALID

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ResourceManagerValidator.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ResourceManagerValidator.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ResourceManagerValidator.java
index c5edeea..bf39bb2 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ResourceManagerValidator.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/ResourceManagerValidator.java
@@ -14,10 +14,10 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.control.ResourceManager;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.control.ResourceManager;
 
 import java.lang.management.ManagementFactory;
 import java.lang.management.RuntimeMXBean;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/SessionCustomExpiry.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/SessionCustomExpiry.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/SessionCustomExpiry.java
index 25ee3b1..2e6b3cf 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/SessionCustomExpiry.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/SessionCustomExpiry.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
+package org.apache.geode.modules.util;
 
-import com.gemstone.gemfire.cache.CustomExpiry;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.ExpirationAction;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.CustomExpiry;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.ExpirationAction;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.Region;
 
 import javax.servlet.http.HttpSession;
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchPartitionedRegionEntriesFunction.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchPartitionedRegionEntriesFunction.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchPartitionedRegionEntriesFunction.java
index 15212b7..ab630a2 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchPartitionedRegionEntriesFunction.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchPartitionedRegionEntriesFunction.java
@@ -14,16 +14,16 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
+package org.apache.geode.modules.util;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
 
 import java.util.Properties;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchReplicatedRegionEntriesFunction.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchReplicatedRegionEntriesFunction.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchReplicatedRegionEntriesFunction.java
index 0e1561e..f3bb294 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchReplicatedRegionEntriesFunction.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/util/TouchReplicatedRegionEntriesFunction.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.util;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
+package org.apache.geode.modules.util;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
 
 import java.util.Properties;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Callback.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Callback.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Callback.java
index 12e935d..4b04b56 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Callback.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Callback.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
 import javax.servlet.ServletException;
 import javax.servlet.http.HttpServletRequest;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/CommandServlet.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/CommandServlet.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/CommandServlet.java
index 32ac7d8..89e8d8d 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/CommandServlet.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/CommandServlet.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
 import javax.servlet.ServletConfig;
 import javax.servlet.ServletContext;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat.java
index 53a305e..1d97149 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import com.gemstone.gemfire.modules.session.catalina.JvmRouteBinderValve;
+import org.apache.geode.modules.session.catalina.JvmRouteBinderValve;
 import org.apache.catalina.Context;
 import org.apache.catalina.Engine;
 import org.apache.catalina.Host;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/QueryCommand.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/QueryCommand.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/QueryCommand.java
index a891c5a..81d5301 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/QueryCommand.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/QueryCommand.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
 /**
  * Basic commands to pass to our test servlet

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/TestSessionsBase.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/TestSessionsBase.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/TestSessionsBase.java
index 5726013..0b10da6 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/TestSessionsBase.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/TestSessionsBase.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 import java.beans.PropertyChangeEvent;
@@ -35,10 +35,10 @@ import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.Test;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
-import com.gemstone.gemfire.modules.session.catalina.PeerToPeerCacheLifecycleListener;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.modules.session.catalina.DeltaSessionManager;
+import org.apache.geode.modules.session.catalina.PeerToPeerCacheLifecycleListener;
 
 public abstract class TestSessionsBase {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Tomcat6SessionsJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Tomcat6SessionsJUnitTest.java b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Tomcat6SessionsJUnitTest.java
index bccf695..1a9c715 100644
--- a/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Tomcat6SessionsJUnitTest.java
+++ b/extensions/geode-modules/src/test/java/org/apache/geode/modules/session/Tomcat6SessionsJUnitTest.java
@@ -14,10 +14,10 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager;
+import org.apache.geode.test.junit.categories.UnitTest;
 import org.junit.BeforeClass;
 import org.junit.experimental.categories.Category;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Event.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Event.hbm.xml b/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Event.hbm.xml
index 17faf29..9843c51 100644
--- a/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Event.hbm.xml
+++ b/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Event.hbm.xml
@@ -3,7 +3,7 @@
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">
 
-<hibernate-mapping package="com.gemstone.gemfire.modules">
+<hibernate-mapping package="org.apache.geode.modules">
 	<class name="Event" table="EVENTS">
 		<cache usage="read-write"/>
 		<id name="id" column="EVENT_ID">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Person.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Person.hbm.xml b/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Person.hbm.xml
index c6380e7..7f6b0da 100644
--- a/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Person.hbm.xml
+++ b/extensions/geode-modules/src/test/resources/org/apache/geode/modules/Person.hbm.xml
@@ -3,7 +3,7 @@
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">
 
-<hibernate-mapping package="com.gemstone.gemfire.modules">
+<hibernate-mapping package="org.apache.geode.modules">
     <class name="Person" table="PERSON">
         <cache usage="read-write"/>
         <id name="id" column="PERSON_ID">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/build.gradle
----------------------------------------------------------------------
diff --git a/geode-assembly/build.gradle b/geode-assembly/build.gradle
index fd9f76c..3ed864b 100755
--- a/geode-assembly/build.gradle
+++ b/geode-assembly/build.gradle
@@ -99,7 +99,7 @@ tasks.withType(Test){
 
 task defaultDistributionConfig(type: JavaExec, dependsOn: classes) {
   outputs.file file("$buildDir/gemfire.properties")
-  main 'com.gemstone.gemfire.distributed.internal.DistributionConfigImpl'
+  main 'org.apache.geode.distributed.internal.DistributionConfigImpl'
   classpath project(':geode-core').sourceSets.main.runtimeClasspath
   workingDir buildDir
   
@@ -110,7 +110,7 @@ task defaultDistributionConfig(type: JavaExec, dependsOn: classes) {
 
 task defaultCacheConfig(type: JavaExec, dependsOn: classes) {
   outputs.file file("$buildDir/cache.xml")
-  main 'com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator'
+  main 'org.apache.geode.internal.cache.xmlcache.CacheXmlGenerator'
   classpath project(':geode-core').sourceSets.main.runtimeClasspath
   workingDir buildDir
 
@@ -215,12 +215,12 @@ task docs(type: Javadoc) {
     source parent.subprojects*.javadoc*.source
     classpath = files(parent.subprojects*.javadoc*.classpath)
     title = "${productName} ${project.version}"
-    include 'com/gemstone/gemfire/**/'
-    exclude 'com/gemstone/gemfire/internal/**/'
-    exclude 'com/gemstone/gemfire/**/internal/**/'
-    exclude 'com/gemstone/gemfire/**/xml/**/'
-    exclude 'com/gemstone/gemfire/distributed/**/util/**/'
-    exclude 'com/gemstone/gemfire/test/**/'
+    include 'org/apache/geode/**/'
+    exclude 'org/apache/geode/internal/**/'
+    exclude 'org/apache/geode/**/internal/**/'
+    exclude 'org/apache/geode/**/xml/**/'
+    exclude 'org/apache/geode/distributed/**/util/**/'
+    exclude 'org/apache/geode/test/**/'
     destinationDir = docsDir
 
     doLast {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/main/dist/bin/gfsh
----------------------------------------------------------------------
diff --git a/geode-assembly/src/main/dist/bin/gfsh b/geode-assembly/src/main/dist/bin/gfsh
index 48d3696..7e6531e 100755
--- a/geode-assembly/src/main/dist/bin/gfsh
+++ b/geode-assembly/src/main/dist/bin/gfsh
@@ -58,7 +58,7 @@ fi
 if [ "x$WINDIR" != "x" ]; then
   if [ "${UNAME}" = "cygwin" ]; then
 #	Added for making backspace work under cygwin
-	JLINE_TERMINAL="-Djline.terminal=com.gemstone.gemfire.management.internal.cli.shell.jline.CygwinMinttyTerminal"
+	JLINE_TERMINAL="-Djline.terminal=org.apache.geode.management.internal.cli.shell.jline.CygwinMinttyTerminal"
   else
     echo "ERROR: The variable WINDIR is set indicating this script is running in a Windows OS, please use the .bat file version instead."
     exit 1
@@ -91,7 +91,7 @@ CLASSPATH=$GEMFIRE_JARS
 #  mkdir -p $HOME/.gemfire/gfsh
 #fi
 
-LAUNCHER=com.gemstone.gemfire.management.internal.cli.Launcher
+LAUNCHER=org.apache.geode.management.internal.cli.Launcher
 
 if [ "x$JAVA_ARGS" != "x" ]; then
   JAVA_ARGS="$JAVA_ARGS"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/main/dist/bin/gfsh.bat
----------------------------------------------------------------------
diff --git a/geode-assembly/src/main/dist/bin/gfsh.bat b/geode-assembly/src/main/dist/bin/gfsh.bat
index 706146a..8206b6e 100755
--- a/geode-assembly/src/main/dist/bin/gfsh.bat
+++ b/geode-assembly/src/main/dist/bin/gfsh.bat
@@ -76,7 +76,7 @@ REM  Expect to find the tools.jar from the JDK
     set TOOLS_JAR=
 )
 
-@set LAUNCHER=com.gemstone.gemfire.management.internal.cli.Launcher
+@set LAUNCHER=org.apache.geode.management.internal.cli.Launcher
 @if defined JAVA_ARGS (
     @set JAVA_ARGS="%JAVA_ARGS%"
 )

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/BundledJarsJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/BundledJarsJUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/BundledJarsJUnitTest.java
index 9b59f80..415866b 100644
--- a/geode-assembly/src/test/java/org/apache/geode/BundledJarsJUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/BundledJarsJUnitTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import static org.junit.Assert.*;
 
@@ -35,9 +35,9 @@ import org.junit.Before;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-import com.gemstone.gemfire.internal.FileUtil;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
-import com.gemstone.gemfire.util.test.TestUtil;
+import org.apache.geode.internal.FileUtil;
+import org.apache.geode.test.junit.categories.IntegrationTest;
+import org.apache.geode.util.test.TestUtil;
 
 @Category(IntegrationTest.class)
 public class BundledJarsJUnitTest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/distributed/LocatorLauncherAssemblyIntegrationTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/distributed/LocatorLauncherAssemblyIntegrationTest.java b/geode-assembly/src/test/java/org/apache/geode/distributed/LocatorLauncherAssemblyIntegrationTest.java
index c37c0b5..ee72b30 100644
--- a/geode-assembly/src/test/java/org/apache/geode/distributed/LocatorLauncherAssemblyIntegrationTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/distributed/LocatorLauncherAssemblyIntegrationTest.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.AbstractLauncher.Status;
-import com.gemstone.gemfire.distributed.LocatorLauncher.Builder;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.process.ProcessType;
-import com.gemstone.gemfire.internal.process.ProcessUtils;
-import com.gemstone.gemfire.management.ManagementService;
-import com.gemstone.gemfire.management.ManagerMXBean;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+package org.apache.geode.distributed;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.AbstractLauncher.Status;
+import org.apache.geode.distributed.LocatorLauncher.Builder;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.process.ProcessType;
+import org.apache.geode.internal.process.ProcessUtils;
+import org.apache.geode.management.ManagementService;
+import org.apache.geode.management.ManagerMXBean;
+import org.apache.geode.test.junit.categories.IntegrationTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Test;
@@ -38,7 +38,7 @@ import java.io.File;
 
 import static org.junit.Assert.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * These tests are part of assembly as they require the REST war file to be present.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/management/internal/AgentUtilJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/management/internal/AgentUtilJUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/management/internal/AgentUtilJUnitTest.java
index 59da3cf..78cf167 100644
--- a/geode-assembly/src/test/java/org/apache/geode/management/internal/AgentUtilJUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/management/internal/AgentUtilJUnitTest.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.management.internal;
+package org.apache.geode.management.internal;
 
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsDUnitTest.java
index 1d91834..5905ff3 100644
--- a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsDUnitTest.java
@@ -14,31 +14,31 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.management.internal.cli.commands;
-
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.*;
-import com.gemstone.gemfire.distributed.AbstractLauncher.ServiceState;
-import com.gemstone.gemfire.distributed.AbstractLauncher.Status;
-import com.gemstone.gemfire.distributed.LocatorLauncher;
-import com.gemstone.gemfire.distributed.LocatorLauncher.Builder;
-import com.gemstone.gemfire.distributed.LocatorLauncher.Command;
-import com.gemstone.gemfire.distributed.LocatorLauncher.LocatorState;
-import com.gemstone.gemfire.distributed.ServerLauncher;
-import com.gemstone.gemfire.distributed.ServerLauncher.ServerState;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.process.ProcessType;
-import com.gemstone.gemfire.internal.util.IOUtils;
-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 com.gemstone.gemfire.test.dunit.WaitCriterion;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+package org.apache.geode.management.internal.cli.commands;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.*;
+import org.apache.geode.distributed.AbstractLauncher.ServiceState;
+import org.apache.geode.distributed.AbstractLauncher.Status;
+import org.apache.geode.distributed.LocatorLauncher;
+import org.apache.geode.distributed.LocatorLauncher.Builder;
+import org.apache.geode.distributed.LocatorLauncher.Command;
+import org.apache.geode.distributed.LocatorLauncher.LocatorState;
+import org.apache.geode.distributed.ServerLauncher;
+import org.apache.geode.distributed.ServerLauncher.ServerState;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.process.ProcessType;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.management.cli.Result;
+import org.apache.geode.management.internal.cli.i18n.CliStrings;
+import org.apache.geode.management.internal.cli.result.CommandResult;
+import org.apache.geode.management.internal.cli.util.CommandStringBuilder;
+import org.apache.geode.test.dunit.WaitCriterion;
+import org.apache.geode.test.junit.categories.DistributedTest;
 import org.junit.FixMethodOrder;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
@@ -64,9 +64,9 @@ import java.util.Set;
 import java.util.concurrent.ConcurrentLinkedDeque;
 import java.util.concurrent.TimeUnit;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-import static com.gemstone.gemfire.test.dunit.Assert.*;
-import static com.gemstone.gemfire.test.dunit.Wait.waitForCriterion;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+import static org.apache.geode.test.dunit.Assert.*;
+import static org.apache.geode.test.dunit.Wait.waitForCriterion;
 
 /**
  * The LauncherLifecycleCommandsDUnitTest class is a test suite of integration tests testing the contract and
@@ -74,14 +74,14 @@ import static com.gemstone.gemfire.test.dunit.Wait.waitForCriterion;
  *
  * @see javax.management.MBeanServerConnection
  * @see javax.management.remote.JMXConnector
- * @see com.gemstone.gemfire.distributed.AbstractLauncher
- * @see com.gemstone.gemfire.distributed.LocatorLauncher
- * @see com.gemstone.gemfire.distributed.ServerLauncher
- * @see com.gemstone.gemfire.internal.AvailablePortHelper
- * @see com.gemstone.gemfire.management.internal.cli.shell.Gfsh
- * @see com.gemstone.gemfire.management.internal.cli.commands.CliCommandTestBase
- * @see com.gemstone.gemfire.management.internal.cli.commands.LauncherLifecycleCommands
- * @see com.gemstone.gemfire.management.internal.cli.util.CommandStringBuilder
+ * @see org.apache.geode.distributed.AbstractLauncher
+ * @see org.apache.geode.distributed.LocatorLauncher
+ * @see org.apache.geode.distributed.ServerLauncher
+ * @see org.apache.geode.internal.AvailablePortHelper
+ * @see org.apache.geode.management.internal.cli.shell.Gfsh
+ * @see org.apache.geode.management.internal.cli.commands.CliCommandTestBase
+ * @see org.apache.geode.management.internal.cli.commands.LauncherLifecycleCommands
+ * @see org.apache.geode.management.internal.cli.util.CommandStringBuilder
  * @since GemFire 7.0
  */
 @Category(DistributedTest.class)
@@ -321,7 +321,7 @@ public class LauncherLifecycleCommandsDUnitTest extends CliCommandTestBase {
         "Exception in thread \"main\" java.lang.RuntimeException: A PID file already exists and a Locator may be running in " + IOUtils.tryGetCanonicalFileElseGetAbsoluteFile(
             workingDirectory)));
     assertTrue(resultString, resultString.contains(
-        "Caused by: com.gemstone.gemfire.internal.process.FileAlreadyExistsException: Pid file already exists: " + IOUtils.tryGetCanonicalFileElseGetAbsoluteFile(
+        "Caused by: org.apache.geode.internal.process.FileAlreadyExistsException: Pid file already exists: " + IOUtils.tryGetCanonicalFileElseGetAbsoluteFile(
             pidFile)));
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsIntegrationTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsIntegrationTest.java b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsIntegrationTest.java
index 32d6df2..be77c7e 100644
--- a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsIntegrationTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsIntegrationTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.management.internal.cli.commands;
+package org.apache.geode.management.internal.cli.commands;
 
 import static org.junit.Assert.*;
 
@@ -38,14 +38,14 @@ import org.junit.experimental.categories.Category;
 import org.junit.rules.TemporaryFolder;
 import org.junit.rules.TestName;
 
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 
 /**
  * The LauncherLifecycleCommandsJUnitTest class is a test suite of test cases testing the contract and functionality of
  * the lifecycle launcher GemFire shell (Gfsh) commands.
  *
- * @see com.gemstone.gemfire.management.internal.cli.commands.LauncherLifecycleCommands
+ * @see org.apache.geode.management.internal.cli.commands.LauncherLifecycleCommands
  * @see org.junit.Assert
  * @see org.junit.Test
  * @since GemFire 7.0


[31/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLParser.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLParser.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLParser.java
index bb70b05..a9c05cc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLParser.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLParser.java
@@ -1,8 +1,8 @@
 // $ANTLR 2.7.4: "oql.g" -> "OQLParser.java"$
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 import java.util.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
+import org.apache.geode.cache.query.internal.types.*;
 
 import antlr.TokenBuffer;
 import antlr.TokenStreamException;
@@ -24,7 +24,7 @@ import antlr.ASTPair;
 import antlr.collections.impl.ASTArray;
 
 /***************************** OQL PARSER *************************************/
-public class OQLParser extends com.gemstone.gemfire.cache.query.internal.parse.UtilParser       implements OQLLexerTokenTypes
+public class OQLParser extends org.apache.geode.cache.query.internal.parse.UtilParser       implements OQLLexerTokenTypes
  {
 
 protected OQLParser(TokenBuffer tokenBuf, int k) {
@@ -135,7 +135,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			queryProgram_AST = (AST)currentAST.root;
 			queryProgram_AST =
-			(AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(QUERY_PROGRAM,"queryProgram","com.gemstone.gemfire.cache.query.internal.parse.GemFireAST")).add(queryProgram_AST));
+			(AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(QUERY_PROGRAM,"queryProgram","org.apache.geode.cache.query.internal.parse.GemFireAST")).add(queryProgram_AST));
 			currentAST.root = queryProgram_AST;
 			currentAST.child = queryProgram_AST!=null &&queryProgram_AST.getFirstChild()!=null ?
 				queryProgram_AST.getFirstChild() : queryProgram_AST;
@@ -153,8 +153,8 @@ public OQLParser(ParserSharedInputState state) {
 		
 		{
 		match(TOK_LT);
-		com.gemstone.gemfire.cache.query.internal.parse.ASTTrace tmp7_AST = null;
-		tmp7_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTTrace)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTTrace");
+		org.apache.geode.cache.query.internal.parse.ASTTrace tmp7_AST = null;
+		tmp7_AST = (org.apache.geode.cache.query.internal.parse.ASTTrace)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTTrace");
 		astFactory.makeASTRoot(currentAST, tmp7_AST);
 		match(LITERAL_trace);
 		match(TOK_GT);
@@ -256,7 +256,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			loneFromClause_AST = (AST)currentAST.root;
 			loneFromClause_AST =
-			(AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_from,"from","com.gemstone.gemfire.cache.query.internal.parse.ASTCombination")).add(loneFromClause_AST));
+			(AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_from,"from","org.apache.geode.cache.query.internal.parse.ASTCombination")).add(loneFromClause_AST));
 			currentAST.root = loneFromClause_AST;
 			currentAST.child = loneFromClause_AST!=null &&loneFromClause_AST.getFirstChild()!=null ?
 				loneFromClause_AST.getFirstChild() : loneFromClause_AST;
@@ -316,7 +316,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			if ( inputState.guessing==0 ) {
 				iteratorDef_AST = (AST)currentAST.root;
-				iteratorDef_AST = (AST)astFactory.make( (new ASTArray(4)).add((AST)astFactory.create(ITERATOR_DEF,"iterDef","com.gemstone.gemfire.cache.query.internal.parse.ASTIteratorDef")).add(ex1_AST).add(id1_AST).add(t1_AST));
+				iteratorDef_AST = (AST)astFactory.make( (new ASTArray(4)).add((AST)astFactory.create(ITERATOR_DEF,"iterDef","org.apache.geode.cache.query.internal.parse.ASTIteratorDef")).add(ex1_AST).add(id1_AST).add(t1_AST));
 				currentAST.root = iteratorDef_AST;
 				currentAST.child = iteratorDef_AST!=null &&iteratorDef_AST.getFirstChild()!=null ?
 					iteratorDef_AST.getFirstChild() : iteratorDef_AST;
@@ -364,7 +364,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			if ( inputState.guessing==0 ) {
 				iteratorDef_AST = (AST)currentAST.root;
-				iteratorDef_AST = (AST)astFactory.make( (new ASTArray(4)).add((AST)astFactory.create(ITERATOR_DEF,"iterDef","com.gemstone.gemfire.cache.query.internal.parse.ASTIteratorDef")).add(ex2_AST).add(id2_AST).add(t2_AST));
+				iteratorDef_AST = (AST)astFactory.make( (new ASTArray(4)).add((AST)astFactory.create(ITERATOR_DEF,"iterDef","org.apache.geode.cache.query.internal.parse.ASTIteratorDef")).add(ex2_AST).add(id2_AST).add(t2_AST));
 				currentAST.root = iteratorDef_AST;
 				currentAST.child = iteratorDef_AST!=null &&iteratorDef_AST.getFirstChild()!=null ?
 					iteratorDef_AST.getFirstChild() : iteratorDef_AST;
@@ -417,7 +417,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			if ( inputState.guessing==0 ) {
 				projectionAttributes_AST = (AST)currentAST.root;
-				projectionAttributes_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(PROJECTION_ATTRS,"projectionAttrs","com.gemstone.gemfire.cache.query.internal.parse.ASTCombination")).add(projectionAttributes_AST));
+				projectionAttributes_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(PROJECTION_ATTRS,"projectionAttrs","org.apache.geode.cache.query.internal.parse.ASTCombination")).add(projectionAttributes_AST));
 				currentAST.root = projectionAttributes_AST;
 				currentAST.child = projectionAttributes_AST!=null &&projectionAttributes_AST.getFirstChild()!=null ?
 					projectionAttributes_AST.getFirstChild() : projectionAttributes_AST;
@@ -425,8 +425,8 @@ public OQLParser(ParserSharedInputState state) {
 			}
 		}
 		else if ((LA(1)==TOK_STAR)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTDummy tmp17_AST = null;
-			tmp17_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTDummy");
+			org.apache.geode.cache.query.internal.parse.ASTDummy tmp17_AST = null;
+			tmp17_AST = (org.apache.geode.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTDummy");
 			astFactory.addASTChild(currentAST, tmp17_AST);
 			match(TOK_STAR);
 		}
@@ -507,8 +507,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST importQuery_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTImport tmp24_AST = null;
-		tmp24_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTImport)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTImport");
+		org.apache.geode.cache.query.internal.parse.ASTImport tmp24_AST = null;
+		tmp24_AST = (org.apache.geode.cache.query.internal.parse.ASTImport)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTImport");
 		astFactory.makeASTRoot(currentAST, tmp24_AST);
 		match(LITERAL_import);
 		qualifiedName();
@@ -626,18 +626,18 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST identifier_AST = null;
 		Token  q = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier q_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTIdentifier q_AST = null;
 		
 		if ((LA(1)==Identifier)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier tmp31_AST = null;
-			tmp31_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier");
+			org.apache.geode.cache.query.internal.parse.ASTIdentifier tmp31_AST = null;
+			tmp31_AST = (org.apache.geode.cache.query.internal.parse.ASTIdentifier)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTIdentifier");
 			astFactory.addASTChild(currentAST, tmp31_AST);
 			match(Identifier);
 			identifier_AST = (AST)currentAST.root;
 		}
 		else if ((LA(1)==QuotedIdentifier)) {
 			q = LT(1);
-			q_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier)astFactory.create(q,"com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier");
+			q_AST = (org.apache.geode.cache.query.internal.parse.ASTIdentifier)astFactory.create(q,"org.apache.geode.cache.query.internal.parse.ASTIdentifier");
 			astFactory.addASTChild(currentAST, q_AST);
 			match(QuotedIdentifier);
 			if ( inputState.guessing==0 ) {
@@ -688,7 +688,7 @@ public OQLParser(ParserSharedInputState state) {
 		match(Token.EOF_TYPE);
 		if ( inputState.guessing==0 ) {
 			loneImports_AST = (AST)currentAST.root;
-			loneImports_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(IMPORTS,"imports","com.gemstone.gemfire.cache.query.internal.parse.GemFireAST")).add(loneImports_AST));
+			loneImports_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(IMPORTS,"imports","org.apache.geode.cache.query.internal.parse.GemFireAST")).add(loneImports_AST));
 			currentAST.root = loneImports_AST;
 			currentAST.child = loneImports_AST!=null &&loneImports_AST.getFirstChild()!=null ?
 				loneImports_AST.getFirstChild() : loneImports_AST;
@@ -712,7 +712,7 @@ public OQLParser(ParserSharedInputState state) {
 		match(NUM_INT);
 		if ( inputState.guessing==0 ) {
 			queryParam_AST = (AST)currentAST.root;
-			queryParam_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(QUERY_PARAM,"queryParam","com.gemstone.gemfire.cache.query.internal.parse.ASTParameter")).add(tmp36_AST));
+			queryParam_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(QUERY_PARAM,"queryParam","org.apache.geode.cache.query.internal.parse.ASTParameter")).add(tmp36_AST));
 			currentAST.root = queryParam_AST;
 			currentAST.child = queryParam_AST!=null &&queryParam_AST.getFirstChild()!=null ?
 				queryParam_AST.getFirstChild() : queryParam_AST;
@@ -727,43 +727,43 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST type_AST = null;
 		Token  typ00 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ00_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ00_AST = null;
 		Token  typ01 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ01_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ01_AST = null;
 		Token  typ02 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ02_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ02_AST = null;
 		Token  typ03 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ03_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ03_AST = null;
 		Token  typ04 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ04_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ04_AST = null;
 		Token  typ05 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ05_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ05_AST = null;
 		Token  typ06 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ06_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ06_AST = null;
 		Token  typ07 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ07_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ07_AST = null;
 		Token  typ08 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ08_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ08_AST = null;
 		Token  typ09 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ09_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ09_AST = null;
 		Token  typ10 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ10_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ10_AST = null;
 		Token  typ11 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ11_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ11_AST = null;
 		Token  typ12 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ12_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ12_AST = null;
 		Token  typ13 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ13_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ13_AST = null;
 		Token  typ14 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ14_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ14_AST = null;
 		Token  typ15 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ15_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ15_AST = null;
 		Token  typ16 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ16_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ16_AST = null;
 		Token  typ17 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ17_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ17_AST = null;
 		Token  typ18 = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTType typ18_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTType typ18_AST = null;
 		AST id_AST = null;
 		
 		{
@@ -771,7 +771,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_short:
 		{
 			typ00 = LT(1);
-			typ00_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ00,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ00_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ00,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ00_AST);
 			match(LITERAL_short);
 			if ( inputState.guessing==0 ) {
@@ -782,7 +782,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_long:
 		{
 			typ01 = LT(1);
-			typ01_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ01,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ01_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ01,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ01_AST);
 			match(LITERAL_long);
 			if ( inputState.guessing==0 ) {
@@ -793,7 +793,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_int:
 		{
 			typ02 = LT(1);
-			typ02_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ02,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ02_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ02,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ02_AST);
 			match(LITERAL_int);
 			if ( inputState.guessing==0 ) {
@@ -804,7 +804,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_float:
 		{
 			typ03 = LT(1);
-			typ03_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ03,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ03_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ03,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ03_AST);
 			match(LITERAL_float);
 			if ( inputState.guessing==0 ) {
@@ -815,7 +815,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_double:
 		{
 			typ04 = LT(1);
-			typ04_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ04,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ04_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ04,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ04_AST);
 			match(LITERAL_double);
 			if ( inputState.guessing==0 ) {
@@ -826,7 +826,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_char:
 		{
 			typ05 = LT(1);
-			typ05_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ05,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ05_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ05,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ05_AST);
 			match(LITERAL_char);
 			if ( inputState.guessing==0 ) {
@@ -837,7 +837,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_string:
 		{
 			typ06 = LT(1);
-			typ06_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ06,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ06_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ06,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ06_AST);
 			match(LITERAL_string);
 			if ( inputState.guessing==0 ) {
@@ -848,7 +848,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_boolean:
 		{
 			typ07 = LT(1);
-			typ07_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ07,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ07_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ07,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ07_AST);
 			match(LITERAL_boolean);
 			if ( inputState.guessing==0 ) {
@@ -859,7 +859,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_byte:
 		{
 			typ08 = LT(1);
-			typ08_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ08,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ08_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ08,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ08_AST);
 			match(LITERAL_byte);
 			if ( inputState.guessing==0 ) {
@@ -870,7 +870,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_octet:
 		{
 			typ09 = LT(1);
-			typ09_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ09,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ09_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ09,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ09_AST);
 			match(LITERAL_octet);
 			if ( inputState.guessing==0 ) {
@@ -907,7 +907,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_date:
 		{
 			typ10 = LT(1);
-			typ10_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ10,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ10_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ10,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ10_AST);
 			match(LITERAL_date);
 			if ( inputState.guessing==0 ) {
@@ -918,7 +918,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_time:
 		{
 			typ11 = LT(1);
-			typ11_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ11,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ11_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ11,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ11_AST);
 			match(LITERAL_time);
 			if ( inputState.guessing==0 ) {
@@ -937,7 +937,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_timestamp:
 		{
 			typ12 = LT(1);
-			typ12_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ12,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ12_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ12,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.addASTChild(currentAST, typ12_AST);
 			match(LITERAL_timestamp);
 			if ( inputState.guessing==0 ) {
@@ -948,7 +948,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_set:
 		{
 			typ13 = LT(1);
-			typ13_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ13,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ13_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ13,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.makeASTRoot(currentAST, typ13_AST);
 			match(LITERAL_set);
 			match(TOK_LT);
@@ -963,7 +963,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_collection:
 		{
 			typ14 = LT(1);
-			typ14_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ14,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ14_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ14,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.makeASTRoot(currentAST, typ14_AST);
 			match(LITERAL_collection);
 			match(TOK_LT);
@@ -990,7 +990,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_list:
 		{
 			typ15 = LT(1);
-			typ15_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ15,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ15_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ15,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.makeASTRoot(currentAST, typ15_AST);
 			match(LITERAL_list);
 			match(TOK_LT);
@@ -1005,7 +1005,7 @@ public OQLParser(ParserSharedInputState state) {
 		case LITERAL_array:
 		{
 			typ16 = LT(1);
-			typ16_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ16,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+			typ16_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ16,"org.apache.geode.cache.query.internal.parse.ASTType");
 			astFactory.makeASTRoot(currentAST, typ16_AST);
 			match(LITERAL_array);
 			match(TOK_LT);
@@ -1023,7 +1023,7 @@ public OQLParser(ParserSharedInputState state) {
 			{
 			if ((LA(1)==LITERAL_dictionary)) {
 				typ17 = LT(1);
-				typ17_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ17,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+				typ17_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ17,"org.apache.geode.cache.query.internal.parse.ASTType");
 				astFactory.makeASTRoot(currentAST, typ17_AST);
 				match(LITERAL_dictionary);
 				if ( inputState.guessing==0 ) {
@@ -1032,7 +1032,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			else if ((LA(1)==LITERAL_map)) {
 				typ18 = LT(1);
-				typ18_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTType)astFactory.create(typ18,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+				typ18_AST = (org.apache.geode.cache.query.internal.parse.ASTType)astFactory.create(typ18,"org.apache.geode.cache.query.internal.parse.ASTType");
 				astFactory.makeASTRoot(currentAST, typ18_AST);
 				match(LITERAL_map);
 				if ( inputState.guessing==0 ) {
@@ -1061,7 +1061,7 @@ public OQLParser(ParserSharedInputState state) {
 			if ( inputState.guessing==0 ) {
 				type_AST = (AST)currentAST.root;
 				String txt = id_AST.getText();
-				type_AST = (AST)astFactory.create(Identifier,txt,"com.gemstone.gemfire.cache.query.internal.parse.ASTType");
+				type_AST = (AST)astFactory.create(Identifier,txt,"org.apache.geode.cache.query.internal.parse.ASTType");
 				((ASTType)type_AST).setTypeName(txt);
 				currentAST.root = type_AST;
 				currentAST.child = type_AST!=null &&type_AST.getFirstChild()!=null ?
@@ -1098,20 +1098,20 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		
 		}
-		com.gemstone.gemfire.cache.query.internal.parse.ASTSelect tmp54_AST = null;
-		tmp54_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTSelect)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTSelect");
+		org.apache.geode.cache.query.internal.parse.ASTSelect tmp54_AST = null;
+		tmp54_AST = (org.apache.geode.cache.query.internal.parse.ASTSelect)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTSelect");
 		astFactory.makeASTRoot(currentAST, tmp54_AST);
 		match(LITERAL_select);
 		{
 		if ((LA(1)==LITERAL_distinct) && (_tokenSet_9.member(LA(2)))) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTDummy tmp55_AST = null;
-			tmp55_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTDummy");
+			org.apache.geode.cache.query.internal.parse.ASTDummy tmp55_AST = null;
+			tmp55_AST = (org.apache.geode.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTDummy");
 			astFactory.addASTChild(currentAST, tmp55_AST);
 			match(LITERAL_distinct);
 		}
 		else if ((LA(1)==LITERAL_all)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTDummy tmp56_AST = null;
-			tmp56_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTDummy");
+			org.apache.geode.cache.query.internal.parse.ASTDummy tmp56_AST = null;
+			tmp56_AST = (org.apache.geode.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTDummy");
 			astFactory.addASTChild(currentAST, tmp56_AST);
 			match(LITERAL_all);
 		}
@@ -1199,8 +1199,8 @@ public OQLParser(ParserSharedInputState state) {
 		AST hintCommand_AST = null;
 		
 		match(TOK_LT);
-		com.gemstone.gemfire.cache.query.internal.parse.ASTHint tmp58_AST = null;
-		tmp58_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTHint)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTHint");
+		org.apache.geode.cache.query.internal.parse.ASTHint tmp58_AST = null;
+		tmp58_AST = (org.apache.geode.cache.query.internal.parse.ASTHint)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTHint");
 		astFactory.makeASTRoot(currentAST, tmp58_AST);
 		match(LITERAL_hint);
 		hintIdentifier();
@@ -1230,8 +1230,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST fromClause_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTCombination tmp61_AST = null;
-		tmp61_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCombination)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCombination");
+		org.apache.geode.cache.query.internal.parse.ASTCombination tmp61_AST = null;
+		tmp61_AST = (org.apache.geode.cache.query.internal.parse.ASTCombination)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCombination");
 		astFactory.makeASTRoot(currentAST, tmp61_AST);
 		match(LITERAL_from);
 		iteratorDef();
@@ -1273,8 +1273,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST groupClause_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTGroupBy tmp64_AST = null;
-		tmp64_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTGroupBy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTGroupBy");
+		org.apache.geode.cache.query.internal.parse.ASTGroupBy tmp64_AST = null;
+		tmp64_AST = (org.apache.geode.cache.query.internal.parse.ASTGroupBy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTGroupBy");
 		astFactory.makeASTRoot(currentAST, tmp64_AST);
 		match(LITERAL_group);
 		match(LITERAL_by);
@@ -1303,8 +1303,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST orderClause_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTOrderBy tmp67_AST = null;
-		tmp67_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTOrderBy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTOrderBy");
+		org.apache.geode.cache.query.internal.parse.ASTOrderBy tmp67_AST = null;
+		tmp67_AST = (org.apache.geode.cache.query.internal.parse.ASTOrderBy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTOrderBy");
 		astFactory.makeASTRoot(currentAST, tmp67_AST);
 		match(LITERAL_order);
 		match(LITERAL_by);
@@ -1347,7 +1347,7 @@ public OQLParser(ParserSharedInputState state) {
 			match(NUM_INT);
 			if ( inputState.guessing==0 ) {
 				limitClause_AST = (AST)currentAST.root;
-				limitClause_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LIMIT,"limitParam","com.gemstone.gemfire.cache.query.internal.parse.ASTParameter")).add(tmp72_AST));
+				limitClause_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LIMIT,"limitParam","org.apache.geode.cache.query.internal.parse.ASTParameter")).add(tmp72_AST));
 				currentAST.root = limitClause_AST;
 				currentAST.child = limitClause_AST!=null &&limitClause_AST.getFirstChild()!=null ?
 					limitClause_AST.getFirstChild() : limitClause_AST;
@@ -1360,7 +1360,7 @@ public OQLParser(ParserSharedInputState state) {
 			match(NUM_INT);
 			if ( inputState.guessing==0 ) {
 				limitClause_AST = (AST)currentAST.root;
-				limitClause_AST =(AST)astFactory.create(LIMIT,n.getText(),"com.gemstone.gemfire.cache.query.internal.parse.ASTLimit") ;
+				limitClause_AST =(AST)astFactory.create(LIMIT,n.getText(),"org.apache.geode.cache.query.internal.parse.ASTLimit") ;
 				currentAST.root = limitClause_AST;
 				currentAST.child = limitClause_AST!=null &&limitClause_AST.getFirstChild()!=null ?
 					limitClause_AST.getFirstChild() : limitClause_AST;
@@ -1414,7 +1414,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			if ( inputState.guessing==0 ) {
 				projection_AST = (AST)currentAST.root;
-				projection_AST = (AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(PROJECTION,"projection","com.gemstone.gemfire.cache.query.internal.parse.ASTProjection")).add(node).add(lb1_AST));
+				projection_AST = (AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(PROJECTION,"projection","org.apache.geode.cache.query.internal.parse.ASTProjection")).add(node).add(lb1_AST));
 				currentAST.root = projection_AST;
 				currentAST.child = projection_AST!=null &&projection_AST.getFirstChild()!=null ?
 					projection_AST.getFirstChild() : projection_AST;
@@ -1457,7 +1457,7 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			if ( inputState.guessing==0 ) {
 				projection_AST = (AST)currentAST.root;
-				projection_AST = (AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(PROJECTION,"projection","com.gemstone.gemfire.cache.query.internal.parse.ASTProjection")).add(node).add(lb2_AST));
+				projection_AST = (AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(PROJECTION,"projection","org.apache.geode.cache.query.internal.parse.ASTProjection")).add(node).add(lb2_AST));
 				currentAST.root = projection_AST;
 				currentAST.child = projection_AST!=null &&projection_AST.getFirstChild()!=null ?
 					projection_AST.getFirstChild() : projection_AST;
@@ -1526,7 +1526,7 @@ public OQLParser(ParserSharedInputState state) {
 			match(TOK_RPAREN);
 			if ( inputState.guessing==0 ) {
 				aggregateExpr_AST = (AST)currentAST.root;
-				aggregateExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(AGG_FUNC,"aggregate","com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc")).add(tokExpr1_AST)); 
+				aggregateExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(AGG_FUNC,"aggregate","org.apache.geode.cache.query.internal.parse.ASTAggregateFunc")).add(tokExpr1_AST)); 
 				((ASTAggregateFunc)aggregateExpr_AST).setAggregateFunctionType(aggFunc);
 				((ASTAggregateFunc)aggregateExpr_AST).setDistinctOnly(distinctOnly);
 				
@@ -1568,7 +1568,7 @@ public OQLParser(ParserSharedInputState state) {
 			match(TOK_RPAREN);
 			if ( inputState.guessing==0 ) {
 				aggregateExpr_AST = (AST)currentAST.root;
-				aggregateExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(AGG_FUNC,"aggregate","com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc")).add(tokExpr2_AST)); 
+				aggregateExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(AGG_FUNC,"aggregate","org.apache.geode.cache.query.internal.parse.ASTAggregateFunc")).add(tokExpr2_AST)); 
 				((ASTAggregateFunc)aggregateExpr_AST).setAggregateFunctionType(aggFunc);               
 				
 				currentAST.root = aggregateExpr_AST;
@@ -1580,15 +1580,15 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		case LITERAL_count:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc tmp84_AST = null;
-			tmp84_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc");
+			org.apache.geode.cache.query.internal.parse.ASTAggregateFunc tmp84_AST = null;
+			tmp84_AST = (org.apache.geode.cache.query.internal.parse.ASTAggregateFunc)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTAggregateFunc");
 			astFactory.makeASTRoot(currentAST, tmp84_AST);
 			match(LITERAL_count);
 			match(TOK_LPAREN);
 			{
 			if ((LA(1)==TOK_STAR)) {
-				com.gemstone.gemfire.cache.query.internal.parse.ASTDummy tmp86_AST = null;
-				tmp86_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTDummy");
+				org.apache.geode.cache.query.internal.parse.ASTDummy tmp86_AST = null;
+				tmp86_AST = (org.apache.geode.cache.query.internal.parse.ASTDummy)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTDummy");
 				astFactory.addASTChild(currentAST, tmp86_AST);
 				match(TOK_STAR);
 			}
@@ -1675,7 +1675,7 @@ public OQLParser(ParserSharedInputState state) {
 		match(StringLiteral);
 		if ( inputState.guessing==0 ) {
 			hintIdentifier_AST = (AST)currentAST.root;
-			hintIdentifier_AST =(AST)astFactory.create(HINT,n.getText(),"com.gemstone.gemfire.cache.query.internal.parse.ASTHintIdentifier") ;
+			hintIdentifier_AST =(AST)astFactory.create(HINT,n.getText(),"org.apache.geode.cache.query.internal.parse.ASTHintIdentifier") ;
 			currentAST.root = hintIdentifier_AST;
 			currentAST.child = hintIdentifier_AST!=null &&hintIdentifier_AST.getFirstChild()!=null ?
 				hintIdentifier_AST.getFirstChild() : hintIdentifier_AST;
@@ -1697,7 +1697,7 @@ public OQLParser(ParserSharedInputState state) {
 		astFactory.addASTChild(currentAST, returnAST);
 		if ( inputState.guessing==0 ) {
 			sortCriterion_AST = (AST)currentAST.root;
-			sortCriterion_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(SORT_CRITERION,"asc","com.gemstone.gemfire.cache.query.internal.parse.ASTSortCriterion")).add(tok_AST));
+			sortCriterion_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(SORT_CRITERION,"asc","org.apache.geode.cache.query.internal.parse.ASTSortCriterion")).add(tok_AST));
 			currentAST.root = sortCriterion_AST;
 			currentAST.child = sortCriterion_AST!=null &&sortCriterion_AST.getFirstChild()!=null ?
 				sortCriterion_AST.getFirstChild() : sortCriterion_AST;
@@ -1747,7 +1747,7 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST castExpr_AST = null;
 		Token  lp = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTTypeCast lp_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTTypeCast lp_AST = null;
 		
 		boolean synPredMatched183 = false;
 		if (((LA(1)==TOK_LPAREN) && (_tokenSet_17.member(LA(2))))) {
@@ -1770,7 +1770,7 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		if ( synPredMatched183 ) {
 			lp = LT(1);
-			lp_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTTypeCast)astFactory.create(lp,"com.gemstone.gemfire.cache.query.internal.parse.ASTTypeCast");
+			lp_AST = (org.apache.geode.cache.query.internal.parse.ASTTypeCast)astFactory.create(lp,"org.apache.geode.cache.query.internal.parse.ASTTypeCast");
 			astFactory.makeASTRoot(currentAST, lp_AST);
 			match(TOK_LPAREN);
 			if ( inputState.guessing==0 ) {
@@ -1824,7 +1824,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			orExpr_AST = (AST)currentAST.root;
 			if (cmplx) {
-			orExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_or,"or","com.gemstone.gemfire.cache.query.internal.parse.ASTOr")).add(orExpr_AST)); }
+			orExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_or,"or","org.apache.geode.cache.query.internal.parse.ASTOr")).add(orExpr_AST)); }
 			currentAST.root = orExpr_AST;
 			currentAST.child = orExpr_AST!=null &&orExpr_AST.getFirstChild()!=null ?
 				orExpr_AST.getFirstChild() : orExpr_AST;
@@ -1901,7 +1901,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			andExpr_AST = (AST)currentAST.root;
 			if (cmplx) {
-			andExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_and,"and","com.gemstone.gemfire.cache.query.internal.parse.ASTAnd")).add(andExpr_AST)); }
+			andExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(LITERAL_and,"and","org.apache.geode.cache.query.internal.parse.ASTAnd")).add(andExpr_AST)); }
 			currentAST.root = andExpr_AST;
 			currentAST.child = andExpr_AST!=null &&andExpr_AST.getFirstChild()!=null ?
 				andExpr_AST.getFirstChild() : andExpr_AST;
@@ -2043,14 +2043,14 @@ public OQLParser(ParserSharedInputState state) {
 				if ((LA(1)==TOK_EQ||LA(1)==TOK_NE)) {
 					{
 					if ((LA(1)==TOK_EQ)) {
-						com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp103_AST = null;
-						tmp103_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+						org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp103_AST = null;
+						tmp103_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 						astFactory.makeASTRoot(currentAST, tmp103_AST);
 						match(TOK_EQ);
 					}
 					else if ((LA(1)==TOK_NE)) {
-						com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp104_AST = null;
-						tmp104_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+						org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp104_AST = null;
+						tmp104_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 						astFactory.makeASTRoot(currentAST, tmp104_AST);
 						match(TOK_NE);
 					}
@@ -2155,8 +2155,8 @@ public OQLParser(ParserSharedInputState state) {
 			_loop207:
 			do {
 				if ((LA(1)==LITERAL_like)) {
-					com.gemstone.gemfire.cache.query.internal.parse.ASTLike tmp108_AST = null;
-					tmp108_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLike)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLike");
+					org.apache.geode.cache.query.internal.parse.ASTLike tmp108_AST = null;
+					tmp108_AST = (org.apache.geode.cache.query.internal.parse.ASTLike)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLike");
 					astFactory.makeASTRoot(currentAST, tmp108_AST);
 					match(LITERAL_like);
 					relationalExpr();
@@ -2194,32 +2194,32 @@ public OQLParser(ParserSharedInputState state) {
 				switch ( LA(1)) {
 				case TOK_LT:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp109_AST = null;
-					tmp109_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+					org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp109_AST = null;
+					tmp109_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 					astFactory.makeASTRoot(currentAST, tmp109_AST);
 					match(TOK_LT);
 					break;
 				}
 				case TOK_GT:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp110_AST = null;
-					tmp110_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+					org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp110_AST = null;
+					tmp110_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 					astFactory.makeASTRoot(currentAST, tmp110_AST);
 					match(TOK_GT);
 					break;
 				}
 				case TOK_LE:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp111_AST = null;
-					tmp111_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+					org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp111_AST = null;
+					tmp111_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 					astFactory.makeASTRoot(currentAST, tmp111_AST);
 					match(TOK_LE);
 					break;
 				}
 				case TOK_GE:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp tmp112_AST = null;
-					tmp112_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp");
+					org.apache.geode.cache.query.internal.parse.ASTCompareOp tmp112_AST = null;
+					tmp112_AST = (org.apache.geode.cache.query.internal.parse.ASTCompareOp)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTCompareOp");
 					astFactory.makeASTRoot(currentAST, tmp112_AST);
 					match(TOK_GE);
 					break;
@@ -2435,8 +2435,8 @@ public OQLParser(ParserSharedInputState state) {
 		astFactory.addASTChild(currentAST, returnAST);
 		{
 		if ((LA(1)==LITERAL_in)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTIn tmp125_AST = null;
-			tmp125_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTIn)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTIn");
+			org.apache.geode.cache.query.internal.parse.ASTIn tmp125_AST = null;
+			tmp125_AST = (org.apache.geode.cache.query.internal.parse.ASTIn)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTIn");
 			astFactory.makeASTRoot(currentAST, tmp125_AST);
 			match(LITERAL_in);
 			unaryExpr();
@@ -2472,8 +2472,8 @@ public OQLParser(ParserSharedInputState state) {
 				}
 				case TOK_MINUS:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTUnary tmp127_AST = null;
-					tmp127_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTUnary)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTUnary");
+					org.apache.geode.cache.query.internal.parse.ASTUnary tmp127_AST = null;
+					tmp127_AST = (org.apache.geode.cache.query.internal.parse.ASTUnary)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTUnary");
 					astFactory.makeASTRoot(currentAST, tmp127_AST);
 					match(TOK_MINUS);
 					break;
@@ -2488,8 +2488,8 @@ public OQLParser(ParserSharedInputState state) {
 				}
 				case LITERAL_not:
 				{
-					com.gemstone.gemfire.cache.query.internal.parse.ASTUnary tmp129_AST = null;
-					tmp129_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTUnary)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTUnary");
+					org.apache.geode.cache.query.internal.parse.ASTUnary tmp129_AST = null;
+					tmp129_AST = (org.apache.geode.cache.query.internal.parse.ASTUnary)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTUnary");
 					astFactory.makeASTRoot(currentAST, tmp129_AST);
 					match(LITERAL_not);
 					break;
@@ -2574,7 +2574,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			postfixExpr_AST = (AST)currentAST.root;
 			if (cmplx) {
-			postfixExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(POSTFIX,"postfix","com.gemstone.gemfire.cache.query.internal.parse.ASTPostfix")).add(postfixExpr_AST));
+			postfixExpr_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(POSTFIX,"postfix","org.apache.geode.cache.query.internal.parse.ASTPostfix")).add(postfixExpr_AST));
 			}
 			
 			currentAST.root = postfixExpr_AST;
@@ -2681,8 +2681,8 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		case RegionPath:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTRegionPath tmp136_AST = null;
-			tmp136_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTRegionPath)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTRegionPath");
+			org.apache.geode.cache.query.internal.parse.ASTRegionPath tmp136_AST = null;
+			tmp136_AST = (org.apache.geode.cache.query.internal.parse.ASTRegionPath)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTRegionPath");
 			astFactory.addASTChild(currentAST, tmp136_AST);
 			match(RegionPath);
 			break;
@@ -2782,7 +2782,7 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		if ( inputState.guessing==0 ) {
 			index_AST = (AST)currentAST.root;
-			index_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(TOK_LBRACK,"index","com.gemstone.gemfire.cache.query.internal.parse.ASTCombination")).add(index_AST));
+			index_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(TOK_LBRACK,"index","org.apache.geode.cache.query.internal.parse.ASTCombination")).add(index_AST));
 			
 			currentAST.root = index_AST;
 			currentAST.child = index_AST!=null &&index_AST.getFirstChild()!=null ?
@@ -2810,7 +2810,7 @@ public OQLParser(ParserSharedInputState state) {
 		if ( inputState.guessing==0 ) {
 			methodInvocation_AST = (AST)currentAST.root;
 			methodInvocation_AST =
-			(AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(METHOD_INV,"methodInv","com.gemstone.gemfire.cache.query.internal.parse.ASTMethodInvocation")).add(methodName_AST).add(args_AST)); 
+			(AST)astFactory.make( (new ASTArray(3)).add((AST)astFactory.create(METHOD_INV,"methodInv","org.apache.geode.cache.query.internal.parse.ASTMethodInvocation")).add(methodName_AST).add(args_AST)); 
 			((ASTMethodInvocation)methodInvocation_AST).setImplicitReceiver(implicitReceiver);
 			currentAST.root = methodInvocation_AST;
 			currentAST.child = methodInvocation_AST!=null &&methodInvocation_AST.getFirstChild()!=null ?
@@ -2826,10 +2826,10 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST argList_AST = null;
 		Token  t = null;
-		com.gemstone.gemfire.cache.query.internal.parse.ASTCombination t_AST = null;
+		org.apache.geode.cache.query.internal.parse.ASTCombination t_AST = null;
 		
 		t = LT(1);
-		t_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTCombination)astFactory.create(t,"com.gemstone.gemfire.cache.query.internal.parse.ASTCombination");
+		t_AST = (org.apache.geode.cache.query.internal.parse.ASTCombination)astFactory.create(t,"org.apache.geode.cache.query.internal.parse.ASTCombination");
 		astFactory.makeASTRoot(currentAST, t_AST);
 		match(TOK_LPAREN);
 		{
@@ -2888,8 +2888,8 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			case LITERAL_element:
 			{
-				com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr tmp143_AST = null;
-				tmp143_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr");
+				org.apache.geode.cache.query.internal.parse.ASTConversionExpr tmp143_AST = null;
+				tmp143_AST = (org.apache.geode.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTConversionExpr");
 				astFactory.makeASTRoot(currentAST, tmp143_AST);
 				match(LITERAL_element);
 				break;
@@ -2926,8 +2926,8 @@ public OQLParser(ParserSharedInputState state) {
 		{
 			{
 			{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr tmp148_AST = null;
-			tmp148_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr");
+			org.apache.geode.cache.query.internal.parse.ASTConversionExpr tmp148_AST = null;
+			tmp148_AST = (org.apache.geode.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTConversionExpr");
 			astFactory.makeASTRoot(currentAST, tmp148_AST);
 			match(LITERAL_nvl);
 			}
@@ -2945,8 +2945,8 @@ public OQLParser(ParserSharedInputState state) {
 		{
 			{
 			{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr tmp152_AST = null;
-			tmp152_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr");
+			org.apache.geode.cache.query.internal.parse.ASTConversionExpr tmp152_AST = null;
+			tmp152_AST = (org.apache.geode.cache.query.internal.parse.ASTConversionExpr)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTConversionExpr");
 			astFactory.makeASTRoot(currentAST, tmp152_AST);
 			match(LITERAL_to_date);
 			}
@@ -3032,14 +3032,14 @@ public OQLParser(ParserSharedInputState state) {
 		
 		{
 		if ((LA(1)==LITERAL_is_undefined)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr tmp162_AST = null;
-			tmp162_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr");
+			org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr tmp162_AST = null;
+			tmp162_AST = (org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr");
 			astFactory.makeASTRoot(currentAST, tmp162_AST);
 			match(LITERAL_is_undefined);
 		}
 		else if ((LA(1)==LITERAL_is_defined)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr tmp163_AST = null;
-			tmp163_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr");
+			org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr tmp163_AST = null;
+			tmp163_AST = (org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr");
 			astFactory.makeASTRoot(currentAST, tmp163_AST);
 			match(LITERAL_is_defined);
 		}
@@ -3118,8 +3118,8 @@ public OQLParser(ParserSharedInputState state) {
 			}
 			case LITERAL_set:
 			{
-				com.gemstone.gemfire.cache.query.internal.parse.ASTConstruction tmp171_AST = null;
-				tmp171_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTConstruction)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTConstruction");
+				org.apache.geode.cache.query.internal.parse.ASTConstruction tmp171_AST = null;
+				tmp171_AST = (org.apache.geode.cache.query.internal.parse.ASTConstruction)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTConstruction");
 				astFactory.makeASTRoot(currentAST, tmp171_AST);
 				match(LITERAL_set);
 				break;
@@ -3292,8 +3292,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST stringLiteral_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp178_AST = null;
-		tmp178_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+		org.apache.geode.cache.query.internal.parse.ASTLiteral tmp178_AST = null;
+		tmp178_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 		astFactory.addASTChild(currentAST, tmp178_AST);
 		match(StringLiteral);
 		stringLiteral_AST = (AST)currentAST.root;
@@ -3330,7 +3330,7 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		if ( inputState.guessing==0 ) {
 			fieldList_AST = (AST)currentAST.root;
-			fieldList_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(COMBO,"fieldList","com.gemstone.gemfire.cache.query.internal.parse.ASTCombination")).add(fieldList_AST));
+			fieldList_AST = (AST)astFactory.make( (new ASTArray(2)).add((AST)astFactory.create(COMBO,"fieldList","org.apache.geode.cache.query.internal.parse.ASTCombination")).add(fieldList_AST));
 			currentAST.root = fieldList_AST;
 			currentAST.child = fieldList_AST!=null &&fieldList_AST.getFirstChild()!=null ?
 				fieldList_AST.getFirstChild() : fieldList_AST;
@@ -3349,8 +3349,8 @@ public OQLParser(ParserSharedInputState state) {
 		switch ( LA(1)) {
 		case LITERAL_nil:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp182_AST = null;
-			tmp182_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp182_AST = null;
+			tmp182_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp182_AST);
 			match(LITERAL_nil);
 			objectLiteral_AST = (AST)currentAST.root;
@@ -3358,8 +3358,8 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		case LITERAL_null:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp183_AST = null;
-			tmp183_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp183_AST = null;
+			tmp183_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp183_AST);
 			match(LITERAL_null);
 			objectLiteral_AST = (AST)currentAST.root;
@@ -3367,8 +3367,8 @@ public OQLParser(ParserSharedInputState state) {
 		}
 		case LITERAL_undefined:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp184_AST = null;
-			tmp184_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp184_AST = null;
+			tmp184_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp184_AST);
 			match(LITERAL_undefined);
 			objectLiteral_AST = (AST)currentAST.root;
@@ -3390,14 +3390,14 @@ public OQLParser(ParserSharedInputState state) {
 		
 		{
 		if ((LA(1)==LITERAL_true)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp185_AST = null;
-			tmp185_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp185_AST = null;
+			tmp185_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp185_AST);
 			match(LITERAL_true);
 		}
 		else if ((LA(1)==LITERAL_false)) {
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp186_AST = null;
-			tmp186_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp186_AST = null;
+			tmp186_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp186_AST);
 			match(LITERAL_false);
 		}
@@ -3420,32 +3420,32 @@ public OQLParser(ParserSharedInputState state) {
 		switch ( LA(1)) {
 		case NUM_INT:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp187_AST = null;
-			tmp187_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp187_AST = null;
+			tmp187_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp187_AST);
 			match(NUM_INT);
 			break;
 		}
 		case NUM_LONG:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp188_AST = null;
-			tmp188_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp188_AST = null;
+			tmp188_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp188_AST);
 			match(NUM_LONG);
 			break;
 		}
 		case NUM_FLOAT:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp189_AST = null;
-			tmp189_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp189_AST = null;
+			tmp189_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp189_AST);
 			match(NUM_FLOAT);
 			break;
 		}
 		case NUM_DOUBLE:
 		{
-			com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp190_AST = null;
-			tmp190_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+			org.apache.geode.cache.query.internal.parse.ASTLiteral tmp190_AST = null;
+			tmp190_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 			astFactory.addASTChild(currentAST, tmp190_AST);
 			match(NUM_DOUBLE);
 			break;
@@ -3466,8 +3466,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST charLiteral_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp191_AST = null;
-		tmp191_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+		org.apache.geode.cache.query.internal.parse.ASTLiteral tmp191_AST = null;
+		tmp191_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 		astFactory.makeASTRoot(currentAST, tmp191_AST);
 		match(LITERAL_char);
 		AST tmp192_AST = null;
@@ -3484,8 +3484,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST dateLiteral_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp193_AST = null;
-		tmp193_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+		org.apache.geode.cache.query.internal.parse.ASTLiteral tmp193_AST = null;
+		tmp193_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 		astFactory.makeASTRoot(currentAST, tmp193_AST);
 		match(LITERAL_date);
 		AST tmp194_AST = null;
@@ -3502,8 +3502,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST timeLiteral_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp195_AST = null;
-		tmp195_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+		org.apache.geode.cache.query.internal.parse.ASTLiteral tmp195_AST = null;
+		tmp195_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 		astFactory.makeASTRoot(currentAST, tmp195_AST);
 		match(LITERAL_time);
 		AST tmp196_AST = null;
@@ -3520,8 +3520,8 @@ public OQLParser(ParserSharedInputState state) {
 		ASTPair currentAST = new ASTPair();
 		AST timestampLiteral_AST = null;
 		
-		com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral tmp197_AST = null;
-		tmp197_AST = (com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral");
+		org.apache.geode.cache.query.internal.parse.ASTLiteral tmp197_AST = null;
+		tmp197_AST = (org.apache.geode.cache.query.internal.parse.ASTLiteral)astFactory.create(LT(1),"org.apache.geode.cache.query.internal.parse.ASTLiteral");
 		astFactory.makeASTRoot(currentAST, tmp197_AST);
 		match(LITERAL_timestamp);
 		AST tmp198_AST = null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
index 2b63f02..2b2a417 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
@@ -20,7 +20,7 @@
  * Created on January 19, 2005, 2:18 PM
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 import antlr.collections.*;
@@ -71,7 +71,7 @@ public class UtilParser extends LLkParser {
         OQLParser parser = new OQLParser(lexer);
         // by default use Unsupported AST class, overridden for supported
         // operators in the grammer proper
-        parser.setASTNodeClass("com.gemstone.gemfire.cache.query.internal.parse.ASTUnsupported");
+        parser.setASTNodeClass("org.apache.geode.cache.query.internal.parse.ASTUnsupported");
         parser.queryProgram();
         AST t = parser.getAST();
         if (useFrame) {


[71/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/PulseController.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/PulseController.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/PulseController.java
new file mode 100644
index 0000000..4eb069e
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/PulseController.java
@@ -0,0 +1,524 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.controllers;
+
+import java.io.IOException;
+import java.util.Collection;
+import java.util.Iterator;
+import java.util.List;
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.PulseVersion;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.service.PulseService;
+import org.apache.geode.tools.pulse.internal.service.PulseServiceFactory;
+import org.apache.geode.tools.pulse.internal.service.SystemAlertsService;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+
+import org.apache.commons.lang.StringEscapeUtils;
+import org.springframework.beans.factory.annotation.Autowired;
+import org.springframework.stereotype.Controller;
+import org.springframework.web.bind.annotation.RequestMapping;
+import org.springframework.web.bind.annotation.RequestMethod;
+
+/**
+ * Class PulseController
+ * 
+ * This class contains the implementations for all http Ajax requests needs to
+ * be served in Pulse.
+ * 
+ * @since GemFire version 7.5
+ */
+@Controller
+public class PulseController {
+
+  private static final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+
+  // CONSTANTS
+  private final String DEFAULT_EXPORT_FILENAME = "DataBrowserQueryResult.json";
+  private final String QUERYSTRING_PARAM_ACTION = "action";
+  private final String QUERYSTRING_PARAM_QUERYID = "queryId";
+  private final String ACTION_VIEW = "view";
+  private final String ACTION_DELETE = "delete";
+
+  private String STATUS_REPSONSE_SUCCESS = "success";
+  private String STATUS_REPSONSE_FAIL = "fail";
+
+  private String ERROR_REPSONSE_QUERYNOTFOUND = "No queries found";
+  private String ERROR_REPSONSE_QUERYIDMISSING = "Query id is missing";
+
+  private static final String EMPTY_JSON = "{}";
+
+  // Shared object to hold pulse version details
+  public static PulseVersion pulseVersion = new PulseVersion();
+
+  //default is gemfire
+  private static String pulseProductSupport = PulseConstants.PRODUCT_NAME_GEMFIRE;
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  @Autowired
+  PulseServiceFactory pulseServiceFactory;
+
+  @RequestMapping(value = "/pulseUpdate", method = RequestMethod.POST)
+  public void getPulseUpdate(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    String pulseData = request.getParameter("pulseData");
+
+    ObjectNode responseMap = mapper.createObjectNode();
+
+    JsonNode requestMap = null;
+
+    try {
+      requestMap = mapper.readTree(pulseData);
+      Iterator<?> keys = requestMap.fieldNames();
+
+      // Execute Services
+      while (keys.hasNext()) {
+        String serviceName = keys.next().toString();
+        try {
+          PulseService pulseService = pulseServiceFactory
+              .getPulseServiceInstance(serviceName);
+          responseMap.put(serviceName, pulseService.execute(request));
+        } catch (Exception serviceException) {
+          LOGGER.warning("serviceException [for service "+serviceName+"] = " + serviceException.getMessage());
+          responseMap.put(serviceName, EMPTY_JSON);
+        }
+      }
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occurred : " + e.getMessage());
+      }
+    }
+
+    // Create Response
+    response.getOutputStream().write(responseMap.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/authenticateUser", method = RequestMethod.GET)
+  public void authenticateUser(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    try {
+      responseJSON.put("isUserLoggedIn", this.isUserLoggedIn(request));
+      // Send json response
+      response.getOutputStream().write(responseJSON.toString().getBytes());
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occurred : " + e.getMessage());
+      }
+    }
+  }
+
+  /**
+   * Method isUserLoggedIn Check whether user is logged in or not.
+   * 
+   * @param request
+   * @return boolean
+   */
+  protected boolean isUserLoggedIn(HttpServletRequest request) {
+    return null != request.getUserPrincipal();
+  }
+
+  @RequestMapping(value = "/pulseVersion", method = RequestMethod.GET)
+  public void pulseVersion(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    try {
+      // Reference to repository
+      Repository repository = Repository.get();
+      // set pulse web app url
+      String pulseWebAppUrl = request.getScheme() + "://"
+          + request.getServerName() + ":" + request.getServerPort()
+          + request.getContextPath();
+
+      repository.setPulseWebAppUrl(pulseWebAppUrl);
+
+      // Response
+      responseJSON.put("pulseVersion", PulseController.pulseVersion.getPulseVersion());
+      responseJSON.put("buildId", PulseController.pulseVersion.getPulseBuildId());
+      responseJSON.put("buildDate", PulseController.pulseVersion.getPulseBuildDate());
+      responseJSON.put("sourceDate", PulseController.pulseVersion.getPulseSourceDate());
+      responseJSON.put("sourceRevision", PulseController.pulseVersion.getPulseSourceRevision());
+      responseJSON.put("sourceRepository", PulseController.pulseVersion.getPulseSourceRepository());
+
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+
+    // Send json response
+    response.getOutputStream().write(responseJSON.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/clearAlerts", method = RequestMethod.GET)
+  public void clearAlerts(HttpServletRequest request, HttpServletResponse response) throws IOException {
+    int alertType;
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    try {
+      alertType = Integer.valueOf(request.getParameter("alertType"));
+    } catch (NumberFormatException e) {
+      // Empty json response
+      response.getOutputStream().write(responseJSON.toString().getBytes());
+      if (LOGGER.finerEnabled()) {
+        LOGGER.finer(e.getMessage());
+      }
+      return;
+    }
+
+    try {
+      boolean isClearAll = Boolean.valueOf(request.getParameter("clearAll"));
+      // get cluster object
+      Cluster cluster = Repository.get().getCluster();
+      cluster.clearAlerts(alertType, isClearAll);
+      responseJSON.put("status", "deleted");
+      responseJSON.put(
+          "systemAlerts", SystemAlertsService.getAlertsJson(cluster,
+              cluster.getNotificationPageNumber()));
+      responseJSON.put("pageNumber", cluster.getNotificationPageNumber());
+
+      boolean isGFConnected = cluster.isConnectedFlag();
+      if(isGFConnected){
+        responseJSON.put("connectedFlag", isGFConnected);
+      }else{
+        responseJSON.put("connectedFlag", isGFConnected);
+        responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
+      }
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occurred : " + e.getMessage());
+      }
+    }
+
+    // Send json response
+    response.getOutputStream().write(responseJSON.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/acknowledgeAlert", method = RequestMethod.GET)
+  public void acknowledgeAlert(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    int alertId;
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    try {
+      alertId = Integer.valueOf(request.getParameter("alertId"));
+    } catch (NumberFormatException e) {
+      // Empty json response
+      response.getOutputStream().write(responseJSON.toString().getBytes());
+      if (LOGGER.finerEnabled()) {
+        LOGGER.finer(e.getMessage());
+      }
+      return;
+    }
+
+    try {
+      // get cluster object
+      Cluster cluster = Repository.get().getCluster();
+
+      // set alert is acknowledged
+      cluster.acknowledgeAlert(alertId);
+      responseJSON.put("status", "deleted");
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+
+    // Send json response
+    response.getOutputStream().write(responseJSON.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/dataBrowserRegions", method = RequestMethod.GET)
+  public void dataBrowserRegions(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+    ArrayNode regionsData = mapper.createArrayNode();
+
+    try {
+      // getting cluster's Regions
+      responseJSON.put("clusterName", cluster.getServerName());
+      regionsData = getRegionsJson(cluster);
+      responseJSON.put("clusterRegions", regionsData);
+      responseJSON.put("connectedFlag", cluster.isConnectedFlag());
+      responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+
+    // Send json response
+    response.getOutputStream().write(responseJSON.toString().getBytes());
+  }
+
+  /**
+   * This method creates json for list of cluster regions
+   * 
+   * @param cluster
+   * @return ArrayNode JSON array
+   */
+  private ArrayNode getRegionsJson(Cluster cluster) {
+
+    Collection<Cluster.Region> clusterRegions = cluster.getClusterRegions().values();
+    ArrayNode regionsListJson = mapper.createArrayNode();
+
+    if (!clusterRegions.isEmpty()) {
+      for (Cluster.Region region : clusterRegions) {
+        ObjectNode regionJSON = mapper.createObjectNode();
+        regionJSON.put("name", region.getName());
+        regionJSON.put("fullPath", region.getFullPath());
+        regionJSON.put("regionType", region.getRegionType());
+
+        if (region.getRegionType().contains("PARTITION")) {
+          regionJSON.put("isPartition", true);
+        } else {
+          regionJSON.put("isPartition", false);
+        }
+
+        regionJSON.put("memberCount", region.getMemberCount());
+        List<String> regionsMembers = region.getMemberName();
+        ArrayNode jsonRegionMembers = mapper.createArrayNode();
+
+        for (int i = 0; i < regionsMembers.size(); i++) {
+          Cluster.Member member = cluster.getMembersHMap().get(
+              regionsMembers.get(i));
+          ObjectNode jsonMember = mapper.createObjectNode();
+          jsonMember.put("key", regionsMembers.get(i));
+          jsonMember.put("id", member.getId());
+          jsonMember.put("name", member.getName());
+
+          jsonRegionMembers.add(jsonMember);
+        }
+
+        regionJSON.put("members", jsonRegionMembers);
+        regionsListJson.add(regionJSON);
+      }
+    }
+    return regionsListJson;
+  }
+
+  @RequestMapping(value = "/dataBrowserQuery", method = RequestMethod.GET)
+  public void dataBrowserQuery(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    // get query string
+    String query = request.getParameter("query");
+    String members = request.getParameter("members");
+    int limit = 0;
+
+    try {
+      limit = Integer.valueOf(request.getParameter("limit"));
+    } catch (NumberFormatException e) {
+      limit = 0;
+      if (LOGGER.finerEnabled()) {
+        LOGGER.finer(e.getMessage());
+      }
+    }
+
+    ObjectNode queryResult = mapper.createObjectNode();
+    try {
+
+      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(query)) {
+        // get cluster object
+        Cluster cluster = Repository.get().getCluster();
+        String userName = request.getUserPrincipal().getName();
+
+        // Call execute query method
+        queryResult = cluster.executeQuery(query, members, limit);
+
+        // Add query in history if query is executed successfully
+        if (!queryResult.has("error")) {
+          // Add html escaped query to history
+          String escapedQuery = StringEscapeUtils.escapeHtml(query);
+          cluster.addQueryInHistory(escapedQuery, userName);
+        }
+      }
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+
+    response.getOutputStream().write(queryResult.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/dataBrowserQueryHistory", method = RequestMethod.GET)
+  public void dataBrowserQueryHistory(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+    ObjectNode responseJSON = mapper.createObjectNode();
+    ArrayNode queryResult = null;
+    String action = "";
+
+    try {
+      // get cluster object
+      Cluster cluster = Repository.get().getCluster();
+      String userName = request.getUserPrincipal().getName();
+
+      // get query string
+      action = request.getParameter(QUERYSTRING_PARAM_ACTION);
+      if (!StringUtils.isNotNullNotEmptyNotWhiteSpace(action)) {
+        action = ACTION_VIEW;
+      }
+
+      if (action.toLowerCase().equalsIgnoreCase(ACTION_DELETE)) {
+        String queryId = request.getParameter(QUERYSTRING_PARAM_QUERYID);
+        if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryId)) {
+
+          boolean deleteStatus = cluster.deleteQueryById(userName, queryId);
+          if (deleteStatus) {
+            responseJSON.put("status", STATUS_REPSONSE_SUCCESS);
+          } else {
+            responseJSON.put("status", STATUS_REPSONSE_FAIL);
+            responseJSON.put("error", ERROR_REPSONSE_QUERYNOTFOUND);
+          }
+        } else {
+          responseJSON.put("status", STATUS_REPSONSE_FAIL);
+          responseJSON.put("error", ERROR_REPSONSE_QUERYIDMISSING);
+        }
+      }
+
+      // Get list of past executed queries
+      queryResult = cluster.getQueryHistoryByUserId(userName);
+      responseJSON.put("queryHistory", queryResult);
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+    response.getOutputStream().write(responseJSON.toString().getBytes());
+  }
+
+  @RequestMapping(value = "/dataBrowserExport", method = RequestMethod.POST)
+  public void dataBrowserExport(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+
+    // get query string
+    String filename = request.getParameter("filename");
+    String resultContent = request.getParameter("content");
+
+    response.setHeader("Cache-Control", "");
+    response.setHeader("Content-type", "text/plain");
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(filename)) {
+      response.setHeader("Content-Disposition", "attachment; filename=" + filename);
+    } else {
+      response.setHeader("Content-Disposition", "attachment; filename=" + DEFAULT_EXPORT_FILENAME);
+    }
+
+    if (!StringUtils.isNotNullNotEmptyNotWhiteSpace(resultContent)) {
+      resultContent = "";
+    }
+
+    response.getOutputStream().write(resultContent.getBytes());
+  }
+
+  @RequestMapping(value = "/pulseProductSupport", method = RequestMethod.GET)
+  public void getConfiguredPulseProduct(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+      ObjectNode responseJSON = mapper.createObjectNode();
+
+    try {
+      responseJSON.put("product", pulseProductSupport);
+
+      // Send json response
+      response.getOutputStream().write(responseJSON.toString().getBytes());
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occurred : " + e.getMessage());
+      }
+    }
+  }
+
+  @RequestMapping(value = "/getQueryStatisticsGridModel", method = RequestMethod.GET)
+  public void getQueryStatisticsGridModel(HttpServletRequest request,
+      HttpServletResponse response) throws IOException {
+
+    ObjectNode responseJSON = mapper.createObjectNode();
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+    String userName = request.getUserPrincipal().getName();
+
+    try {
+      String[] arrColNames = Cluster.Statement.getGridColumnNames();
+      String[] arrColAttribs = Cluster.Statement.getGridColumnAttributes();
+      int[] arrColWidths = Cluster.Statement.getGridColumnWidths();
+
+      ArrayNode colNamesList = mapper.createArrayNode();
+      for (int i = 0; i < arrColNames.length; ++i) {
+        colNamesList.add(arrColNames[i]);
+      }
+
+      ArrayNode colModelList = mapper.createArrayNode();
+      for (int i = 0; i < arrColAttribs.length; ++i) {
+        ObjectNode columnJSON = mapper.createObjectNode();
+        columnJSON.put("name", arrColAttribs[i]);
+        columnJSON.put("index", arrColAttribs[i]);
+        columnJSON.put("width", arrColWidths[i]);
+        columnJSON.put("sortable", "true");
+        columnJSON.put("sorttype", ((i == 0) ? "String" : "integer"));
+        colModelList.add(columnJSON);
+      }
+
+      responseJSON.put("columnNames", colNamesList);
+      responseJSON.put("columnModels", colModelList);
+      responseJSON.put("clusterName", cluster.getServerName());
+      responseJSON.put("userName", userName);
+
+      // Send json response
+      response.getOutputStream().write(responseJSON.toString().getBytes());
+    } catch (Exception e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine("Exception Occured : " + e.getMessage());
+      }
+    }
+  }
+
+  /**
+   * @return the pulseProductSupport
+   */
+  public static String getPulseProductSupport() {
+    return pulseProductSupport;
+  }
+
+  /**
+   * @param pulseProductSupport
+   *          the pulseProductSupport to set
+   */
+  public static void setPulseProductSupport(String pulseProductSupport) {
+    PulseController.pulseProductSupport = pulseProductSupport;
+  }
+}
\ No newline at end of file


[76/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONArray.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONArray.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONArray.java
deleted file mode 100644
index 5715db5..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONArray.java
+++ /dev/null
@@ -1,901 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.io.IOException;
-import java.io.StringWriter;
-import java.io.Writer;
-import java.lang.reflect.Array;
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.Iterator;
-import java.util.Map;
-
-/**
- * A JSONArray is an ordered sequence of values. Its external text form is a
- * string wrapped in square brackets with commas separating the values. The
- * internal form is an object having <code>get</code> and <code>opt</code>
- * methods for accessing the values by index, and <code>put</code> methods for
- * adding or replacing values. The values can be any of these types:
- * <code>Boolean</code>, <code>JSONArray</code>, <code>JSONObject</code>,
- * <code>Number</code>, <code>String</code>, or the
- * <code>JSONObject.NULL object</code>.
- * <p>
- * The constructor can convert a JSON text into a Java object. The
- * <code>toString</code> method converts to JSON text.
- * <p>
- * A <code>get</code> method returns a value if one can be found, and throws an
- * exception if one cannot be found. An <code>opt</code> method returns a
- * default value instead of throwing an exception, and so is useful for
- * obtaining optional values.
- * <p>
- * The generic <code>get()</code> and <code>opt()</code> methods return an
- * object which you can cast or query for type. There are also typed
- * <code>get</code> and <code>opt</code> methods that do type checking and type
- * coercion for you.
- * <p>
- * The texts produced by the <code>toString</code> methods strictly conform to
- * JSON syntax rules. The constructors are more forgiving in the texts they will
- * accept:
- * <ul>
- * <li>An extra <code>,</code>&nbsp;<small>(comma)</small> may appear just
- * before the closing bracket.</li>
- * <li>The <code>null</code> value will be inserted when there is <code>,</code>
- * &nbsp;<small>(comma)</small> elision.</li>
- * <li>Strings may be quoted with <code>'</code>&nbsp;<small>(single
- * quote)</small>.</li>
- * <li>Strings do not need to be quoted at all if they do not begin with a quote
- * or single quote, and if they do not contain leading or trailing spaces, and
- * if they do not contain any of these characters:
- * <code>{ } [ ] / \ : , = ; #</code> and if they do not look like numbers and
- * if they are not the reserved words <code>true</code>, <code>false</code>, or
- * <code>null</code>.</li>
- * <li>Values can be separated by <code>;</code> <small>(semicolon)</small> as
- * well as by <code>,</code> <small>(comma)</small>.</li>
- * </ul>
- *
- * @author JSON.org
- * @version 2012-04-20
- */
-public class JSONArray {
-
-
-    /**
-     * The arrayList where the JSONArray's properties are kept.
-     */
-    private final ArrayList myArrayList;
-
-
-    /**
-     * Construct an empty JSONArray.
-     */
-    public JSONArray() {
-        this.myArrayList = new ArrayList();
-    }
-
-    /**
-     * Construct a JSONArray from a JSONTokener.
-     * @param x A JSONTokener
-     * @throws JSONException If there is a syntax error.
-     */
-    public JSONArray(JSONTokener x) throws JSONException {
-        this();
-        if (x.nextClean() != '[') {
-            throw x.syntaxError("A JSONArray text must start with '['");
-        }
-        if (x.nextClean() != ']') {
-            x.back();
-            for (;;) {
-                if (x.nextClean() == ',') {
-                    x.back();
-                    this.myArrayList.add(JSONObject.NULL);
-                } else {
-                    x.back();
-                    this.myArrayList.add(x.nextValue());
-                }
-                switch (x.nextClean()) {
-                case ';':
-                case ',':
-                    if (x.nextClean() == ']') {
-                        return;
-                    }
-                    x.back();
-                    break;
-                case ']':
-                    return;
-                default:
-                    throw x.syntaxError("Expected a ',' or ']'");
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONArray from a source JSON text.
-     * @param source     A string that begins with
-     * <code>[</code>&nbsp;<small>(left bracket)</small>
-     *  and ends with <code>]</code>&nbsp;<small>(right bracket)</small>.
-     *  @throws JSONException If there is a syntax error.
-     */
-    public JSONArray(String source) throws JSONException {
-        this(new JSONTokener(source));
-    }
-
-
-    /**
-     * Construct a JSONArray from a Collection.
-     * @param collection     A Collection.
-     */
-    public JSONArray(Collection collection) {
-        this.myArrayList = new ArrayList();
-        if (collection != null) {
-            Iterator iter = collection.iterator();
-            while (iter.hasNext()) {
-                this.myArrayList.add(JSONObject.wrap(iter.next()));
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONArray from an array
-     * @throws JSONException If not an array.
-     */
-    public JSONArray(Object array) throws JSONException {
-        this();
-        if (array.getClass().isArray()) {
-            int length = Array.getLength(array);
-            for (int i = 0; i < length; i += 1) {
-                this.put(JSONObject.wrap(Array.get(array, i)));
-            }
-        } else {
-            throw new JSONException(
-"JSONArray initial value should be a string or collection or array.");
-        }
-    }
-
-
-    /**
-     * Get the object value associated with an index.
-     * @param index
-     *  The index must be between 0 and length() - 1.
-     * @return An object value.
-     * @throws JSONException If there is no value for the index.
-     */
-    public Object get(int index) throws JSONException {
-        Object object = this.opt(index);
-        if (object == null) {
-            throw new JSONException("JSONArray[" + index + "] not found.");
-        }
-        return object;
-    }
-
-
-    /**
-     * Get the boolean value associated with an index.
-     * The string values "true" and "false" are converted to boolean.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The truth.
-     * @throws JSONException If there is no value for the index or if the
-     *  value is not convertible to boolean.
-     */
-    public boolean getBoolean(int index) throws JSONException {
-        Object object = this.get(index);
-        if (object.equals(Boolean.FALSE) ||
-                (object instanceof String &&
-                ((String)object).equalsIgnoreCase("false"))) {
-            return false;
-        } else if (object.equals(Boolean.TRUE) ||
-                (object instanceof String &&
-                ((String)object).equalsIgnoreCase("true"))) {
-            return true;
-        }
-        throw new JSONException("JSONArray[" + index + "] is not a boolean.");
-    }
-
-
-    /**
-     * Get the double value associated with an index.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     * @throws   JSONException If the key is not found or if the value cannot
-     *  be converted to a number.
-     */
-    public double getDouble(int index) throws JSONException {
-        Object object = this.get(index);
-        try {
-            return object instanceof Number
-                ? ((Number)object).doubleValue()
-                : Double.parseDouble((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONArray[" + index +
-                "] is not a number.");
-        }
-    }
-
-
-    /**
-     * Get the int value associated with an index.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     * @throws   JSONException If the key is not found or if the value is not a number.
-     */
-    public int getInt(int index) throws JSONException {
-        Object object = this.get(index);
-        try {
-            return object instanceof Number
-                ? ((Number)object).intValue()
-                : Integer.parseInt((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONArray[" + index +
-                "] is not a number.");
-        }
-    }
-
-
-    /**
-     * Get the JSONArray associated with an index.
-     * @param index The index must be between 0 and length() - 1.
-     * @return      A JSONArray value.
-     * @throws JSONException If there is no value for the index. or if the
-     * value is not a JSONArray
-     */
-    public JSONArray getJSONArray(int index) throws JSONException {
-        Object object = this.get(index);
-        if (object instanceof JSONArray) {
-            return (JSONArray)object;
-        }
-        throw new JSONException("JSONArray[" + index +
-                "] is not a JSONArray.");
-    }
-
-
-    /**
-     * Get the JSONObject associated with an index.
-     * @param index subscript
-     * @return      A JSONObject value.
-     * @throws JSONException If there is no value for the index or if the
-     * value is not a JSONObject
-     */
-    public JSONObject getJSONObject(int index) throws JSONException {
-        Object object = this.get(index);
-        if (object instanceof JSONObject) {
-            return (JSONObject)object;
-        }
-        throw new JSONException("JSONArray[" + index +
-            "] is not a JSONObject.");
-    }
-
-
-    /**
-     * Get the long value associated with an index.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     * @throws   JSONException If the key is not found or if the value cannot
-     *  be converted to a number.
-     */
-    public long getLong(int index) throws JSONException {
-        Object object = this.get(index);
-        try {
-            return object instanceof Number
-                ? ((Number)object).longValue()
-                : Long.parseLong((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONArray[" + index +
-                "] is not a number.");
-        }
-    }
-
-
-    /**
-     * Get the string associated with an index.
-     * @param index The index must be between 0 and length() - 1.
-     * @return      A string value.
-     * @throws JSONException If there is no string value for the index.
-     */
-    public String getString(int index) throws JSONException {
-        Object object = this.get(index);
-        if (object instanceof String) {
-            return (String)object;
-        }
-        throw new JSONException("JSONArray[" + index + "] not a string.");
-    }
-
-
-    /**
-     * Determine if the value is null.
-     * @param index The index must be between 0 and length() - 1.
-     * @return true if the value at the index is null, or if there is no value.
-     */
-    public boolean isNull(int index) {
-        return JSONObject.NULL.equals(this.opt(index));
-    }
-
-
-    /**
-     * Make a string from the contents of this JSONArray. The
-     * <code>separator</code> string is inserted between each element.
-     * Warning: This method assumes that the data structure is acyclical.
-     * @param separator A string that will be inserted between the elements.
-     * @return a string.
-     * @throws JSONException If the array contains an invalid number.
-     */
-    public String join(String separator) throws JSONException {
-        int len = this.length();
-        StringBuffer sb = new StringBuffer();
-
-        for (int i = 0; i < len; i += 1) {
-            if (i > 0) {
-                sb.append(separator);
-            }
-            sb.append(JSONObject.valueToString(this.myArrayList.get(i)));
-        }
-        return sb.toString();
-    }
-
-
-    /**
-     * Get the number of elements in the JSONArray, included nulls.
-     *
-     * @return The length (or size).
-     */
-    public int length() {
-        return this.myArrayList.size();
-    }
-
-
-    /**
-     * Get the optional object value associated with an index.
-     * @param index The index must be between 0 and length() - 1.
-     * @return      An object value, or null if there is no
-     *              object at that index.
-     */
-    public Object opt(int index) {
-        return (index < 0 || index >= this.length())
-            ? null
-            : this.myArrayList.get(index);
-    }
-
-
-    /**
-     * Get the optional boolean value associated with an index.
-     * It returns false if there is no value at that index,
-     * or if the value is not Boolean.TRUE or the String "true".
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The truth.
-     */
-    public boolean optBoolean(int index)  {
-        return this.optBoolean(index, false);
-    }
-
-
-    /**
-     * Get the optional boolean value associated with an index.
-     * It returns the defaultValue if there is no value at that index or if
-     * it is not a Boolean or the String "true" or "false" (case insensitive).
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @param defaultValue     A boolean default.
-     * @return      The truth.
-     */
-    public boolean optBoolean(int index, boolean defaultValue)  {
-        try {
-            return this.getBoolean(index);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get the optional double value associated with an index.
-     * NaN is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     */
-    public double optDouble(int index) {
-        return this.optDouble(index, Double.NaN);
-    }
-
-
-    /**
-     * Get the optional double value associated with an index.
-     * The defaultValue is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     *
-     * @param index subscript
-     * @param defaultValue     The default value.
-     * @return      The value.
-     */
-    public double optDouble(int index, double defaultValue) {
-        try {
-            return this.getDouble(index);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get the optional int value associated with an index.
-     * Zero is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     */
-    public int optInt(int index) {
-        return this.optInt(index, 0);
-    }
-
-
-    /**
-     * Get the optional int value associated with an index.
-     * The defaultValue is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     * @param index The index must be between 0 and length() - 1.
-     * @param defaultValue     The default value.
-     * @return      The value.
-     */
-    public int optInt(int index, int defaultValue) {
-        try {
-            return this.getInt(index);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get the optional JSONArray associated with an index.
-     * @param index subscript
-     * @return      A JSONArray value, or null if the index has no value,
-     * or if the value is not a JSONArray.
-     */
-    public JSONArray optJSONArray(int index) {
-        Object o = this.opt(index);
-        return o instanceof JSONArray ? (JSONArray)o : null;
-    }
-
-
-    /**
-     * Get the optional JSONObject associated with an index.
-     * Null is returned if the key is not found, or null if the index has
-     * no value, or if the value is not a JSONObject.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      A JSONObject value.
-     */
-    public JSONObject optJSONObject(int index) {
-        Object o = this.opt(index);
-        return o instanceof JSONObject ? (JSONObject)o : null;
-    }
-
-
-    /**
-     * Get the optional long value associated with an index.
-     * Zero is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      The value.
-     */
-    public long optLong(int index) {
-        return this.optLong(index, 0);
-    }
-
-
-    /**
-     * Get the optional long value associated with an index.
-     * The defaultValue is returned if there is no value for the index,
-     * or if the value is not a number and cannot be converted to a number.
-     * @param index The index must be between 0 and length() - 1.
-     * @param defaultValue     The default value.
-     * @return      The value.
-     */
-    public long optLong(int index, long defaultValue) {
-        try {
-            return this.getLong(index);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get the optional string value associated with an index. It returns an
-     * empty string if there is no value at that index. If the value
-     * is not a string and is not null, then it is coverted to a string.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @return      A String value.
-     */
-    public String optString(int index) {
-        return this.optString(index, "");
-    }
-
-
-    /**
-     * Get the optional string associated with an index.
-     * The defaultValue is returned if the key is not found.
-     *
-     * @param index The index must be between 0 and length() - 1.
-     * @param defaultValue     The default value.
-     * @return      A String value.
-     */
-    public String optString(int index, String defaultValue) {
-        Object object = this.opt(index);
-        return JSONObject.NULL.equals(object)
- ? defaultValue : object
-                .toString();
-    }
-
-
-    /**
-     * Append a boolean value. This increases the array's length by one.
-     *
-     * @param value A boolean value.
-     * @return this.
-     */
-    public JSONArray put(boolean value) {
-        this.put(value ? Boolean.TRUE : Boolean.FALSE);
-        return this;
-    }
-
-
-    /**
-     * Put a value in the JSONArray, where the value will be a
-     * JSONArray which is produced from a Collection.
-     * @param value A Collection value.
-     * @return      this.
-     */
-    public JSONArray put(Collection value) {
-        this.put(new JSONArray(value));
-        return this;
-    }
-
-
-    /**
-     * Append a double value. This increases the array's length by one.
-     *
-     * @param value A double value.
-     * @throws JSONException if the value is not finite.
-     * @return this.
-     */
-    public JSONArray put(double value) throws JSONException {
-        Double d = new Double(value);
-        JSONObject.testValidity(d);
-        this.put(d);
-        return this;
-    }
-
-
-    /**
-     * Append an int value. This increases the array's length by one.
-     *
-     * @param value An int value.
-     * @return this.
-     */
-    public JSONArray put(int value) {
-        this.put(new Integer(value));
-        return this;
-    }
-
-
-    /**
-     * Append an long value. This increases the array's length by one.
-     *
-     * @param value A long value.
-     * @return this.
-     */
-    public JSONArray put(long value) {
-        this.put(new Long(value));
-        return this;
-    }
-
-
-    /**
-     * Put a value in the JSONArray, where the value will be a
-     * JSONObject which is produced from a Map.
-     * @param value A Map value.
-     * @return      this.
-     */
-    public JSONArray put(Map value) {
-        this.put(new JSONObject(value));
-        return this;
-    }
-
-
-    /**
-     * Append an object value. This increases the array's length by one.
-     * @param value An object value.  The value should be a
-     *  Boolean, Double, Integer, JSONArray, JSONObject, Long, or String, or the
-     *  JSONObject.NULL object.
-     * @return this.
-     */
-    public JSONArray put(Object value) {
-        this.myArrayList.add(value);
-        return this;
-    }
-
-
-    /**
-     * Put or replace a boolean value in the JSONArray. If the index is greater
-     * than the length of the JSONArray, then null elements will be added as
-     * necessary to pad it out.
-     * @param index The subscript.
-     * @param value A boolean value.
-     * @return this.
-     * @throws JSONException If the index is negative.
-     */
-    public JSONArray put(int index, boolean value) throws JSONException {
-        this.put(index, value ? Boolean.TRUE : Boolean.FALSE);
-        return this;
-    }
-
-
-    /**
-     * Put a value in the JSONArray, where the value will be a
-     * JSONArray which is produced from a Collection.
-     * @param index The subscript.
-     * @param value A Collection value.
-     * @return      this.
-     * @throws JSONException If the index is negative or if the value is
-     * not finite.
-     */
-    public JSONArray put(int index, Collection value) throws JSONException {
-        this.put(index, new JSONArray(value));
-        return this;
-    }
-
-
-    /**
-     * Put or replace a double value. If the index is greater than the length of
-     *  the JSONArray, then null elements will be added as necessary to pad
-     *  it out.
-     * @param index The subscript.
-     * @param value A double value.
-     * @return this.
-     * @throws JSONException If the index is negative or if the value is
-     * not finite.
-     */
-    public JSONArray put(int index, double value) throws JSONException {
-        this.put(index, new Double(value));
-        return this;
-    }
-
-
-    /**
-     * Put or replace an int value. If the index is greater than the length of
-     *  the JSONArray, then null elements will be added as necessary to pad
-     *  it out.
-     * @param index The subscript.
-     * @param value An int value.
-     * @return this.
-     * @throws JSONException If the index is negative.
-     */
-    public JSONArray put(int index, int value) throws JSONException {
-        this.put(index, new Integer(value));
-        return this;
-    }
-
-
-    /**
-     * Put or replace a long value. If the index is greater than the length of
-     *  the JSONArray, then null elements will be added as necessary to pad
-     *  it out.
-     * @param index The subscript.
-     * @param value A long value.
-     * @return this.
-     * @throws JSONException If the index is negative.
-     */
-    public JSONArray put(int index, long value) throws JSONException {
-        this.put(index, new Long(value));
-        return this;
-    }
-
-
-    /**
-     * Put a value in the JSONArray, where the value will be a
-     * JSONObject that is produced from a Map.
-     * @param index The subscript.
-     * @param value The Map value.
-     * @return      this.
-     * @throws JSONException If the index is negative or if the the value is
-     *  an invalid number.
-     */
-    public JSONArray put(int index, Map value) throws JSONException {
-        this.put(index, new JSONObject(value));
-        return this;
-    }
-
-
-    /**
-     * Put or replace an object value in the JSONArray. If the index is greater
-     *  than the length of the JSONArray, then null elements will be added as
-     *  necessary to pad it out.
-     * @param index The subscript.
-     * @param value The value to put into the array. The value should be a
-     *  Boolean, Double, Integer, JSONArray, JSONObject, Long, or String, or the
-     *  JSONObject.NULL object.
-     * @return this.
-     * @throws JSONException If the index is negative or if the the value is
-     *  an invalid number.
-     */
-    public JSONArray put(int index, Object value) throws JSONException {
-        JSONObject.testValidity(value);
-        if (index < 0) {
-            throw new JSONException("JSONArray[" + index + "] not found.");
-        }
-        if (index < this.length()) {
-            this.myArrayList.set(index, value);
-        } else {
-            while (index != this.length()) {
-                this.put(JSONObject.NULL);
-            }
-            this.put(value);
-        }
-        return this;
-    }
-
-
-    /**
-     * Remove an index and close the hole.
-     * @param index The index of the element to be removed.
-     * @return The value that was associated with the index,
-     * or null if there was no value.
-     */
-    public Object remove(int index) {
-        Object o = this.opt(index);
-        this.myArrayList.remove(index);
-        return o;
-    }
-
-
-    /**
-     * Produce a JSONObject by combining a JSONArray of names with the values
-     * of this JSONArray.
-     * @param names A JSONArray containing a list of key strings. These will be
-     * paired with the values.
-     * @return A JSONObject, or null if there are no names or if this JSONArray
-     * has no values.
-     * @throws JSONException If any of the names are null.
-     */
-    public JSONObject toJSONObject(JSONArray names) throws JSONException {
-        if (names == null || names.length() == 0 || this.length() == 0) {
-            return null;
-        }
-        JSONObject jo = new JSONObject();
-        for (int i = 0; i < names.length(); i += 1) {
-            jo.put(names.getString(i), this.opt(i));
-        }
-        return jo;
-    }
-
-
-    /**
-     * Make a JSON text of this JSONArray. For compactness, no
-     * unnecessary whitespace is added. If it is not possible to produce a
-     * syntactically correct JSON text then null will be returned instead. This
-     * could occur if the array contains an invalid number.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     *
-     * @return a printable, displayable, transmittable
-     *  representation of the array.
-     */
-    public String toString() {
-        try {
-            return '[' + this.join(",") + ']';
-        } catch (Exception e) {
-            return null;
-        }
-    }
-
-
-    /**
-     * Make a prettyprinted JSON text of this JSONArray.
-     * Warning: This method assumes that the data structure is acyclical.
-     * @param indentFactor The number of spaces to add to each level of
-     *  indentation.
-     * @return a printable, displayable, transmittable
-     *  representation of the object, beginning
-     *  with <code>[</code>&nbsp;<small>(left bracket)</small> and ending
-     *  with <code>]</code>&nbsp;<small>(right bracket)</small>.
-     * @throws JSONException
-     */
-    public String toString(int indentFactor) throws JSONException {
-        StringWriter sw = new StringWriter();
-        synchronized (sw.getBuffer()) {
-            return this.write(sw, indentFactor, 0).toString();
-        }
-    }
-
-    /**
-     * Write the contents of the JSONArray as JSON text to a writer. For
-     * compactness, no whitespace is added.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     *
-     * @return The writer.
-     * @throws JSONException
-     */
-    public Writer write(Writer writer) throws JSONException {
-        return this.write(writer, 0, 0);
-    }
-
-    /**
-     * Write the contents of the JSONArray as JSON text to a writer. For
-     * compactness, no whitespace is added.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     *
-     * @param indentFactor
-     *            The number of spaces to add to each level of indentation.
-     * @param indent
-     *            The indention of the top level.
-     * @return The writer.
-     * @throws JSONException
-     */
-    Writer write(Writer writer, int indentFactor, int indent)
-            throws JSONException {
-        try {
-            boolean commanate = false;
-            int length = this.length();
-            writer.write('[');
-
-            if (length == 1) {
-                JSONObject.writeValue(writer, this.myArrayList.get(0),
-                        indentFactor, indent);
-            } else if (length != 0) {
-                final int newindent = indent + indentFactor;
-
-                for (int i = 0; i < length; i += 1) {
-                    if (commanate) {
-                        writer.write(',');
-                    }
-                    if (indentFactor > 0) {
-                        writer.write('\n');
-                    }
-                    JSONObject.indent(writer, newindent);
-                    JSONObject.writeValue(writer, this.myArrayList.get(i),
-                            indentFactor, newindent);
-                    commanate = true;
-                }
-                if (indentFactor > 0) {
-                    writer.write('\n');
-                }
-                JSONObject.indent(writer, indent);
-            }
-            writer.write(']');
-            return writer;
-        } catch (IOException e) {
-           throw new JSONException(e);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONException.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONException.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONException.java
deleted file mode 100644
index 7533e49..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONException.java
+++ /dev/null
@@ -1,47 +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 com.vmware.geode.tools.pulse.internal.json;
-
-/**
- * The JSONException is thrown by the JSON.org classes when things are amiss.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class JSONException extends Exception {
-    private static final long serialVersionUID = 0;
-    private Throwable cause;
-
-    /**
-     * Constructs a JSONException with an explanatory message.
-     * @param message Detail about the reason for the exception.
-     */
-    public JSONException(String message) {
-        super(message);
-    }
-
-    public JSONException(Throwable cause) {
-        super(cause.getMessage());
-        this.cause = cause;
-    }
-
-    public Throwable getCause() {
-        return this.cause;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONML.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONML.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONML.java
deleted file mode 100644
index 3c52063..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONML.java
+++ /dev/null
@@ -1,462 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.util.Iterator;
-
-
-/**
- * This provides static methods to convert an XML text into a JSONArray or
- * JSONObject, and to covert a JSONArray or JSONObject into an XML text using
- * the JsonML transform.
- * 
- * @author JSON.org
- * @version 2012-03-28
- */
-public class JSONML {
-
-    /**
-     * Parse XML values and store them in a JSONArray.
-     * @param x       The XMLTokener containing the source string.
-     * @param arrayForm true if array form, false if object form.
-     * @param ja      The JSONArray that is containing the current tag or null
-     *     if we are at the outermost level.
-     * @return A JSONArray if the value is the outermost tag, otherwise null.
-     * @throws JSONException
-     */
-    private static Object parse(
-        XMLTokener x,
-        boolean    arrayForm,
-        JSONArray  ja
-    ) throws JSONException {
-        String     attribute;
-        char       c;
-        String       closeTag = null;
-        int        i;
-        JSONArray  newja = null;
-        JSONObject newjo = null;
-        Object     token;
-        String       tagName = null;
-
-// Test for and skip past these forms:
-//      <!-- ... -->
-//      <![  ... ]]>
-//      <!   ...   >
-//      <?   ...  ?>
-
-        while (true) {
-            if (!x.more()) {
-                throw x.syntaxError("Bad XML");
-            }
-            token = x.nextContent();
-            if (token == XML.LT) {
-                token = x.nextToken();
-                if (token instanceof Character) {
-                    if (token == XML.SLASH) {
-
-// Close tag </
-
-                        token = x.nextToken();
-                        if (!(token instanceof String)) {
-                            throw new JSONException(
-                                    "Expected a closing name instead of '" +
-                                    token + "'.");
-                        }
-                        if (x.nextToken() != XML.GT) {
-                            throw x.syntaxError("Misshaped close tag");
-                        }
-                        return token;
-                    } else if (token == XML.BANG) {
-
-// <!
-
-                        c = x.next();
-                        if (c == '-') {
-                            if (x.next() == '-') {
-                                x.skipPast("-->");
-                            } else {
-                                x.back();
-                            }
-                        } else if (c == '[') {
-                            token = x.nextToken();
-                            if (token.equals("CDATA") && x.next() == '[') {
-                                if (ja != null) {
-                                    ja.put(x.nextCDATA());
-                                }
-                            } else {
-                                throw x.syntaxError("Expected 'CDATA['");
-                            }
-                        } else {
-                            i = 1;
-                            do {
-                                token = x.nextMeta();
-                                if (token == null) {
-                                    throw x.syntaxError("Missing '>' after '<!'.");
-                                } else if (token == XML.LT) {
-                                    i += 1;
-                                } else if (token == XML.GT) {
-                                    i -= 1;
-                                }
-                            } while (i > 0);
-                        }
-                    } else if (token == XML.QUEST) {
-
-// <?
-
-                        x.skipPast("?>");
-                    } else {
-                        throw x.syntaxError("Misshaped tag");
-                    }
-
-// Open tag <
-
-                } else {
-                    if (!(token instanceof String)) {
-                        throw x.syntaxError("Bad tagName '" + token + "'.");
-                    }
-                    tagName = (String)token;
-                    newja = new JSONArray();
-                    newjo = new JSONObject();
-                    if (arrayForm) {
-                        newja.put(tagName);
-                        if (ja != null) {
-                            ja.put(newja);
-                        }
-                    } else {
-                        newjo.put("tagName", tagName);
-                        if (ja != null) {
-                            ja.put(newjo);
-                        }
-                    }
-                    token = null;
-                    for (;;) {
-                        if (token == null) {
-                            token = x.nextToken();
-                        }
-                        if (token == null) {
-                            throw x.syntaxError("Misshaped tag");
-                        }
-                        if (!(token instanceof String)) {
-                            break;
-                        }
-
-// attribute = value
-
-                        attribute = (String)token;
-                        if (!arrayForm && ("tagName".equals(attribute) || "childNode".equals(attribute))) {
-                            throw x.syntaxError("Reserved attribute.");
-                        }
-                        token = x.nextToken();
-                        if (token == XML.EQ) {
-                            token = x.nextToken();
-                            if (!(token instanceof String)) {
-                                throw x.syntaxError("Missing value");
-                            }
-                            newjo.accumulate(attribute, XML.stringToValue((String)token));
-                            token = null;
-                        } else {
-                            newjo.accumulate(attribute, "");
-                        }
-                    }
-                    if (arrayForm && newjo.length() > 0) {
-                        newja.put(newjo);
-                    }
-
-// Empty tag <.../>
-
-                    if (token == XML.SLASH) {
-                        if (x.nextToken() != XML.GT) {
-                            throw x.syntaxError("Misshaped tag");
-                        }
-                        if (ja == null) {
-                            if (arrayForm) {
-                                return newja;
-                            } else {
-                                return newjo;
-                            }
-                        }
-
-// Content, between <...> and </...>
-
-                    } else {
-                        if (token != XML.GT) {
-                            throw x.syntaxError("Misshaped tag");
-                        }
-                        closeTag = (String)parse(x, arrayForm, newja);
-                        if (closeTag != null) {
-                            if (!closeTag.equals(tagName)) {
-                                throw x.syntaxError("Mismatched '" + tagName +
-                                        "' and '" + closeTag + "'");
-                            }
-                            tagName = null;
-                            if (!arrayForm && newja.length() > 0) {
-                                newjo.put("childNodes", newja);
-                            }
-                            if (ja == null) {
-                                if (arrayForm) {
-                                    return newja;
-                                } else {
-                                    return newjo;
-                                }
-                            }
-                        }
-                    }
-                }
-            } else {
-                if (ja != null) {
-                    ja.put(token instanceof String
-                        ? XML.stringToValue((String)token)
-                        : token);
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Convert a well-formed (but not necessarily valid) XML string into a
-     * JSONArray using the JsonML transform. Each XML tag is represented as
-     * a JSONArray in which the first element is the tag name. If the tag has
-     * attributes, then the second element will be JSONObject containing the
-     * name/value pairs. If the tag contains children, then strings and
-     * JSONArrays will represent the child tags.
-     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
-     * @param string The source string.
-     * @return A JSONArray containing the structured data from the XML string.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(String string) throws JSONException {
-        return toJSONArray(new XMLTokener(string));
-    }
-
-
-    /**
-     * Convert a well-formed (but not necessarily valid) XML string into a
-     * JSONArray using the JsonML transform. Each XML tag is represented as
-     * a JSONArray in which the first element is the tag name. If the tag has
-     * attributes, then the second element will be JSONObject containing the
-     * name/value pairs. If the tag contains children, then strings and
-     * JSONArrays will represent the child content and tags.
-     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
-     * @param x An XMLTokener.
-     * @return A JSONArray containing the structured data from the XML string.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(XMLTokener x) throws JSONException {
-        return (JSONArray)parse(x, true, null);
-    }
-
-
-    /**
-     * Convert a well-formed (but not necessarily valid) XML string into a
-     * JSONObject using the JsonML transform. Each XML tag is represented as
-     * a JSONObject with a "tagName" property. If the tag has attributes, then
-     * the attributes will be in the JSONObject as properties. If the tag
-     * contains children, the object will have a "childNodes" property which
-     * will be an array of strings and JsonML JSONObjects.
-
-     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
-     * @param x An XMLTokener of the XML source text.
-     * @return A JSONObject containing the structured data from the XML string.
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(XMLTokener x) throws JSONException {
-           return (JSONObject)parse(x, false, null);
-    }
-
-
-    /**
-     * Convert a well-formed (but not necessarily valid) XML string into a
-     * JSONObject using the JsonML transform. Each XML tag is represented as
-     * a JSONObject with a "tagName" property. If the tag has attributes, then
-     * the attributes will be in the JSONObject as properties. If the tag
-     * contains children, the object will have a "childNodes" property which
-     * will be an array of strings and JsonML JSONObjects.
-
-     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
-     * @param string The XML source text.
-     * @return A JSONObject containing the structured data from the XML string.
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(String string) throws JSONException {
-        return toJSONObject(new XMLTokener(string));
-    }
-
-
-    /**
-     * Reverse the JSONML transformation, making an XML text from a JSONArray.
-     * @param ja A JSONArray.
-     * @return An XML string.
-     * @throws JSONException
-     */
-    public static String toString(JSONArray ja) throws JSONException {
-        int             i;
-        JSONObject   jo;
-        String       key;
-        Iterator     keys;
-        int             length;
-        Object         object;
-        StringBuffer sb = new StringBuffer();
-        String       tagName;
-        String       value;
-
-// Emit <tagName
-
-        tagName = ja.getString(0);
-        XML.noSpace(tagName);
-        tagName = XML.escape(tagName);
-        sb.append('<');
-        sb.append(tagName);
-
-        object = ja.opt(1);
-        if (object instanceof JSONObject) {
-            i = 2;
-            jo = (JSONObject)object;
-
-// Emit the attributes
-
-            keys = jo.keys();
-            while (keys.hasNext()) {
-                key = keys.next().toString();
-                XML.noSpace(key);
-                value = jo.optString(key);
-                if (value != null) {
-                    sb.append(' ');
-                    sb.append(XML.escape(key));
-                    sb.append('=');
-                    sb.append('"');
-                    sb.append(XML.escape(value));
-                    sb.append('"');
-                }
-            }
-        } else {
-            i = 1;
-        }
-
-//Emit content in body
-
-        length = ja.length();
-        if (i >= length) {
-            sb.append('/');
-            sb.append('>');
-        } else {
-            sb.append('>');
-            do {
-                object = ja.get(i);
-                i += 1;
-                if (object != null) {
-                    if (object instanceof String) {
-                        sb.append(XML.escape(object.toString()));
-                    } else if (object instanceof JSONObject) {
-                        sb.append(toString((JSONObject)object));
-                    } else if (object instanceof JSONArray) {
-                        sb.append(toString((JSONArray)object));
-                    }
-                }
-            } while (i < length);
-            sb.append('<');
-            sb.append('/');
-            sb.append(tagName);
-            sb.append('>');
-        }
-        return sb.toString();
-    }
-
-    /**
-     * Reverse the JSONML transformation, making an XML text from a JSONObject.
-     * The JSONObject must contain a "tagName" property. If it has children,
-     * then it must have a "childNodes" property containing an array of objects.
-     * The other properties are attributes with string values.
-     * @param jo A JSONObject.
-     * @return An XML string.
-     * @throws JSONException
-     */
-    public static String toString(JSONObject jo) throws JSONException {
-        StringBuffer sb = new StringBuffer();
-        int          i;
-        JSONArray    ja;
-        String       key;
-        Iterator     keys;
-        int          length;
-        Object         object;
-        String       tagName;
-        String       value;
-
-//Emit <tagName
-
-        tagName = jo.optString("tagName");
-        if (tagName == null) {
-            return XML.escape(jo.toString());
-        }
-        XML.noSpace(tagName);
-        tagName = XML.escape(tagName);
-        sb.append('<');
-        sb.append(tagName);
-
-//Emit the attributes
-
-        keys = jo.keys();
-        while (keys.hasNext()) {
-            key = keys.next().toString();
-            if (!"tagName".equals(key) && !"childNodes".equals(key)) {
-                XML.noSpace(key);
-                value = jo.optString(key);
-                if (value != null) {
-                    sb.append(' ');
-                    sb.append(XML.escape(key));
-                    sb.append('=');
-                    sb.append('"');
-                    sb.append(XML.escape(value));
-                    sb.append('"');
-                }
-            }
-        }
-
-//Emit content in body
-
-        ja = jo.optJSONArray("childNodes");
-        if (ja == null) {
-            sb.append('/');
-            sb.append('>');
-        } else {
-            sb.append('>');
-            length = ja.length();
-            for (i = 0; i < length; i += 1) {
-                object = ja.get(i);
-                if (object != null) {
-                    if (object instanceof String) {
-                        sb.append(XML.escape(object.toString()));
-                    } else if (object instanceof JSONObject) {
-                        sb.append(toString((JSONObject)object));
-                    } else if (object instanceof JSONArray) {
-                        sb.append(toString((JSONArray)object));
-                    } else {
-                        sb.append(object.toString());
-                    }
-                }
-            }
-            sb.append('<');
-            sb.append('/');
-            sb.append(tagName);
-            sb.append('>');
-        }
-        return sb.toString();
-    }
-}


[40/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ClientNotReadyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientNotReadyException.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientNotReadyException.java
index eebc36f..388ff4a 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientNotReadyException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientNotReadyException.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.OperationAbortedException;
+import org.apache.geode.cache.OperationAbortedException;
 
 /**
  * A <code>ClientNotReadyException</code> indicates a client attempted to invoke
- * the {@link com.gemstone.gemfire.cache.Cache#readyForEvents}
+ * the {@link org.apache.geode.cache.Cache#readyForEvents}
  * method, but failed.
  * <p>This exception was moved from the <code>util</code> package in 5.7.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
index 3141d47..d57ac05 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheListener;
-import com.gemstone.gemfire.cache.CustomExpiry;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.compression.Compressor;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.CustomExpiry;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.compression.Compressor;
 
 /**
  * A factory for constructing {@link ClientCache client cache} {@link Region

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionShortcut.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionShortcut.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionShortcut.java
index cb04d74..415bd1b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionShortcut.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionShortcut.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  * Each enum represents a predefined {@link RegionAttributes} in a {@link ClientCache}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableLocatorsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableLocatorsException.java b/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableLocatorsException.java
index 0967a8c..7397f17 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableLocatorsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableLocatorsException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableServersException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableServersException.java b/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableServersException.java
index 0c3f0e5..e5d9e4e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableServersException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/NoAvailableServersException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/Pool.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/Pool.java b/geode-core/src/main/java/org/apache/geode/cache/client/Pool.java
index 14f20ab..9955a06 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/Pool.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/Pool.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
 import java.net.InetSocketAddress;
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.query.QueryService;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/PoolFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/PoolFactory.java b/geode-core/src/main/java/org/apache/geode/cache/client/PoolFactory.java
index 4d9588b..aeaa44a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/PoolFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/PoolFactory.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.*; // for javadocs
-import com.gemstone.gemfire.cache.query.*; // for javadocs
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.*; // for javadocs
+import org.apache.geode.cache.query.*; // for javadocs
 
 
 /**
@@ -432,7 +432,7 @@ public interface PoolFactory {
    * By default setPRSingleHopEnabled is <code>true</code>
    * in which case the client is aware of the location of partitions on servers hosting
    * {@link Region regions} with
-   * {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}.
+   * {@link org.apache.geode.cache.DataPolicy#PARTITION}.
    * Using this information, the client routes the client cache operations
    * directly to the server which is hosting the required partition for the
    * cache operation using a single network hop.
@@ -445,9 +445,9 @@ public interface PoolFactory {
    * to go to the required partition for that cache operation.
    * The client will use fewer network connections to the servers.
    * <p>
-   * Caution: for {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION partition} regions
+   * Caution: for {@link org.apache.geode.cache.DataPolicy#PARTITION partition} regions
    *  with
-   * {@link com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int) local-max-memory}
+   * {@link org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int) local-max-memory}
    * equal to zero, no cache operations mentioned above will be routed to those
    * servers as they do not host any partitions.
    * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/PoolManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/PoolManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/PoolManager.java
index de125a2..614f936 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/PoolManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/PoolManager.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.distributed.DistributedSystem; // for javadocs
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.PoolManagerImpl;
+import org.apache.geode.distributed.DistributedSystem; // for javadocs
 
 /**
  * Manages creation and access to {@link Pool connection pools} for clients.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ServerConnectivityException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ServerConnectivityException.java b/geode-core/src/main/java/org/apache/geode/cache/client/ServerConnectivityException.java
index 545bfe0..2abb81e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ServerConnectivityException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ServerConnectivityException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * A generic exception indicating that a failure has happened while communicating

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ServerOperationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ServerOperationException.java b/geode-core/src/main/java/org/apache/geode/cache/client/ServerOperationException.java
index e18a8b2..e48dee8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ServerOperationException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ServerOperationException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
 
 /**
  * An exception indicating that a failure has happened on the server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ServerRefusedConnectionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ServerRefusedConnectionException.java b/geode-core/src/main/java/org/apache/geode/cache/client/ServerRefusedConnectionException.java
index 363942d..0370d9b 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ServerRefusedConnectionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ServerRefusedConnectionException.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.OperationAbortedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.OperationAbortedException;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * A <code>ServerRefusedConnectionException</code> indicates a client attempted

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/SubscriptionNotEnabledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/SubscriptionNotEnabledException.java b/geode-core/src/main/java/org/apache/geode/cache/client/SubscriptionNotEnabledException.java
index b099528..f655336 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/SubscriptionNotEnabledException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/SubscriptionNotEnabledException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
index f93620e..1d7d4fc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInputStream;
@@ -22,22 +22,22 @@ import java.net.SocketTimeoutException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CacheServerImpl;
+import org.apache.geode.internal.cache.PutAllPartialResultException;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Represents an operation that can be performed in a client by sending
@@ -370,7 +370,7 @@ public abstract class AbstractOp implements Op {
   protected boolean timedOut;
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.Op#attempt(com.gemstone.gemfire.cache.client.internal.Connection)
+   * @see org.apache.geode.cache.client.internal.Op#attempt(org.apache.geode.cache.client.internal.Connection)
    */
   public Object attempt(Connection cnx) throws Exception {
     this.failed = true;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXEnumOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXEnumOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXEnumOp.java
index 59ed8f2..14121cb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXEnumOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXEnumOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.pdx.internal.EnumInfo;
 
 /**
  * Push a PDX Enum id to other servers.
@@ -44,7 +44,7 @@ public class AddPDXEnumOp {
   
   private static class AddPdxEnumOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public AddPdxEnumOpImpl(int id, EnumInfo ei) {
       super(MessageType.ADD_PDX_ENUM, 2);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXTypeOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXTypeOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXTypeOp.java
index b7eece8..e6b74a9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXTypeOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AddPDXTypeOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.pdx.internal.PdxType;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.pdx.internal.PdxType;
 
 /**
  * Add a PdxType to a server.
@@ -44,7 +44,7 @@ public class AddPDXTypeOp {
   
   private static class AddPDXTypeOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public AddPDXTypeOpImpl(int id, PdxType type) {
       super(MessageType.ADD_PDX_TYPE, 2);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
index 27f77ff..dc04cd7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
@@ -17,34 +17,34 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.command.PutUserCredentials;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
-import com.gemstone.gemfire.security.AuthenticationRequiredException;
-import com.gemstone.gemfire.security.NotAuthorizedException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.HandShake;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.command.PutUserCredentials;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.security.AuthenticationFailedException;
+import org.apache.geode.security.AuthenticationRequiredException;
+import org.apache.geode.security.NotAuthorizedException;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInputStream;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Authenticates this client (or a user) on a server. This op ideally should get

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
index 844a775..7381675 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.IOException;
 import java.net.ConnectException;
@@ -36,25 +36,25 @@ import java.util.concurrent.atomic.AtomicReference;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.client.NoAvailableLocatorsException;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientReplacementRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.ServerLocationRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.ServerLocationResponse;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpClient;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.client.NoAvailableLocatorsException;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionResponse;
+import org.apache.geode.cache.client.internal.locator.ClientReplacementRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersResponse;
+import org.apache.geode.cache.client.internal.locator.LocatorListRequest;
+import org.apache.geode.cache.client.internal.locator.LocatorListResponse;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionResponse;
+import org.apache.geode.cache.client.internal.locator.ServerLocationRequest;
+import org.apache.geode.cache.client.internal.locator.ServerLocationResponse;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.tcpserver.TcpClient;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A connection source which uses locators to find

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/CacheServerLoadMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CacheServerLoadMessage.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CacheServerLoadMessage.java
index 31550b4..ae6cd2b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CacheServerLoadMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CacheServerLoadMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,15 +22,15 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.ServerLocator;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.ServerLocator;
+import org.apache.geode.internal.InternalDataSerializer;
 
 /**
  * A message from a server to a locator to update the locator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClearOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClearOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClearOp.java
index c576f85..7d8944f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClearOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClearOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.EventID;
 
 /**
  * Does a region clear (or create) on a server
@@ -68,7 +68,7 @@ public class ClearOp {
   
   private static class ClearOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public ClearOpImpl(String region,
                        EventID eventId,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientMetadataService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientMetadataService.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientMetadataService.java
index 4005b78..c863d46 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientMetadataService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientMetadataService.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.cache.client.internal;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
index c8a523d..d7ac2c0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientPartitionAdvisor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -28,16 +28,16 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionResolver;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.cache.BucketServerLocation66;
-import com.gemstone.gemfire.internal.cache.FixedPartitionAttributesImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.PartitionResolver;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.cache.BucketServerLocation66;
+import org.apache.geode.internal.cache.FixedPartitionAttributesImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Stores the information such as partition attributes and meta data details

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientRegionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientRegionFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientRegionFactoryImpl.java
index bba2d75..02edbda 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientRegionFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientRegionFactoryImpl.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.CacheListener;
-import com.gemstone.gemfire.cache.CustomExpiry;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.InterestPolicy;
-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.SubscriptionAttributes;
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.UserSpecifiedRegionAttributes;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.CustomExpiry;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.InterestPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.SubscriptionAttributes;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.UserSpecifiedRegionAttributes;
 
 /**
  * The distributed system will always default to a loner on a client.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
index 93b02c4..25bb69f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/CloseConnectionOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CloseConnectionOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CloseConnectionOp.java
index 2845ef9..e4d2510 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CloseConnectionOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CloseConnectionOp.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.EOFException;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Tell a server that a connection is being closed
@@ -48,7 +48,7 @@ public class CloseConnectionOp {
   
   private static class CloseConnectionOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public CloseConnectionOpImpl(boolean keepAlive)  {
       super(MessageType.CLOSE_CONNECTION, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/CommitOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CommitOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CommitOp.java
index e694a49..4f0098f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/CommitOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/CommitOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Does a commit on a server
@@ -47,7 +47,7 @@ public class CommitOp {
     
     private TXCommitMessage tXCommitMessageResponse = null;
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public CommitOpImpl(int txId) {
       super(MessageType.COMMIT, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/Connection.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Connection.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Connection.java
index 5037135..a00cbb4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Connection.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Connection.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.InputStream;
 import java.io.OutputStream;
@@ -22,8 +22,8 @@ import java.net.Socket;
 import java.net.SocketException;
 import java.nio.ByteBuffer;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
 
 /**
  * Represents a connection from a client to a server.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactory.java
index 248420f..272ae7e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactory.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.security.GemFireSecurityException;
 
 /**
  * A factory for creating new connections.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactoryImpl.java
index 56449db..2b04403 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionFactoryImpl.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.GatewayConfigurationException;
-import com.gemstone.gemfire.cache.client.ServerRefusedConnectionException;
-import com.gemstone.gemfire.cache.client.internal.ServerBlackList.FailureTracker;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.tier.Acceptor;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientUpdater;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.GatewayConfigurationException;
+import org.apache.geode.cache.client.ServerRefusedConnectionException;
+import org.apache.geode.cache.client.internal.ServerBlackList.FailureTracker;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.tier.Acceptor;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientUpdater;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.HandShake;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.security.GemFireSecurityException;
 import org.apache.logging.log4j.Logger;
 
 import java.util.HashSet;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionImpl.java
index 6ed2912..0392000 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -28,23 +28,23 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.ForcedDisconnectException;
-import com.gemstone.gemfire.cache.client.internal.ExecuteFunctionOp.ExecuteFunctionOpImpl;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.ForcedDisconnectException;
+import org.apache.geode.cache.client.internal.ExecuteFunctionOp.ExecuteFunctionOpImpl;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.tier.sockets.HandShake;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A single client to server connection.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionSource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionSource.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionSource.java
index 4230f62..cd867c8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionSource.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionSource.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionStats.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionStats.java
index 6aaae2d..c5e4fac 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionStats.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ConnectionStats.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.PoolStats;
-import com.gemstone.gemfire.internal.cache.tier.sockets.MessageStats;
+package org.apache.geode.cache.client.internal;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.PoolStats;
+import org.apache.geode.internal.cache.tier.sockets.MessageStats;
 
 /**
  * Stats for a client to server {@link Connection}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ContainsKeyOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ContainsKeyOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ContainsKeyOp.java
index 6200f3e..9cd7be1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ContainsKeyOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ContainsKeyOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Does a region containsKey on a server
@@ -53,7 +53,7 @@ public class ContainsKeyOp {
     private final MODE mode;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public ContainsKeyOpImpl(String region,
                          Object key,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/DataSerializerRecoveryListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DataSerializerRecoveryListener.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DataSerializerRecoveryListener.java
index 4333b0e..754bdcb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DataSerializerRecoveryListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DataSerializerRecoveryListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.RejectedExecutionException;
 import java.util.concurrent.ScheduledExecutorService;
@@ -23,14 +23,14 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.InternalDataSerializer.SerializerAttributesHolder;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.InternalDataSerializer.SerializerAttributesHolder;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class DataSerializerRecoveryListener extends EndpointManager.EndpointListenerAdapter {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyOp.java
index ab9b2d1..2587ab6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyOp.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.client.AllConnectionsInUseException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-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 com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.client.AllConnectionsInUseException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region destroy on a server
@@ -146,7 +146,7 @@ public class DestroyOp {
     private Object callbackArg;
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public DestroyOpImpl(LocalRegion region,
                          Object key,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyRegionOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyRegionOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyRegionOp.java
index fa13609..4bafa63 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyRegionOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/DestroyRegionOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.EventID;
 
 /**
  * Does a region destroyRegion (or create) on a server
@@ -66,7 +66,7 @@ public class DestroyRegionOp {
   
   private static class DestroyRegionOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public DestroyRegionOpImpl(String region,
                      EventID eventId,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/Endpoint.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Endpoint.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Endpoint.java
index 0048244..a1155d6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Endpoint.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Endpoint.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicLong;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * Represents a server. Keeps track of information about the specific server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
index 9d88670..6fb43da 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Map;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * The endpoint manager keeps track of which servers we 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
index 111cec6..3f3d725 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -26,16 +26,16 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.statistics.DummyStatisticsFactory;
-import com.gemstone.gemfire.internal.cache.PoolStats;
-import com.gemstone.gemfire.internal.cache.tier.InternalClientMembership;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.statistics.DummyStatisticsFactory;
+import org.apache.geode.internal.cache.PoolStats;
+import org.apache.geode.internal.cache.tier.InternalClientMembership;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  *
@@ -60,7 +60,7 @@ public class EndpointManagerImpl implements EndpointManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#referenceEndpoint(com.gemstone.gemfire.distributed.internal.ServerLocation)
+   * @see org.apache.geode.cache.client.internal.EndpointManager#referenceEndpoint(org.apache.geode.distributed.internal.ServerLocation)
    */
   public Endpoint referenceEndpoint(ServerLocation server, DistributedMember memberId) {
     //logger.warn("REFENDPOINT server:"+server+" memberId:"+memberId);
@@ -94,7 +94,7 @@ public class EndpointManagerImpl implements EndpointManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#serverCrashed(com.gemstone.gemfire.cache.client.internal.Endpoint)
+   * @see org.apache.geode.cache.client.internal.EndpointManager#serverCrashed(org.apache.geode.cache.client.internal.Endpoint)
    */
   public void serverCrashed(Endpoint endpoint) {
     removeEndpoint(endpoint, true);
@@ -161,14 +161,14 @@ public class EndpointManagerImpl implements EndpointManager {
   
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#getEndpointMap()
+   * @see org.apache.geode.cache.client.internal.EndpointManager#getEndpointMap()
    */
   public Map<ServerLocation, Endpoint> getEndpointMap() {
     return endpointMap;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#close()
+   * @see org.apache.geode.cache.client.internal.EndpointManager#close()
    */
   public synchronized void close() {
     for(Iterator<ConnectionStats> itr = statMap.values().iterator(); itr.hasNext(); ) {
@@ -182,14 +182,14 @@ public class EndpointManagerImpl implements EndpointManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#addListener(com.gemstone.gemfire.cache.client.internal.EndpointManagerImpl.EndpointListener)
+   * @see org.apache.geode.cache.client.internal.EndpointManager#addListener(org.apache.geode.cache.client.internal.EndpointManagerImpl.EndpointListener)
    */
   public void addListener(EndpointManager.EndpointListener listener) {
     this.listener.addListener(listener);
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.EndpointManager#removeListener(com.gemstone.gemfire.cache.client.internal.EndpointManagerImpl.EndpointListener)
+   * @see org.apache.geode.cache.client.internal.EndpointManager#removeListener(org.apache.geode.cache.client.internal.EndpointManagerImpl.EndpointListener)
    */
   public void removeListener(EndpointManager.EndpointListener listener) {
     this.listener.removeListener(listener);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
index aeea0b9..6c6d232 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 
-import com.gemstone.gemfire.cache.NoSubscriptionServersAvailableException;
-import com.gemstone.gemfire.cache.client.SubscriptionNotEnabledException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.cache.NoSubscriptionServersAvailableException;
+import org.apache.geode.cache.client.SubscriptionNotEnabledException;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * Provides methods to execute AbstractOp instances on a client pool.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionHelper.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionHelper.java
index 46d6162..993b2cf 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 public class ExecuteFunctionHelper {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
index 705f892..d142eb5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Arrays;
 import java.util.Iterator;
@@ -22,19 +22,19 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
-import com.gemstone.gemfire.internal.cache.execute.MemberMappedArgument;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
+import org.apache.geode.internal.cache.execute.MemberMappedArgument;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Does a Execution of function on server (possibly without region/cache) 
@@ -144,7 +144,7 @@ public class ExecuteFunctionNoAckOp {
     private static final int MSG_PARTS = 6;
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException
+     * @throws org.apache.geode.SerializationException
      *                 if serialization fails
      */
     public ExecuteFunctionNoAckOpImpl(Function function, Object args,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
index 105638a..6597b68 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
-
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionException;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTargetException;
-import com.gemstone.gemfire.internal.cache.execute.MemberMappedArgument;
-import com.gemstone.gemfire.internal.cache.execute.ServerFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.cache.client.internal;
+
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.execute.InternalFunctionException;
+import org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException;
+import org.apache.geode.internal.cache.execute.MemberMappedArgument;
+import org.apache.geode.internal.cache.execute.ServerFunctionExecutor;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -399,7 +399,7 @@ public class ExecuteFunctionOp {
     private static final int MSG_PARTS = 6;
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public ExecuteFunctionOpImpl(Function function, Object args,
         MemberMappedArgument memberMappedArg, byte hasResult,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
index 732d9c1..cd08e6d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionNoAckOp.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
-import com.gemstone.gemfire.internal.cache.execute.MemberMappedArgument;
-import com.gemstone.gemfire.internal.cache.execute.ServerRegionFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
+import org.apache.geode.internal.cache.execute.MemberMappedArgument;
+import org.apache.geode.internal.cache.execute.ServerRegionFunctionExecutor;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Does a Execution of function on server region
@@ -105,7 +105,7 @@ public class ExecuteRegionFunctionNoAckOp {
     private final boolean executeOnBucketSet ;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public ExecuteRegionFunctionNoAckOpImpl(String region, Function function,
         ServerRegionFunctionExecutor serverRegionExecutor, byte hasResult) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionOp.java
index 0260f77..ae08ac0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionOp.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.HashSet;
@@ -23,30 +23,30 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionException;
-import com.gemstone.gemfire.internal.cache.execute.MemberMappedArgument;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTargetException;
-import com.gemstone.gemfire.internal.cache.execute.ServerRegionFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.execute.InternalFunctionException;
+import org.apache.geode.internal.cache.execute.MemberMappedArgument;
+import org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException;
+import org.apache.geode.internal.cache.execute.ServerRegionFunctionExecutor;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a Execution of function on server region.<br>



[26/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRecoverGrantorProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRecoverGrantorProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRecoverGrantorProcessor.java
index 5f283c6..7a9d658 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRecoverGrantorProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRecoverGrantorProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,21 +26,21 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Handles messaging to all members of a lock service for the purposes of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockReleaseProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockReleaseProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockReleaseProcessor.java
index d94a82c..c649756 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockReleaseProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockReleaseProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
   
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,21 +23,21 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Synchronously releases a lock.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRemoteToken.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRemoteToken.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRemoteToken.java
index 783a65e..5f890db 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRemoteToken.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRemoteToken.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRequestProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRequestProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRequestProcessor.java
index 7d34840..50681ce 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRequestProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockRequestProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,27 +23,27 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ProcessorKeeper21;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ProcessorKeeper21;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Provides handling of remote and local lock requests.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockService.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockService.java
index 7314b61..7d4b8c6 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockService.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockService.java
@@ -15,28 +15,28 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.distributed.*;
-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.ResourceEvent;
-import com.gemstone.gemfire.distributed.internal.deadlock.UnsafeThreadLocal;
-import com.gemstone.gemfire.distributed.internal.locks.DLockQueryProcessor.DLockQueryReplyMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.StopWatch;
-import com.gemstone.gemfire.internal.util.concurrent.FutureResult;
+package org.apache.geode.distributed.internal.locks;
+
+import org.apache.geode.*;
+import org.apache.geode.distributed.*;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.distributed.internal.deadlock.UnsafeThreadLocal;
+import org.apache.geode.distributed.internal.locks.DLockQueryProcessor.DLockQueryReplyMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.StopWatch;
+import org.apache.geode.internal.util.concurrent.FutureResult;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -2069,7 +2069,7 @@ public class DLockService extends DistributedLockService {
    * Caller must be synchronized on {@link 
    * DLockService#services}.
    * 
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#create(String, DistributedSystem)
+   * @see org.apache.geode.distributed.DistributedLockService#create(String, DistributedSystem)
    */
   static DLockService basicCreate(String serviceName, 
                                   InternalDistributedSystem ds,
@@ -2338,7 +2338,7 @@ public class DLockService extends DistributedLockService {
    * Returns copy of the tokens map. Synchronizes on token map.
    * <p>
    * Called by {@link 
-   * com.gemstone.gemfire.internal.admin.remote.FetchDistLockInfoResponse}.
+   * org.apache.geode.internal.admin.remote.FetchDistLockInfoResponse}.
    * 
    * @return copy of the tokens map
    */
@@ -2406,7 +2406,7 @@ public class DLockService extends DistributedLockService {
   }
 
   /**
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#destroy(String)
+   * @see org.apache.geode.distributed.DistributedLockService#destroy(String)
    */
   public static void destroyServiceNamed(String serviceName)
   throws IllegalArgumentException {
@@ -2930,7 +2930,7 @@ public class DLockService extends DistributedLockService {
   // -------------------------------------------------------------------------
   
   /**
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#getServiceNamed(String)
+   * @see org.apache.geode.distributed.DistributedLockService#getServiceNamed(String)
    */
   public static DistributedLockService getServiceNamed(String serviceName) {
     DLockService svc = null;
@@ -2967,7 +2967,7 @@ public class DLockService extends DistributedLockService {
    *
    * @throws IllegalStateException if system is in process of disconnecting
    *
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#create(String, DistributedSystem)
+   * @see org.apache.geode.distributed.DistributedLockService#create(String, DistributedSystem)
    */
   public static DistributedLockService create(String serviceName, 
                                               InternalDistributedSystem ds,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockStats.java
index ac83d14..7e1ab96 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockStats.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * This class maintains statistics in GemFire about the distributed lock 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockToken.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockToken.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockToken.java
index 301b047..6eb94ed 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockToken.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockToken.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.util.WeakHashMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.LeaseExpiredException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.distributed.LeaseExpiredException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A DistributedLockService contains a collection of DLockToken
@@ -79,7 +79,7 @@ public class DLockToken {
    
   /** 
    * Tracks expired leases so that the leasing thread can report a
-   * {@link com.gemstone.gemfire.distributed.LeaseExpiredException}.
+   * {@link org.apache.geode.distributed.LeaseExpiredException}.
    * Keys are threads that have had their lease expire on this lock,
    * but may not yet have noticed.  Would use weak set if available.
    * Entry is removed upon throwing LeaseExpiredException. Protected by
@@ -131,7 +131,7 @@ public class DLockToken {
    * no current lease. Caller must synchronize on this lock token. 
    * <p>
    * Public because {@link 
-   * com.gemstone.gemfire.internal.admin.remote.RemoteDLockInfo} is a caller.
+   * org.apache.geode.internal.admin.remote.RemoteDLockInfo} is a caller.
    * 
    * @return the lock re-entry recursion of the current lease or -1 if none
    */
@@ -144,7 +144,7 @@ public class DLockToken {
    * if there is no lease. Caller must synchronize on this lock token. 
    * <p>
    * Public because {@link 
-   * com.gemstone.gemfire.internal.admin.remote.RemoteDLockInfo} is a caller.
+   * org.apache.geode.internal.admin.remote.RemoteDLockInfo} is a caller.
    * 
    * @return the name of the actual local thread leasing this lock or null
    */
@@ -165,7 +165,7 @@ public class DLockToken {
    * if there is no lease. Caller must synchronize on this lock token.
    * <p>
    * Public because {@link 
-   * com.gemstone.gemfire.internal.admin.remote.RemoteDLockInfo} is a caller.
+   * org.apache.geode.internal.admin.remote.RemoteDLockInfo} is a caller.
    * 
    * @return the absolute time at which the current lease will expire or -1
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DeposeGrantorProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DeposeGrantorProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DeposeGrantorProcessor.java
index 08d459b..e9ae9fe 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DeposeGrantorProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DeposeGrantorProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,17 +23,17 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A processor for telling the old grantor that he is deposed by a new grantor. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedLockStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedLockStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedLockStats.java
index 9a8b8a6..8c1abca 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedLockStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedLockStats.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.distributed.internal.*;
 
 /**
  * Defines the interface used to access and modify distributed lock statistics.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedMemberLock.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedMemberLock.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedMemberLock.java
index 9655bda..596685c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedMemberLock.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DistributedMemberLock.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.Serializable;
 
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService.ThreadRequestState;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.internal.locks.DLockService.ThreadRequestState;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.locks.Condition;
@@ -31,7 +31,7 @@ import java.util.concurrent.locks.Lock;
 /**
  * Distributed lock which is owned by a member rather than a single thread.
  * Any thread within the {@link 
- * com.gemstone.gemfire.distributed.DistributedMember} may unlock a held
+ * org.apache.geode.distributed.DistributedMember} may unlock a held
  * <code>DistributedMemberLock</code>.
  *
  * While this member holds the lock, another member will not be able to
@@ -39,7 +39,7 @@ import java.util.concurrent.locks.Lock;
  * lock.
  * 
  * Operations delegate to {@link 
- * com.gemstone.gemfire.distributed.DistributedLockService} and may throw
+ * org.apache.geode.distributed.DistributedLockService} and may throw
  * LockNotHeldException or LockServiceDestroyedException.
  * 
  * @since GemFire 5.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DummyDLockStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DummyDLockStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DummyDLockStats.java
index 0c8e2e6..a0dfdb0 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DummyDLockStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DummyDLockStats.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.distributed.internal.*;
 
 /**
  * Empty implementation of <code>DistributedLockStats</code> used when there is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderInitProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderInitProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderInitProcessor.java
index 5d2833d..cf4d354 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderInitProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderInitProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,21 +28,21 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A processor for initializing the ElderState. This may involve sending

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderState.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderState.java
index 8b1d631..dafa7ea 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderState.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/ElderState.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.util.HashMap;
 import java.util.Iterator;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Keeps track of all the information kept by the elder.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorInfo.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorInfo.java
index 664921b..3609778 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorInfo.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Used to provide information on a grantor request made to the elder.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorRequestProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorRequestProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorRequestProcessor.java
index 5a6b867..2870c0b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorRequestProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/GrantorRequestProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,25 +26,25 @@ import java.util.concurrent.locks.*;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCondition;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantLock;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.StoppableCondition;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantLock;
 
 /**
  * A processor for sending a message to the elder asking it for the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorDestroyedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorDestroyedException.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorDestroyedException.java
index aede763..0fc5c80 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorDestroyedException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorDestroyedException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 /**
  * A <code>LockGrantorDestroyedException</code> is thrown when attempting

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorId.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorId.java
index 448c382..e394985 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorId.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/LockGrantorId.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Identifies specific lock grantor member and version.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/NonGrantorDestroyedProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/NonGrantorDestroyedProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/NonGrantorDestroyedProcessor.java
index d371ad2..105dfc1 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/NonGrantorDestroyedProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/NonGrantorDestroyedProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,23 +23,23 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-//import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-//import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+//import org.apache.geode.distributed.internal.DistributionAdvisor;
+//import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A processor for telling the grantor that a lock service participant has

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/RemoteThread.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/RemoteThread.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/RemoteThread.java
index 7e55203..5ed1d10 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/RemoteThread.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/RemoteThread.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Uniquely identifies a remote thread by DistributedMember and threadId

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/package.html b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/package.html
index 65949ac..5e6911d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/package.html
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/package.html
@@ -22,7 +22,7 @@ limitations under the License.
 The GemFire Distributed Lock Service (also know as "dlock" or "DLS")
 provides synchronization locks that span multiple members of a
 distributed system.  The user creates a {@link
-com.gemstone.gemfire.distributed.DistributedLockService} with a given
+org.apache.geode.distributed.DistributedLockService} with a given
 name and uses to acquire distributed locks.  Lock coordination and
 management is provided by an instance of the distributed lock service
 referred to as the "grantor".  Each lock service instance knows which
@@ -39,7 +39,7 @@ out which member hosts the lock service's "grantor".  The "elder"
 member is defined as the oldest member in the JavaGroups view of the
 distributed system.  The member that is creating the lock service
 sends the elder a {@link
-com.gemstone.gemfire.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage} to
+org.apache.geode.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage} to
 find out who the current grantor is.  If no member is currently the
 grantor of the distributed lock service, then the member that sent the
 request is chosen to be the grantor.
@@ -68,21 +68,21 @@ need it.
 Once a distributed lock service has been created and initialized, it
 can be used to obtain a distributed lock.  The member that wishes to
 obtain a lock sends a {@link
-com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage} to the
+org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage} to the
 lock service's grantor.  The grantor will process the lock request and
 will grant the lock once it becomes available.
 
 <P>
 
 However, it is possible that the member that the requester sent the
-{@link com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}
+{@link org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}
 to is no longer the grantor.  That is, there can be a race between the
 requester requesting the lock and the grantor lock service being
 destroyed.  In this scenario, the member replies to the requester with
 a <code>LockResponseMessage</code> that
 indicates that the member is not the grantor.  The requester will then
 send a {@link
-com.gemstone.gemfire.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage} to
+org.apache.geode.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage} to
 the elder to determine who the new grantor is.
 
 <P>
@@ -93,14 +93,14 @@ is the grantor.  That is, the elder might inform a requester of the
 identity of a grantor before the grantor member has fully initialized
 (or has even heard back from the elder that it is the grantor).  This
 race condition is resolved by blocking the processing of a {@link
-com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage} until
+org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage} until
 the member knows whether or not it is the grantor.
 
 <H2>Lock Service Destruction</H2>
 
 When an application has finished using a lock service, the service can
 be {@linkplain
-com.gemstone.gemfire.distributed.DistributedLockService#destroy
+org.apache.geode.distributed.DistributedLockService#destroy
 destroyed}.  When a non-grantor distributed lock service is destroyed,
 the member destroying the lock service sends a
 <code>DestroyServiceMessage</code> to the grantor.  Upon receiving the
@@ -197,7 +197,7 @@ to optimize this scenario by ensuring that the member that requests
 the locks is also the grantor.  The grantor member can grant itself
 locks faster that it can grant locks to other members because there is
 no messaging involved.  The {@link
-com.gemstone.gemfire.distributed.DistributedLockService#becomeLockGrantor}
+org.apache.geode.distributed.DistributedLockService#becomeLockGrantor}
 transfers grantorship to a distributed lock service instance.
 
 <P>
@@ -208,10 +208,10 @@ to the elder.  The elder notes that the young turk is now the grantor
 and instructs the current grantor that it is no longer the grantor and
 that it should expect to hear from the young turk shortly.  Once the
 current grantor has received this message, it will reply to {@link
-com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s with a
+org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s with a
 response that indicates that it is not the grantor.  Note that the
 young turk will not reply to {@link
-com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s until
+org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s until
 grantorship has been fully transferred.
 
 <P>
@@ -239,7 +239,7 @@ transfer from another young turk, the older turk gives up its dreams
 of becoming grantor and "passes through" the lock information to the
 younger turk when that information arrives.  After the older turk
 gives up, it replies to any pending {@link
-com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s with
+org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage}s with
 "not grantor".
 
 <P>
@@ -276,7 +276,7 @@ member is the eldest.  (Note that we assume that all members of the
 distributed system have identical JavaGroups views and will, thus,
 choose the same member as the elder.)  The member then sends a
 grantor-related message (such as a {@link
-com.gemstone.gemfire.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage}) to
+org.apache.geode.distributed.internal.locks.GrantorRequestProcessor.GrantorRequestMessage}) to
 the member it believes to the elder.  If a member receives a
 grantor-related message, it assumes it is the elder and begins to act
 as such.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/DistributedMembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/DistributedMembershipListener.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/DistributedMembershipListener.java
index d970b6b..73ed239 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/DistributedMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/DistributedMembershipListener.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.direct.DirectChannelListener;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.direct.DirectChannelListener;
 
 public interface DistributedMembershipListener extends DirectChannelListener {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalDistributedMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalDistributedMember.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalDistributedMember.java
index ead2c89..b80bc8c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalDistributedMember.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalDistributedMember.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.UnsupportedVersionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.ProfileId;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.distributed.internal.membership;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.UnsupportedVersionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.DistributionAdvisor.ProfileId;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.net.Inet4Address;
@@ -97,7 +97,7 @@ public class InternalDistributedMember
 
   /**
    * The name of this member's distributed system connection.
-   * @see com.gemstone.gemfire.distributed.DistributedSystem#getName
+   * @see org.apache.geode.distributed.DistributedSystem#getName
    */
   private String name = null;
 
@@ -328,7 +328,7 @@ public class InternalDistributedMember
   public InternalDistributedMember(String host, int p, String n, String u,
       int vmKind, String[] groups, DurableClientAttributes attr) throws UnknownHostException {
     MemberAttributes mattr = new MemberAttributes(p,
-        com.gemstone.gemfire.internal.OSProcess.getId(),
+        org.apache.geode.internal.OSProcess.getId(),
         vmKind, -1,
         n,
         groups, attr);
@@ -431,8 +431,8 @@ public class InternalDistributedMember
    * [GemStone] Returns the kind of VM that hosts the distribution manager with
    * this address.
    *
-   * @see com.gemstone.gemfire.distributed.internal.DistributionManager#getDMType()
-   * @see com.gemstone.gemfire.distributed.internal.DistributionManager#NORMAL_DM_TYPE
+   * @see org.apache.geode.distributed.internal.DistributionManager#getDMType()
+   * @see org.apache.geode.distributed.internal.DistributionManager#NORMAL_DM_TYPE
    */
   public int getVmKind()
   {
@@ -537,7 +537,7 @@ public class InternalDistributedMember
   /**
    * Returns the name of this member's distributed system connection or null
    * if no name was specified.
-   * @see com.gemstone.gemfire.distributed.DistributedSystem#getName
+   * @see org.apache.geode.distributed.DistributedSystem#getName
    */
   public String getName() {
     String result = this.name;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalRole.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalRole.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalRole.java
index 62ba859..f52e4f7 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalRole.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/InternalRole.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
@@ -35,12 +35,12 @@ import org.apache.commons.lang.StringUtils;
  * Any serializable object which has instances of InternalRole should flag
  * those variables as transient. Objects that implement DataSerializable
  * should convert the roles to String names. For an example, please see
- * {@link com.gemstone.gemfire.cache.MembershipAttributes}.</p>
+ * {@link org.apache.geode.cache.MembershipAttributes}.</p>
  *
  * <p>Serializable classes which hold references to Roles should customize
  * serialization to transfer string names for Roles. See {@link 
- * com.gemstone.gemfire.cache.RegionAccessException RegionAccessException}
- * and {@link com.gemstone.gemfire.cache.RegionDistributionException 
+ * org.apache.geode.cache.RegionAccessException RegionAccessException}
+ * and {@link org.apache.geode.cache.RegionDistributionException 
  * RegionDistributionException} for examples on how to do this.</p>
  *
  * @deprecated this feature is scheduled to be removed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberAttributes.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberAttributes.java
index 7f2e92a..cd2dad0 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberAttributes.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 import java.util.ArrayList;
 import java.util.List;
 import java.util.StringTokenizer;
 
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.DurableClientAttributes;
 
 /**
  * The attributes of a distributed member.  This is largely deprecated as

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberFactory.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberFactory.java
index f10731b..e9ed567 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberFactory.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.LocatorStats;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMemberFactory;
-import com.gemstone.gemfire.distributed.internal.membership.gms.NetLocator;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.LocatorStats;
+import org.apache.geode.distributed.internal.membership.gms.GMSMemberFactory;
+import org.apache.geode.distributed.internal.membership.gms.NetLocator;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -30,7 +30,7 @@ import java.net.InetAddress;
  * Create a new Member based on the given inputs.
  * TODO: need to implement a real factory implementation based on gemfire.properties
  * 
- * @see com.gemstone.gemfire.distributed.internal.membership.NetMember
+ * @see org.apache.geode.distributed.internal.membership.NetMember
  */
 public class MemberFactory {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberServices.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberServices.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberServices.java
index 235373f..2a04dac 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberServices.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MemberServices.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.LocatorStats;
-import com.gemstone.gemfire.distributed.internal.membership.gms.NetLocator;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.LocatorStats;
+import org.apache.geode.distributed.internal.membership.gms.NetLocator;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -28,7 +28,7 @@ import java.net.InetAddress;
 /**
  * This is the SPI for a provider of membership services.
  * 
- * @see com.gemstone.gemfire.distributed.internal.membership.NetMember
+ * @see org.apache.geode.distributed.internal.membership.NetMember
  */
 public interface MemberServices {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipManager.java
index 95eff07..9df3c33 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 import java.io.NotSerializableException;
 import java.util.Map;
@@ -22,11 +22,11 @@ import java.util.Set;
 import java.util.concurrent.TimeoutException;
 import java.util.concurrent.locks.ReadWriteLock;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 /**
  * A MembershipManager is responsible for reporting a MemberView, as well as

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipTestHook.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipTestHook.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipTestHook.java
index a6209ee..c23cb2e 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipTestHook.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/MembershipTestHook.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 /**
  * Test hook for hydra test development

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetMember.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetMember.java
index 1bab0d1..f20f637 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetMember.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetMember.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.net.InetAddress;
 
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.internal.Version;
 
 /**
  * This is the SPI for the basic element of membership provided in the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetView.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetView.java
index 7d9a84c..0bb0b8a 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetView.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/NetView.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,12 +25,12 @@ import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 /**
  * The NetView class represents a membership view. Note that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/QuorumChecker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/QuorumChecker.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/QuorumChecker.java
index 41106a3..abe8696 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/QuorumChecker.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/QuorumChecker.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.membership;
+package org.apache.geode.distributed.internal.membership;
 
 /**
  * A QuorumChecker is created after a forced-disconnect in order

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMember.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMember.java
index 969933b..e31d445 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMember.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMember.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.MemberAttributes;
-import com.gemstone.gemfire.distributed.internal.membership.NetMember;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.distributed.internal.membership.gms;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.MemberAttributes;
+import org.apache.geode.distributed.internal.membership.NetMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import org.jgroups.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMemberFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMemberFactory.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMemberFactory.java
index 3c968f6..85e0570 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMemberFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSMemberFactory.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionException;
-import com.gemstone.gemfire.distributed.internal.LocatorStats;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.GMSLocator;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.tcp.ConnectionException;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
-import com.gemstone.gemfire.security.AuthenticationRequiredException;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionException;
+import org.apache.geode.distributed.internal.LocatorStats;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.gms.locator.GMSLocator;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.tcp.ConnectionException;
+import org.apache.geode.security.AuthenticationFailedException;
+import org.apache.geode.security.AuthenticationRequiredException;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -39,7 +39,7 @@ import java.net.UnknownHostException;
 /**
  * Create a new Member based on the given inputs.
  * 
- * @see com.gemstone.gemfire.distributed.internal.membership.NetMember
+ * @see org.apache.geode.distributed.internal.membership.NetMember
  */
 public class GMSMemberFactory implements MemberServices {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSUtil.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSUtil.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSUtil.java
index d489431..123c61d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/GMSUtil.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
 import java.net.InetAddress;
 import java.net.InetSocketAddress;
@@ -25,8 +25,8 @@ import java.util.StringTokenizer;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.internal.SocketCreator;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.internal.SocketCreator;
 
 public class GMSUtil {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/NetLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/NetLocator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/NetLocator.java
index 7e82523..5fecd9a 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/NetLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/NetLocator.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpHandler;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.distributed.internal.tcpserver.TcpHandler;
 
 public interface NetLocator extends TcpHandler {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/ServiceConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/ServiceConfig.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/ServiceConfig.java
index 6df0c7b..1f3f9bf 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/ServiceConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/ServiceConfig.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
 
 import java.net.InetAddress;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/Services.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/Services.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/Services.java
index 9ff1636..5764d73 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/Services.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/Services.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.ForcedDisconnectException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.distributed.internal.membership.DistributedMembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.auth.GMSAuthenticator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.fd.GMSHealthMonitor;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.*;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.GMSLocator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.membership.GMSJoinLeave;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messenger.JGroupsMessenger;
-import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.ForcedDisconnectException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.distributed.internal.membership.DistributedMembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.auth.GMSAuthenticator;
+import org.apache.geode.distributed.internal.membership.gms.fd.GMSHealthMonitor;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.*;
+import org.apache.geode.distributed.internal.membership.gms.locator.GMSLocator;
+import org.apache.geode.distributed.internal.membership.gms.membership.GMSJoinLeave;
+import org.apache.geode.distributed.internal.membership.gms.messenger.JGroupsMessenger;
+import org.apache.geode.distributed.internal.membership.gms.mgr.GMSMembershipManager;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.security.AuthenticationFailedException;
 import org.apache.logging.log4j.Logger;
 
 import java.util.Timer;
@@ -137,7 +137,7 @@ public class Services {
     this.manager.init(this);
     this.joinLeave.init(this);
     this.healthMon.init(this);
-    InternalLocator l = (InternalLocator)com.gemstone.gemfire.distributed.Locator.getLocator();
+    InternalLocator l = (InternalLocator)org.apache.geode.distributed.Locator.getLocator();
     if (l != null && l.getLocatorHandler() != null) {
       if (l.getLocatorHandler().setMembershipManager((MembershipManager)this.manager)) {
         this.locator = (Locator)l.getLocatorHandler();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/SuspectMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/SuspectMember.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/SuspectMember.java
index 37180b6..8d5547a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/SuspectMember.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/SuspectMember.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms;
+package org.apache.geode.distributed.internal.membership.gms;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /** represents a suspicion raised about a member */
 public class SuspectMember


[14/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegion.java
index 4cbcbd0..a6951de 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegion.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.*;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.*;
 
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
@@ -54,164 +54,164 @@ import java.util.regex.Pattern;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.DeltaSerializationException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.internal.SystemMemberCacheEventProcessor;
-import com.gemstone.gemfire.cache.AttributesMutator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-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.CacheRuntimeException;
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.CustomExpiry;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.DiskStoreFactory;
-import com.gemstone.gemfire.cache.DiskWriteAttributes;
-import com.gemstone.gemfire.cache.DiskWriteAttributesFactory;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.FailedSynchronizationException;
-import com.gemstone.gemfire.cache.InterestRegistrationEvent;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.LoaderHelper;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.PartitionedRegionStorageException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.cache.RegionMembershipListener;
-import com.gemstone.gemfire.cache.RegionReinitializedException;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.cache.client.SubscriptionNotEnabledException;
-import com.gemstone.gemfire.cache.client.internal.Connection;
-import com.gemstone.gemfire.cache.client.internal.Endpoint;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.MultiIndexCreationException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.index.IndexCreationData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ResourceEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ClassLoadUtil;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.ClientHealthMonitoringRegion;
-import com.gemstone.gemfire.internal.cache.AbstractRegionMap.ARMLockTestHook;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIIStatus;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException.PutAllPartialResult;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.cache.control.ResourceListener;
-import com.gemstone.gemfire.internal.cache.execute.DistributedRegionFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.execute.DistributedRegionFunctionResultSender;
-import com.gemstone.gemfire.internal.cache.execute.LocalResultCollector;
-import com.gemstone.gemfire.internal.cache.execute.RegionFunctionContextImpl;
-import com.gemstone.gemfire.internal.cache.execute.ServerToClientFunctionResultSender;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.partitioned.RedundancyAlreadyMetException;
-import com.gemstone.gemfire.internal.cache.persistence.DiskExceptionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.query.IndexMap;
-import com.gemstone.gemfire.internal.cache.persistence.query.mock.IndexMapImpl;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientHealthMonitor;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientTombstoneMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionHolder;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-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.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventCallbackArgument;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.ReferenceCountHelper;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
-import com.gemstone.gemfire.internal.util.concurrent.FutureResult;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReadWriteLock;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.CopyHelper;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.DeltaSerializationException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.LogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.internal.SystemMemberCacheEventProcessor;
+import org.apache.geode.cache.AttributesMutator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.CustomExpiry;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.DiskStoreFactory;
+import org.apache.geode.cache.DiskWriteAttributes;
+import org.apache.geode.cache.DiskWriteAttributesFactory;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.FailedSynchronizationException;
+import org.apache.geode.cache.InterestRegistrationEvent;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.LoaderHelper;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.PartitionedRegionStorageException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.RegionMembershipListener;
+import org.apache.geode.cache.RegionReinitializedException;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.cache.client.SubscriptionNotEnabledException;
+import org.apache.geode.cache.client.internal.Connection;
+import org.apache.geode.cache.client.internal.Endpoint;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.client.internal.ServerRegionProxy;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.IndexMaintenanceException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.MultiIndexCreationException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.index.IndexCreationData;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ClassLoadUtil;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.ClientHealthMonitoringRegion;
+import org.apache.geode.internal.cache.AbstractRegionMap.ARMLockTestHook;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.InitialImageOperation.GIIStatus;
+import org.apache.geode.internal.cache.PutAllPartialResultException.PutAllPartialResult;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryEvent;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.cache.control.ResourceListener;
+import org.apache.geode.internal.cache.execute.DistributedRegionFunctionExecutor;
+import org.apache.geode.internal.cache.execute.DistributedRegionFunctionResultSender;
+import org.apache.geode.internal.cache.execute.LocalResultCollector;
+import org.apache.geode.internal.cache.execute.RegionFunctionContextImpl;
+import org.apache.geode.internal.cache.execute.ServerToClientFunctionResultSender;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.partitioned.RedundancyAlreadyMetException;
+import org.apache.geode.internal.cache.persistence.DiskExceptionHandler;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.query.IndexMap;
+import org.apache.geode.internal.cache.persistence.query.mock.IndexMapImpl;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientHealthMonitor;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientTombstoneMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessage;
+import org.apache.geode.internal.cache.tier.sockets.HandShake;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.cache.versions.RegionVersionHolder;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventCallbackArgument;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.offheap.ReferenceCountHelper;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.sequencelog.EntryLogger;
+import org.apache.geode.internal.util.concurrent.FutureResult;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
+import org.apache.geode.internal.util.concurrent.StoppableReadWriteLock;
 
 /**
  * Implementation of a local scoped-region. Note that this class has a different
@@ -359,7 +359,7 @@ public class LocalRegion extends AbstractRegion
    * Prevents access to this region until it is done initializing, except for
    * some special initializing operations such as replying to create region
    * messages In JDK 1.5 we will use java.util.concurrent.CountDownLatch instead
-   * of com.gemstone.gemfire.internal.util.CountDownLatch.
+   * of org.apache.geode.internal.util.CountDownLatch.
    */
   protected final StoppableCountDownLatch initializationLatchBeforeGetInitialImage;
 
@@ -397,7 +397,7 @@ public class LocalRegion extends AbstractRegion
   /*
    * Asif: This boolean needs to be made true if the test needs to receive a
    * synchronous callback just after clear on map is done. Its visibility is
-   * default so that only tests present in com.gemstone.gemfire.internal.cache
+   * default so that only tests present in org.apache.geode.internal.cache
    * will be able to see it
    */
   public static boolean ISSUE_CALLBACKS_TO_CACHE_OBSERVER = false;
@@ -486,7 +486,7 @@ public class LocalRegion extends AbstractRegion
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.CancelCriterion#generateCancelledException(java.lang.Throwable)
+     * @see org.apache.geode.CancelCriterion#generateCancelledException(java.lang.Throwable)
      */
     @Override
     public RuntimeException generateCancelledException(Throwable e) {
@@ -1717,7 +1717,7 @@ public class LocalRegion extends AbstractRegion
     // 3. Check if it has server region proxy. 
     //    We do not have a handle to event in PutOpImpl to check if we have 
     //    delta bytes calculated already. So no need to calculate it here.
-    // 4. Check if value is instanceof com.gemstone.gemfire.Delta
+    // 4. Check if value is instanceof org.apache.geode.Delta
     // 5. Check if Region in PR with redundantCopies > 0. Set extractDelta.
     // 6. Check if Region has peers. Set extractDelta.
     // 7. Check if it has any delta proxies attached to it. Set extractDelta.
@@ -1729,7 +1729,7 @@ public class LocalRegion extends AbstractRegion
       boolean extractDelta = false;
       // How costly is this if check?
       if (this.getSystem().getConfig().getDeltaPropagation()
-          && value instanceof com.gemstone.gemfire.Delta) {
+          && value instanceof org.apache.geode.Delta) {
         if (!this.hasServerProxy()) {
           if ((this instanceof PartitionedRegion)) {
             if (((PartitionedRegion)this).getRedundantCopies() > 0) {
@@ -1760,11 +1760,11 @@ public class LocalRegion extends AbstractRegion
           // This is a client region
           extractDelta = true;
         }
-        if (extractDelta && ((com.gemstone.gemfire.Delta)value).hasDelta()) {
+        if (extractDelta && ((org.apache.geode.Delta)value).hasDelta()) {
           HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
           long start = DistributionStats.getStatTime();
           try {
-            ((com.gemstone.gemfire.Delta)value).toDelta(hdos);
+            ((org.apache.geode.Delta)value).toDelta(hdos);
           } catch (RuntimeException re) {
             throw re;
           } catch (Exception e) {
@@ -11357,7 +11357,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.control.ResourceListener#onEvent(java.lang.Object)
+   * @see org.apache.geode.cache.control.ResourceListener#onEvent(java.lang.Object)
    */
   public final void onEvent(MemoryEvent event) {
     if (logger.isDebugEnabled()) {
@@ -12624,7 +12624,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.DiskRecoveryStore#getVersionForMember(com.gemstone.gemfire.internal.cache.versions.VersionSource)
+   * @see org.apache.geode.internal.cache.DiskRecoveryStore#getVersionForMember(org.apache.geode.internal.cache.versions.VersionSource)
    */
   @Override
   public long getVersionForMember(VersionSource member) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegionDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegionDataView.java b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegionDataView.java
index ae4789d..1f4faa4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegionDataView.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalRegionDataView.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
 
 /**
  * 
@@ -33,7 +33,7 @@ import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationE
  */
 public class LocalRegionDataView implements InternalDataView {
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getDeserializedValue(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getDeserializedValue(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getDeserializedValue(KeyInfo keyInfo,
                                      LocalRegion localRegion,
@@ -48,7 +48,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#txDestroyExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#txDestroyExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean)
    */
   public void destroyExistingEntry(EntryEventImpl event, boolean cacheWrite, Object expectedOldValue) {
     LocalRegion lr = event.getLocalRegion();
@@ -59,7 +59,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#txInvalidateExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#txInvalidateExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(EntryEventImpl event,
       boolean invokeCallbacks, boolean forceNewEntry) {
@@ -83,14 +83,14 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#entryCount(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#entryCount(org.apache.geode.internal.cache.LocalRegion)
    */
   public int entryCount(LocalRegion localRegion) {
     return localRegion.getRegionSize();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getValueInVM(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getValueInVM(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getValueInVM(KeyInfo keyInfo, LocalRegion localRegion,
       boolean rememberRead) {
@@ -98,21 +98,21 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#containsKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#containsKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsKey(KeyInfo keyInfo, LocalRegion localRegion) {
     return localRegion.nonTXContainsKey(keyInfo);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#containsValueForKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#containsValueForKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsValueForKey(KeyInfo keyInfo, LocalRegion localRegion) {
     return localRegion.nonTXContainsValueForKey(keyInfo);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntry(KeyInfo keyInfo, LocalRegion localRegion, boolean allowTombstones) {
     return localRegion.nonTXGetEntry(keyInfo, false, allowTombstones);
@@ -124,7 +124,7 @@ public class LocalRegionDataView implements InternalDataView {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntry(EntryEventImpl event, boolean ifNew, boolean ifOld,
       Object expectedOldValue, boolean requireOldValue, long lastModified,
@@ -133,14 +133,14 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#isStatsDeferred()
+   * @see org.apache.geode.internal.cache.InternalDataView#isStatsDeferred()
    */
   public boolean isDeferredStats() {
     return false;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#findObject(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#findObject(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
    */
   public Object findObject(KeyInfo keyInfo,
                            LocalRegion r,
@@ -156,7 +156,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryForIterator(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryForIterator(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, boolean)
    */
   public Region.Entry<?, ?> getEntryForIterator(final KeyInfo keyInfo,
       final LocalRegion currRgn, boolean rememberReads, boolean allowTombstones) {
@@ -169,7 +169,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getKeyForIterator(final KeyInfo keyInfo,
       final LocalRegion currRgn, boolean rememberReads, boolean allowTombstones) {
@@ -184,7 +184,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getAdditionalKeysForIterator(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getAdditionalKeysForIterator(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getAdditionalKeysForIterator(LocalRegion currRgn) {
     return null;
@@ -192,7 +192,7 @@ public class LocalRegionDataView implements InternalDataView {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getSerializedValue(com.gemstone.gemfire.internal.cache.BucketRegion, java.lang.Object, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#getSerializedValue(org.apache.geode.internal.cache.BucketRegion, java.lang.Object, java.lang.Object)
    */
   public Object getSerializedValue(LocalRegion localRegion,
                                    KeyInfo key,
@@ -216,7 +216,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#invalidateOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#invalidateOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateOnRemote(EntryEventImpl event, boolean invokeCallbacks,
       boolean forceNewEntry) throws DataLocationException {
@@ -224,14 +224,14 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getBucketKeys(int)
+   * @see org.apache.geode.internal.cache.InternalDataView#getBucketKeys(int)
    */
   public Set getBucketKeys(LocalRegion localRegion, int bucketId, boolean allowTombstones) {
     throw new IllegalStateException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntryOnRemote(KeyInfo key, LocalRegion localRegion, boolean allowTombstones) throws DataLocationException {
     throw new IllegalStateException();
@@ -254,7 +254,7 @@ public class LocalRegionDataView implements InternalDataView {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getRegionKeysForIteration(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getRegionKeysForIteration(org.apache.geode.internal.cache.LocalRegion)
    */
   public Collection<?> getRegionKeysForIteration(LocalRegion currRegion) {
     //return currRegion.getRegionKeysForIteration();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/MemberFunctionStreamingMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/MemberFunctionStreamingMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/MemberFunctionStreamingMessage.java
index a28d0f6..b86e707 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/MemberFunctionStreamingMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/MemberFunctionStreamingMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,33 +24,33 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.execute.FunctionContextImpl;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.execute.MemberFunctionResultSender;
-import com.gemstone.gemfire.internal.cache.execute.MultiRegionFunctionContextImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.execute.FunctionContextImpl;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.execute.MemberFunctionResultSender;
+import org.apache.geode.internal.cache.execute.MultiRegionFunctionContextImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 
@@ -378,13 +378,13 @@ public class MemberFunctionStreamingMessage extends DistributionMessage implemen
     return (ds == null || ds.isDisconnecting());
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TransactionMessage#canStartRemoteTransaction()
+   * @see org.apache.geode.internal.cache.TransactionMessage#canStartRemoteTransaction()
    */
   public boolean canStartRemoteTransaction() {
     return true;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TransactionMessage#getTXUniqId()
+   * @see org.apache.geode.internal.cache.TransactionMessage#getTXUniqId()
    */
   public int getTXUniqId() {
     return this.txUniqId;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/MinimumSystemRequirements.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/MinimumSystemRequirements.java b/geode-core/src/main/java/org/apache/geode/internal/cache/MinimumSystemRequirements.java
index 775b4ba..c470ab3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/MinimumSystemRequirements.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/MinimumSystemRequirements.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Checks that minimum system requirements are met.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/NetSearchExpirationCalculator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/NetSearchExpirationCalculator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/NetSearchExpirationCalculator.java
index c1909b8..6810a4b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/NetSearchExpirationCalculator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/NetSearchExpirationCalculator.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  * EntryExpiryTask already implements the algorithm for figuring out

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/Node.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/Node.java b/geode-core/src/main/java/org/apache/geode/internal/cache/Node.java
index d94540c..9441e57 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/Node.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/Node.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 import java.io.*;
 
-import com.gemstone.gemfire.internal.ExternalizableDSFID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.ExternalizableDSFID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * Stores information about a PartitionedRegion singleton instance running

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntry.java
index 4c1fa7f..ff1ba72 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntry.java
@@ -17,30 +17,30 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-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.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
   private long lastModified;
@@ -306,14 +306,14 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#getValueOnDiskOrBuffer(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.RegionEntry#getValueOnDiskOrBuffer(org.apache.geode.internal.cache.LocalRegion)
    */
   public Object getValueOnDiskOrBuffer(LocalRegion r)
       throws EntryNotFoundException {
     throw new UnsupportedOperationException(LocalizedStrings.PartitionedRegion_NOT_APPROPRIATE_FOR_PARTITIONEDREGIONNONLOCALREGIONENTRY.toLocalizedString());
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#getSerializedValueOnDisk(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.RegionEntry#getSerializedValueOnDisk(org.apache.geode.internal.cache.LocalRegion)
    */
   public Object getSerializedValueOnDisk(LocalRegion localRegion) {
     throw new UnsupportedOperationException(LocalizedStrings.PartitionedRegion_NOT_APPROPRIATE_FOR_PARTITIONEDREGIONNONLOCALREGIONENTRY.toLocalizedString());
@@ -339,7 +339,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
   // VersionStamp methods ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#generateVersionTag(com.gemstone.gemfire.distributed.DistributedMember, boolean)
+   * @see org.apache.geode.internal.cache.RegionEntry#generateVersionTag(org.apache.geode.distributed.DistributedMember, boolean)
    */
   public VersionTag generateVersionTag(VersionSource member,
       boolean withDelta, LocalRegion region, EntryEventImpl event) {
@@ -348,7 +348,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#concurrencyCheck(com.gemstone.gemfire.internal.cache.LocalRegion, com.gemstone.gemfire.internal.cache.versions.VersionTag, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember)
+   * @see org.apache.geode.internal.cache.RegionEntry#concurrencyCheck(org.apache.geode.internal.cache.LocalRegion, org.apache.geode.internal.cache.versions.VersionTag, org.apache.geode.distributed.internal.membership.InternalDistributedMember, org.apache.geode.distributed.internal.membership.InternalDistributedMember)
    */
   public void processVersionTag(LocalRegion r, VersionTag tag,
       InternalDistributedMember thisVM, InternalDistributedMember sender) {
@@ -357,7 +357,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#getEntryVersion()
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#getEntryVersion()
    */
   public int getEntryVersion() {
     if (this.versionTag != null) {
@@ -374,7 +374,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#getMemberID()
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#getMemberID()
    */
   public VersionSource getMemberID() {
     if (this.versionTag != null) {
@@ -392,7 +392,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#setEntryVersion(int)
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#setEntryVersion(int)
    */
   public void setVersions(VersionTag tag) {
     throw new UnsupportedOperationException();
@@ -400,7 +400,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#setMemberID(com.gemstone.gemfire.distributed.DistributedMember)
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#setMemberID(org.apache.geode.distributed.DistributedMember)
    */
   public void setMemberID(VersionSource memberID) {
     throw new UnsupportedOperationException();
@@ -408,7 +408,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#setPreviousMemberID(com.gemstone.gemfire.distributed.DistributedMember)
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#setPreviousMemberID(org.apache.geode.distributed.DistributedMember)
    */
   public void setPreviousMemberID(DistributedMember previousMemberID) {
     throw new UnsupportedOperationException();
@@ -416,7 +416,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#asVersionTag()
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#asVersionTag()
    */
   public VersionTag asVersionTag() {
     return this.versionTag;
@@ -424,7 +424,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#processVersionTag(com.gemstone.gemfire.internal.cache.LocalRegion, com.gemstone.gemfire.internal.cache.versions.VersionTag, boolean, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember)
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#processVersionTag(org.apache.geode.internal.cache.LocalRegion, org.apache.geode.internal.cache.versions.VersionTag, boolean, org.apache.geode.distributed.internal.membership.InternalDistributedMember, org.apache.geode.distributed.internal.membership.InternalDistributedMember)
    */
   public void processVersionTag(LocalRegion r, VersionTag tag,
       boolean isTombstoneFromGII, boolean hasDelta,
@@ -433,7 +433,7 @@ public class NonLocalRegionEntry implements RegionEntry, VersionStamp {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.versions.VersionStamp#getVersionTimeStamp()
+   * @see org.apache.geode.internal.cache.versions.VersionStamp#getVersionTimeStamp()
    */
   @Override
   public long getVersionTimeStamp() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntryWithStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntryWithStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntryWithStats.java
index 91ae3f0..70d61a5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntryWithStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/NonLocalRegionEntryWithStats.java
@@ -17,15 +17,15 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
 
 public class NonLocalRegionEntryWithStats extends NonLocalRegionEntry {
   private long hitCount;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OffHeapRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OffHeapRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OffHeapRegionEntry.java
index acd1e63..20d4ae3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OffHeapRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OffHeapRegionEntry.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.offheap.Releasable;
+import org.apache.geode.internal.offheap.Releasable;
 
 /**
  * Any RegionEntry that is stored off heap must

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OfflineCompactionDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OfflineCompactionDiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OfflineCompactionDiskRegion.java
index 516edbe..e71fa7f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OfflineCompactionDiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OfflineCompactionDiskRegion.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.cache.persistence.DiskExceptionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.cache.persistence.DiskExceptionHandler;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
 
 /**
  * A disk region that is created when doing offline compaction.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OpType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OpType.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OpType.java
index f4a49d6..ca51312 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OpType.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OpType.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Enumerated type for an event operation.
  * 
  * 
  * 
- * @see com.gemstone.gemfire.cache.Operation
+ * @see org.apache.geode.cache.Operation
  * 
  * @since GemFire 6.6
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/Oplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/Oplog.java b/geode-core/src/main/java/org/apache/geode/internal/cache/Oplog.java
index 59b0893..004fc4a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/Oplog.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/Oplog.java
@@ -14,41 +14,41 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.OplogCancelledException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.Flushable;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.OplogCompactor;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.OplogEntryIdSet;
-import com.gemstone.gemfire.internal.cache.DistributedRegion.DiskPosition;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.cache.persistence.*;
-import com.gemstone.gemfire.internal.cache.versions.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.ReferenceCountHelper;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
-import com.gemstone.gemfire.internal.shared.NativeCalls;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.internal.util.TransformUtils;
-import com.gemstone.gemfire.pdx.internal.PdxWriterImpl;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SerializationException;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.OplogCancelledException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.DiskEntry.Helper.Flushable;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.DiskStoreImpl.OplogCompactor;
+import org.apache.geode.internal.cache.DiskStoreImpl.OplogEntryIdSet;
+import org.apache.geode.internal.cache.DistributedRegion.DiskPosition;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.persistence.*;
+import org.apache.geode.internal.cache.versions.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.offheap.ReferenceCountHelper;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.sequencelog.EntryLogger;
+import org.apache.geode.internal.shared.NativeCalls;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.internal.util.TransformUtils;
+import org.apache.geode.pdx.internal.PdxWriterImpl;
 import it.unimi.dsi.fastutil.ints.Int2ObjectMap;
 import it.unimi.dsi.fastutil.ints.Int2ObjectOpenHashMap;
 import it.unimi.dsi.fastutil.longs.Long2ObjectMap;
@@ -1006,9 +1006,9 @@ public final class Oplog implements CompactableOplog, Flushable {
         // at sun.nio.ch.IOUtil.writeFromNativeBuffer(IOUtil.java:104)
         // at sun.nio.ch.IOUtil.write(IOUtil.java:60)
         // at sun.nio.ch.FileChannelImpl.write(FileChannelImpl.java:206)
-        // at com.gemstone.gemfire.internal.cache.Oplog.flush(Oplog.java:3377)
+        // at org.apache.geode.internal.cache.Oplog.flush(Oplog.java:3377)
         // at
-        // com.gemstone.gemfire.internal.cache.Oplog.flushAll(Oplog.java:3419)
+        // org.apache.geode.internal.cache.Oplog.flushAll(Oplog.java:3419)
         /*
          * { String os = System.getProperty("os.name"); if (os != null) { if
          * (os.indexOf("Windows") != -1) { olf.raf.close(); olf.RAFClosed =
@@ -7100,7 +7100,7 @@ public final class Oplog implements CompactableOplog, Flushable {
     /*
      * (non-Javadoc)
      * 
-     * @see com.gemstone.gemfire.internal.cache.DiskEntry#getVersionStamp()
+     * @see org.apache.geode.internal.cache.DiskEntry#getVersionStamp()
      */
     @Override
     public VersionStamp getVersionStamp() {
@@ -7203,7 +7203,7 @@ public final class Oplog implements CompactableOplog, Flushable {
     }
 
     @Override
-    public boolean fillInValue(LocalRegion r, com.gemstone.gemfire.internal.cache.InitialImageOperation.Entry entry,
+    public boolean fillInValue(LocalRegion r, org.apache.geode.internal.cache.InitialImageOperation.Entry entry,
         ByteArrayDataInput in, DM mgr) {
       // TODO Auto-generated method stub
       return false;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OplogSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OplogSet.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OplogSet.java
index d7f2423..bb7076d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OplogSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OplogSet.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
 
 public interface OplogSet {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OrderedTombstoneMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OrderedTombstoneMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OrderedTombstoneMap.java
index 09d5309..df87ee9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OrderedTombstoneMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OrderedTombstoneMap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Comparator;
 import java.util.HashMap;
@@ -22,9 +22,9 @@ import java.util.Map;
 import java.util.Map.Entry;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * This class is used for sorting tombstones by region version number. Because

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplog.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplog.java
index bb792a8..846325c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplog.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplog.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.File;
 import java.io.IOException;
@@ -31,20 +31,20 @@ import java.util.concurrent.locks.ReentrantLock;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.distributed.OplogCancelledException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.Flushable;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.OplogCompactor;
-import com.gemstone.gemfire.internal.cache.Oplog.OplogDiskEntry;
-import com.gemstone.gemfire.internal.cache.persistence.BytesAndBits;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.distributed.OplogCancelledException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.DiskEntry.Helper.Flushable;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskStoreImpl.OplogCompactor;
+import org.apache.geode.internal.cache.Oplog.OplogDiskEntry;
+import org.apache.geode.internal.cache.persistence.BytesAndBits;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * An oplog used for overflow-only regions.
@@ -901,7 +901,7 @@ class OverflowOplog implements CompactableOplog, Flushable {
           myRAF.readFully(valueBytes);
 //           if (EntryBits.isSerialized(userBits)) {
 //             try {
-//               com.gemstone.gemfire.internal.util.BlobHelper.deserializeBlob(valueBytes);
+//               org.apache.geode.internal.util.BlobHelper.deserializeBlob(valueBytes);
 //             } catch (IOException ex) {
 //               throw new RuntimeException("DEBUG readPos=" + readPosition + " len=" + valueLength +  "doneApp=" + doneAppending + " userBits=" + userBits, ex);
 //             } catch (ClassNotFoundException ex2) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplogSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplogSet.java b/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplogSet.java
index 62da419..b98d5fc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplogSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/OverflowOplogSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.nio.channels.FileChannel;
@@ -29,11 +29,11 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class OverflowOplogSet implements OplogSet {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PRContainsValueFunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PRContainsValueFunction.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PRContainsValueFunction.java
index 5768c99..9f956b0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PRContainsValueFunction.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PRContainsValueFunction.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Iterator;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.FunctionAdapter;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.internal.InternalEntity;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.FunctionAdapter;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.internal.InternalEntity;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PRHARedundancyProvider.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PRHARedundancyProvider.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PRHARedundancyProvider.java
index 9e01c1c..cfedb67 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PRHARedundancyProvider.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PRHARedundancyProvider.java
@@ -15,41 +15,41 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.PartitionedRegionStorageException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.persistence.PartitionOfflineException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.LonerDistributionManager;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.OneTaskOnlyExecutor;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.RetryTimeKeeper;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore.CreateBucketResult;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.partitioned.*;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchPartitionDetailsMessage.FetchPartitionDetailsResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage.NodeResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.CompositeDirector;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.FPRDirector;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.RebalanceDirector;
-import com.gemstone.gemfire.internal.cache.persistence.MembershipFlushRequest;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentStateListener;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.PartitionedRegionStorageException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.persistence.PartitionOfflineException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.LonerDistributionManager;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.OneTaskOnlyExecutor;
+import org.apache.geode.internal.cache.PartitionedRegion.RetryTimeKeeper;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore.CreateBucketResult;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.partitioned.*;
+import org.apache.geode.internal.cache.partitioned.FetchPartitionDetailsMessage.FetchPartitionDetailsResponse;
+import org.apache.geode.internal.cache.partitioned.ManageBucketMessage.NodeResponse;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
+import org.apache.geode.internal.cache.partitioned.rebalance.CompositeDirector;
+import org.apache.geode.internal.cache.partitioned.rebalance.FPRDirector;
+import org.apache.geode.internal.cache.partitioned.rebalance.RebalanceDirector;
+import org.apache.geode.internal.cache.persistence.MembershipFlushRequest;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentStateListener;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PRQueryProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PRQueryProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PRQueryProcessor.java
index 967a39d..02a5ce8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PRQueryProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PRQueryProcessor.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator.PRQueryResultCollector;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.PartitionedRegionQueryEvaluator.PRQueryResultCollector;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PRSystemPropertyGetter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PRSystemPropertyGetter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PRSystemPropertyGetter.java
index 868a3e9..f141257 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PRSystemPropertyGetter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PRSystemPropertyGetter.java
@@ -18,7 +18,7 @@
  * Created on Dec 22, 2005
  *
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionAttributesImpl.java
index dd90a62..243c7a1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionAttributesImpl.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -31,22 +31,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.PartitionResolver;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.OffHeapStorage;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.PartitionResolver;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.OffHeapStorage;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Internal implementation of PartitionAttributes. New attributes existing   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfig.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfig.java
index 926c47a..44f6888 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfig.java
@@ -18,25 +18,25 @@
 /*
  * Created on Dec 1, 2005
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
 import java.io.*;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.ExternalizableDSFID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.internal.cache.PartitionAttributesImpl;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.util.Versionable;
-import com.gemstone.gemfire.internal.util.VersionedArrayList;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.ExternalizableDSFID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.internal.cache.PartitionAttributesImpl;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.util.Versionable;
+import org.apache.geode.internal.util.VersionedArrayList;
 
 /**
  * Maintains configuration information for a PartitionedRegion. Instances are



[83/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
GEODE-37 renamed pulse package


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

Branch: refs/heads/feature/GEODE-37_1
Commit: eff7f21631a34484fd0e3ffcf3de69020f5d9d3f
Parents: 939fcf2
Author: Hitesh Khamesra <hk...@pivotal.io>
Authored: Fri Sep 9 14:33:43 2016 -0700
Committer: Hitesh Khamesra <hk...@pivotal.io>
Committed: Fri Sep 9 14:33:43 2016 -0700

----------------------------------------------------------------------
 .../src/test/java/com/company/app/Customer.java |   36 +
 .../src/test/java/com/company/app/DBLoader.java |   63 +
 .../com/company/app/OrdersCacheListener.java    |   51 +
 .../java/com/company/data/DatabaseLoader.java   |   42 +
 .../java/com/company/data/MyDeclarable.java     |   32 +
 .../src/test/java/com/company/data/MySizer.java |   39 +
 .../com/company/data/MyTransactionListener.java |   38 +
 .../src/test/java/com/examples/LinkNode.java    |   77 +
 .../src/test/java/com/examples/SuperClass.java  |   92 +
 .../src/test/java/com/examples/TestObject.java  |   54 +
 .../src/test/java/com/examples/ds/Address.java  |   23 +
 .../src/test/java/com/examples/ds/Company.java  |   43 +
 .../java/com/examples/ds/CompanySerializer.java |   67 +
 .../src/test/java/com/examples/ds/Employee.java |   53 +
 .../com/examples/ds/PutDataSerializables.java   |   54 +
 .../src/test/java/com/examples/ds/User.java     |   58 +
 .../com/examples/snapshot/MyDataSerializer.java |   63 +
 .../java/com/examples/snapshot/MyObject.java    |   68 +
 .../snapshot/MyObjectDataSerializable.java      |   45 +
 .../java/com/examples/snapshot/MyObjectPdx.java |   33 +
 .../snapshot/MyObjectPdxSerializable.java       |   42 +
 .../com/examples/snapshot/MyPdxSerializer.java  |   64 +
 .../com/main/MyDistributedSystemListener.java   |  114 +
 .../com/main/WANBootStrapping_Site1_Add.java    |  122 +
 .../com/main/WANBootStrapping_Site1_Remove.java |   78 +
 .../com/main/WANBootStrapping_Site2_Add.java    |  108 +
 .../com/main/WANBootStrapping_Site2_Remove.java |   74 +
 .../geode/internal/ClassPathLoaderTest.java     |    2 +-
 .../src/test/java/org/company/app/Customer.java |   36 -
 .../src/test/java/org/company/app/DBLoader.java |   63 -
 .../org/company/app/OrdersCacheListener.java    |   51 -
 .../java/org/company/data/DatabaseLoader.java   |   42 -
 .../java/org/company/data/MyDeclarable.java     |   32 -
 .../src/test/java/org/company/data/MySizer.java |   39 -
 .../org/company/data/MyTransactionListener.java |   38 -
 .../src/test/java/org/examples/LinkNode.java    |   77 -
 .../src/test/java/org/examples/SuperClass.java  |   92 -
 .../src/test/java/org/examples/TestObject.java  |   54 -
 .../src/test/java/org/examples/ds/Address.java  |   23 -
 .../src/test/java/org/examples/ds/Company.java  |   43 -
 .../java/org/examples/ds/CompanySerializer.java |   67 -
 .../src/test/java/org/examples/ds/Employee.java |   53 -
 .../org/examples/ds/PutDataSerializables.java   |   54 -
 .../src/test/java/org/examples/ds/User.java     |   58 -
 .../org/examples/snapshot/MyDataSerializer.java |   63 -
 .../java/org/examples/snapshot/MyObject.java    |   68 -
 .../snapshot/MyObjectDataSerializable.java      |   45 -
 .../java/org/examples/snapshot/MyObjectPdx.java |   33 -
 .../snapshot/MyObjectPdxSerializable.java       |   42 -
 .../org/examples/snapshot/MyPdxSerializer.java  |   64 -
 .../org/main/MyDistributedSystemListener.java   |  114 -
 .../org/main/WANBootStrapping_Site1_Add.java    |  122 -
 .../org/main/WANBootStrapping_Site1_Remove.java |   78 -
 .../org/main/WANBootStrapping_Site2_Add.java    |  108 -
 .../org/main/WANBootStrapping_Site2_Remove.java |   74 -
 .../tools/pulse/internal/PulseAppListener.java  |  742 ----
 .../controllers/ExceptionHandlingAdvice.java    |   51 -
 .../internal/controllers/PulseController.java   |  524 ---
 .../tools/pulse/internal/data/Cluster.java      | 3815 ------------------
 .../tools/pulse/internal/data/DataBrowser.java  |  248 --
 .../pulse/internal/data/IClusterUpdater.java    |   35 -
 .../pulse/internal/data/JMXDataUpdater.java     | 2392 -----------
 .../pulse/internal/data/JmxManagerFinder.java   |  169 -
 .../tools/pulse/internal/data/PulseConfig.java  |  139 -
 .../pulse/internal/data/PulseConstants.java     |  434 --
 .../tools/pulse/internal/data/PulseVersion.java |  103 -
 .../tools/pulse/internal/data/Repository.java   |  246 --
 .../gemfire/tools/pulse/internal/json/CDL.java  |  274 --
 .../tools/pulse/internal/json/Cookie.java       |  164 -
 .../tools/pulse/internal/json/CookieList.java   |   85 -
 .../gemfire/tools/pulse/internal/json/HTTP.java |  158 -
 .../tools/pulse/internal/json/HTTPTokener.java  |   72 -
 .../tools/pulse/internal/json/JSONArray.java    |  901 -----
 .../pulse/internal/json/JSONException.java      |   47 -
 .../tools/pulse/internal/json/JSONML.java       |  462 ---
 .../tools/pulse/internal/json/JSONObject.java   | 1585 --------
 .../tools/pulse/internal/json/JSONString.java   |   37 -
 .../tools/pulse/internal/json/JSONStringer.java |   73 -
 .../tools/pulse/internal/json/JSONTokener.java  |  441 --
 .../tools/pulse/internal/json/JSONWriter.java   |  322 --
 .../gemfire/tools/pulse/internal/json/README    |   68 -
 .../gemfire/tools/pulse/internal/json/XML.java  |  503 ---
 .../tools/pulse/internal/json/XMLTokener.java   |  360 --
 .../tools/pulse/internal/log/LogWriter.java     |  265 --
 .../pulse/internal/log/MessageFormatter.java    |  102 -
 .../pulse/internal/log/PulseLogWriter.java      |  299 --
 .../tools/pulse/internal/log/PulseLogger.java   |  142 -
 .../security/GemFireAuthentication.java         |   91 -
 .../security/GemFireAuthenticationProvider.java |   80 -
 .../pulse/internal/security/LogoutHandler.java  |   55 -
 .../internal/service/ClusterDetailsService.java |  104 -
 .../service/ClusterDiskThroughputService.java   |   71 -
 .../service/ClusterGCPausesService.java         |   69 -
 .../service/ClusterKeyStatisticsService.java    |   69 -
 .../internal/service/ClusterMemberService.java  |  132 -
 .../service/ClusterMembersRGraphService.java    |  359 --
 .../service/ClusterMemoryUsageService.java      |   65 -
 .../internal/service/ClusterRegionService.java  |  211 -
 .../internal/service/ClusterRegionsService.java |  206 -
 .../service/ClusterSelectedRegionService.java   |  237 --
 .../ClusterSelectedRegionsMemberService.java    |  143 -
 .../internal/service/ClusterWANInfoService.java |   75 -
 .../service/MemberAsynchEventQueuesService.java |   99 -
 .../internal/service/MemberClientsService.java  |  101 -
 .../internal/service/MemberDetailsService.java  |  122 -
 .../service/MemberDiskThroughputService.java    |   76 -
 .../internal/service/MemberGCPausesService.java |   73 -
 .../service/MemberGatewayHubService.java        |  149 -
 .../service/MemberHeapUsageService.java         |   73 -
 .../service/MemberKeyStatisticsService.java     |   76 -
 .../internal/service/MemberRegionsService.java  |  127 -
 .../internal/service/MembersListService.java    |   75 -
 .../pulse/internal/service/PulseService.java    |   40 -
 .../internal/service/PulseServiceFactory.java   |   55 -
 .../internal/service/PulseVersionService.java   |   65 -
 .../service/QueryStatisticsService.java         |  115 -
 .../internal/service/SystemAlertsService.java   |  127 -
 .../pulse/internal/util/ConnectionUtil.java     |   46 -
 .../pulse/internal/util/IPAddressUtil.java      |   65 -
 .../tools/pulse/internal/util/StringUtils.java  |   85 -
 .../tools/pulse/internal/util/TimeUtils.java    |  120 -
 .../tools/pulse/internal/PulseAppListener.java  |  742 ++++
 .../controllers/ExceptionHandlingAdvice.java    |   51 +
 .../internal/controllers/PulseController.java   |  524 +++
 .../tools/pulse/internal/data/Cluster.java      | 3815 ++++++++++++++++++
 .../tools/pulse/internal/data/DataBrowser.java  |  248 ++
 .../pulse/internal/data/IClusterUpdater.java    |   35 +
 .../pulse/internal/data/JMXDataUpdater.java     | 2392 +++++++++++
 .../pulse/internal/data/JmxManagerFinder.java   |  169 +
 .../tools/pulse/internal/data/PulseConfig.java  |  139 +
 .../pulse/internal/data/PulseConstants.java     |  434 ++
 .../tools/pulse/internal/data/PulseVersion.java |  103 +
 .../tools/pulse/internal/data/Repository.java   |  246 ++
 .../geode/tools/pulse/internal/json/CDL.java    |  274 ++
 .../geode/tools/pulse/internal/json/Cookie.java |  164 +
 .../tools/pulse/internal/json/CookieList.java   |   85 +
 .../geode/tools/pulse/internal/json/HTTP.java   |  158 +
 .../tools/pulse/internal/json/HTTPTokener.java  |   72 +
 .../tools/pulse/internal/json/JSONArray.java    |  901 +++++
 .../pulse/internal/json/JSONException.java      |   47 +
 .../geode/tools/pulse/internal/json/JSONML.java |  462 +++
 .../tools/pulse/internal/json/JSONObject.java   | 1585 ++++++++
 .../tools/pulse/internal/json/JSONString.java   |   37 +
 .../tools/pulse/internal/json/JSONStringer.java |   73 +
 .../tools/pulse/internal/json/JSONTokener.java  |  441 ++
 .../tools/pulse/internal/json/JSONWriter.java   |  322 ++
 .../geode/tools/pulse/internal/json/README      |   68 +
 .../geode/tools/pulse/internal/json/XML.java    |  503 +++
 .../tools/pulse/internal/json/XMLTokener.java   |  360 ++
 .../tools/pulse/internal/log/LogWriter.java     |  265 ++
 .../pulse/internal/log/MessageFormatter.java    |  102 +
 .../pulse/internal/log/PulseLogWriter.java      |  299 ++
 .../tools/pulse/internal/log/PulseLogger.java   |  142 +
 .../security/GemFireAuthentication.java         |   91 +
 .../security/GemFireAuthenticationProvider.java |   80 +
 .../pulse/internal/security/LogoutHandler.java  |   55 +
 .../internal/service/ClusterDetailsService.java |  104 +
 .../service/ClusterDiskThroughputService.java   |   71 +
 .../service/ClusterGCPausesService.java         |   69 +
 .../service/ClusterKeyStatisticsService.java    |   69 +
 .../internal/service/ClusterMemberService.java  |  132 +
 .../service/ClusterMembersRGraphService.java    |  359 ++
 .../service/ClusterMemoryUsageService.java      |   65 +
 .../internal/service/ClusterRegionService.java  |  211 +
 .../internal/service/ClusterRegionsService.java |  206 +
 .../service/ClusterSelectedRegionService.java   |  237 ++
 .../ClusterSelectedRegionsMemberService.java    |  143 +
 .../internal/service/ClusterWANInfoService.java |   75 +
 .../service/MemberAsynchEventQueuesService.java |   99 +
 .../internal/service/MemberClientsService.java  |  101 +
 .../internal/service/MemberDetailsService.java  |  122 +
 .../service/MemberDiskThroughputService.java    |   76 +
 .../internal/service/MemberGCPausesService.java |   73 +
 .../service/MemberGatewayHubService.java        |  149 +
 .../service/MemberHeapUsageService.java         |   73 +
 .../service/MemberKeyStatisticsService.java     |   76 +
 .../internal/service/MemberRegionsService.java  |  127 +
 .../internal/service/MembersListService.java    |   75 +
 .../pulse/internal/service/PulseService.java    |   40 +
 .../internal/service/PulseServiceFactory.java   |   55 +
 .../internal/service/PulseVersionService.java   |   65 +
 .../service/QueryStatisticsService.java         |  115 +
 .../internal/service/SystemAlertsService.java   |  127 +
 .../pulse/internal/util/ConnectionUtil.java     |   46 +
 .../pulse/internal/util/IPAddressUtil.java      |   65 +
 .../tools/pulse/internal/util/StringUtils.java  |   85 +
 .../tools/pulse/internal/util/TimeUtils.java    |  120 +
 .../webapp/WEB-INF/mvc-dispatcher-servlet.xml   |    4 +-
 .../controllers/PulseControllerJUnitTest.java   |  816 ----
 .../pulse/testbed/GemFireDistributedSystem.java |  324 --
 .../tools/pulse/testbed/GemfireTopology.java    |   24 -
 .../tools/pulse/testbed/PropFileHelper.java     |  115 -
 .../pulse/testbed/PropMockDataUpdater.java      |  513 ---
 .../gemfire/tools/pulse/testbed/TestBed.java    |   84 -
 .../tools/pulse/testbed/driver/PulseUITest.java |  277 --
 .../tools/pulse/tests/AggregateStatement.java   |  217 -
 .../pulse/tests/AggregateStatementMBean.java    |  168 -
 .../pulse/tests/DataBrowserResultLoader.java    |   84 -
 .../pulse/tests/GemFireXDAggregateTable.java    |   46 -
 .../tests/GemFireXDAggregateTableMBean.java     |   28 -
 .../tools/pulse/tests/GemFireXDCluster.java     |   95 -
 .../pulse/tests/GemFireXDClusterMBean.java      |   32 -
 .../tools/pulse/tests/GemFireXDMember.java      |   80 -
 .../tools/pulse/tests/GemFireXDMemberMBean.java |   31 -
 .../gemfire/tools/pulse/tests/JMXBaseBean.java  |   67 -
 .../tools/pulse/tests/JMXProperties.java        |   47 -
 .../gemfire/tools/pulse/tests/Member.java       |  193 -
 .../gemfire/tools/pulse/tests/MemberMBean.java  |   86 -
 .../tools/pulse/tests/PulseAbstractTest.java    | 1047 -----
 .../tools/pulse/tests/PulseAuthTest.java        |   33 -
 .../tools/pulse/tests/PulseAutomatedTest.java   |  784 ----
 .../tools/pulse/tests/PulseBaseTest.java        |  693 ----
 .../tools/pulse/tests/PulseNoAuthTest.java      |   33 -
 .../tools/pulse/tests/PulseTestData.java        |  106 -
 .../tools/pulse/tests/PulseTestLocators.java    |  225 --
 .../gemfire/tools/pulse/tests/Region.java       |  187 -
 .../gemfire/tools/pulse/tests/RegionMBean.java  |   59 -
 .../tools/pulse/tests/RegionOnMember.java       |   95 -
 .../tools/pulse/tests/RegionOnMemberMBean.java  |   49 -
 .../gemfire/tools/pulse/tests/Server.java       |  247 --
 .../gemfire/tools/pulse/tests/ServerObject.java |  267 --
 .../tools/pulse/tests/ServerObjectMBean.java    |   79 -
 .../pulse/tests/junit/BaseServiceTest.java      |  254 --
 .../junit/ClusterSelectedRegionServiceTest.java |  340 --
 ...ClusterSelectedRegionsMemberServiceTest.java |  354 --
 .../junit/MemberGatewayHubServiceTest.java      |  412 --
 .../controllers/PulseControllerJUnitTest.java   |  816 ++++
 .../pulse/testbed/GemFireDistributedSystem.java |  324 ++
 .../tools/pulse/testbed/GemfireTopology.java    |   24 +
 .../tools/pulse/testbed/PropFileHelper.java     |  115 +
 .../pulse/testbed/PropMockDataUpdater.java      |  513 +++
 .../geode/tools/pulse/testbed/TestBed.java      |   84 +
 .../tools/pulse/testbed/driver/PulseUITest.java |  277 ++
 .../tools/pulse/tests/AggregateStatement.java   |  217 +
 .../pulse/tests/AggregateStatementMBean.java    |  168 +
 .../pulse/tests/DataBrowserResultLoader.java    |   84 +
 .../pulse/tests/GemFireXDAggregateTable.java    |   46 +
 .../tests/GemFireXDAggregateTableMBean.java     |   28 +
 .../tools/pulse/tests/GemFireXDCluster.java     |   95 +
 .../pulse/tests/GemFireXDClusterMBean.java      |   32 +
 .../tools/pulse/tests/GemFireXDMember.java      |   80 +
 .../tools/pulse/tests/GemFireXDMemberMBean.java |   31 +
 .../geode/tools/pulse/tests/JMXBaseBean.java    |   67 +
 .../geode/tools/pulse/tests/JMXProperties.java  |   47 +
 .../apache/geode/tools/pulse/tests/Member.java  |  193 +
 .../geode/tools/pulse/tests/MemberMBean.java    |   86 +
 .../tools/pulse/tests/PulseAbstractTest.java    | 1047 +++++
 .../geode/tools/pulse/tests/PulseAuthTest.java  |   33 +
 .../tools/pulse/tests/PulseAutomatedTest.java   |  784 ++++
 .../geode/tools/pulse/tests/PulseBaseTest.java  |  693 ++++
 .../tools/pulse/tests/PulseNoAuthTest.java      |   33 +
 .../geode/tools/pulse/tests/PulseTestData.java  |  106 +
 .../tools/pulse/tests/PulseTestLocators.java    |  225 ++
 .../apache/geode/tools/pulse/tests/Region.java  |  187 +
 .../geode/tools/pulse/tests/RegionMBean.java    |   59 +
 .../geode/tools/pulse/tests/RegionOnMember.java |   95 +
 .../tools/pulse/tests/RegionOnMemberMBean.java  |   49 +
 .../apache/geode/tools/pulse/tests/Server.java  |  247 ++
 .../geode/tools/pulse/tests/ServerObject.java   |  267 ++
 .../tools/pulse/tests/ServerObjectMBean.java    |   79 +
 .../pulse/tests/junit/BaseServiceTest.java      |  254 ++
 .../junit/ClusterSelectedRegionServiceTest.java |  340 ++
 ...ClusterSelectedRegionsMemberServiceTest.java |  354 ++
 .../junit/MemberGatewayHubServiceTest.java      |  412 ++
 264 files changed, 29141 insertions(+), 29141 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/app/Customer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/app/Customer.java b/geode-core/src/test/java/com/company/app/Customer.java
new file mode 100644
index 0000000..9dc87ca
--- /dev/null
+++ b/geode-core/src/test/java/com/company/app/Customer.java
@@ -0,0 +1,36 @@
+/*
+ * 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.company.app;
+
+import org.apache.geode.cache.Declarable;
+
+/**
+ * A class that is <code>Declarable</code>
+ *
+ * @since GemFire 3.2.1
+ */
+public class Customer implements Declarable {
+
+  public Customer() {
+
+  }
+
+  public void init(java.util.Properties props) {
+
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/app/DBLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/app/DBLoader.java b/geode-core/src/test/java/com/company/app/DBLoader.java
new file mode 100644
index 0000000..ab22805
--- /dev/null
+++ b/geode-core/src/test/java/com/company/app/DBLoader.java
@@ -0,0 +1,63 @@
+/*
+ * 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.company.app;
+
+import java.util.Properties;
+
+import org.apache.geode.cache.*;
+
+/**
+ * A <code>CacheLoader</code> that is <code>Declarable</code>
+ *
+ * @since GemFire 3.2.1
+ */
+public class DBLoader implements CacheLoader, Declarable {
+
+  private Properties props = new Properties();
+  
+  public Object load(LoaderHelper helper)
+    throws CacheLoaderException {
+
+    throw new UnsupportedOperationException("I do NOTHING");
+  }
+
+  public void init(java.util.Properties props) {
+    this.props = props; 
+  }
+
+  public void close() {
+  }
+
+  public boolean equals(Object obj)
+  {
+    if (this == obj) {
+      return true;
+    }
+
+    if (! (obj instanceof DBLoader)) {
+      return false;
+    }
+    
+    DBLoader other = (DBLoader) obj;
+    if (! this.props.equals(other.props)) {
+      return false;
+    }
+    
+    return true;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/app/OrdersCacheListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/app/OrdersCacheListener.java b/geode-core/src/test/java/com/company/app/OrdersCacheListener.java
new file mode 100755
index 0000000..ec91dcb
--- /dev/null
+++ b/geode-core/src/test/java/com/company/app/OrdersCacheListener.java
@@ -0,0 +1,51 @@
+/*
+ * 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.company.app;
+
+import org.apache.geode.cache.*;
+
+/**
+ * com.company.app.OrdersCacheListener. Cache listener impl for CacheXmlxxTest
+ *
+ * @since GemFire 5.0
+ */
+public class OrdersCacheListener implements CacheListener, Declarable {
+
+  public OrdersCacheListener() {}
+
+  public void afterCreate(EntryEvent event) {}
+
+  public void afterUpdate(EntryEvent event) {}
+
+  public void afterInvalidate(EntryEvent event) {}
+
+  public void afterDestroy(EntryEvent event) {}
+
+  public void afterRegionInvalidate(RegionEvent event) {}
+
+  public void afterRegionDestroy(RegionEvent event) {}
+
+  public void afterRegionClear(RegionEvent event) {}
+  
+  public void afterRegionCreate(RegionEvent event) {}
+  
+  public void afterRegionLive(RegionEvent event) {}
+  
+  public void close() {}
+  
+  public void init(java.util.Properties props) {}
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/data/DatabaseLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/data/DatabaseLoader.java b/geode-core/src/test/java/com/company/data/DatabaseLoader.java
new file mode 100644
index 0000000..84b1c70
--- /dev/null
+++ b/geode-core/src/test/java/com/company/data/DatabaseLoader.java
@@ -0,0 +1,42 @@
+/*
+ * 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.company.data;
+
+import org.apache.geode.cache.*;
+
+/**
+ * A <code>CacheLoader</code> that is <code>Declarable</code>
+ *
+ * @since GemFire 3.2.1
+ */
+public class DatabaseLoader implements CacheLoader, Declarable {
+
+  public Object load(LoaderHelper helper)
+    throws CacheLoaderException {
+
+    throw new UnsupportedOperationException("I do NOTHING");
+  }
+
+  public void init(java.util.Properties props) {
+
+  }
+
+  public void close() {
+
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/data/MyDeclarable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/data/MyDeclarable.java b/geode-core/src/test/java/com/company/data/MyDeclarable.java
new file mode 100644
index 0000000..0545c26
--- /dev/null
+++ b/geode-core/src/test/java/com/company/data/MyDeclarable.java
@@ -0,0 +1,32 @@
+/*
+ * 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.company.data;
+
+import org.apache.geode.cache.*;
+
+/**
+ * A <code>Declarable</code> object
+ *
+ * @since GemFire 3.2.1
+ */
+public class MyDeclarable implements Declarable {
+
+  public void init(java.util.Properties props) {
+
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/data/MySizer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/data/MySizer.java b/geode-core/src/test/java/com/company/data/MySizer.java
new file mode 100644
index 0000000..30e5e16
--- /dev/null
+++ b/geode-core/src/test/java/com/company/data/MySizer.java
@@ -0,0 +1,39 @@
+/*
+ * 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.company.data;
+/**
+ * A <code>Declarable</code> <code>ObjectSizer</code> for used for XML testing
+ *
+ * @since GemFire 5.0
+ */
+import java.util.Properties;
+
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.util.ObjectSizer;
+
+public class MySizer implements ObjectSizer, Declarable {
+
+  String name;
+
+  public int sizeof( Object o ) {
+    return ObjectSizer.DEFAULT.sizeof(o);
+  }
+
+  public void init(Properties props) {
+      this.name = props.getProperty("name", "defaultName");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/company/data/MyTransactionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/company/data/MyTransactionListener.java b/geode-core/src/test/java/com/company/data/MyTransactionListener.java
new file mode 100644
index 0000000..074e12d
--- /dev/null
+++ b/geode-core/src/test/java/com/company/data/MyTransactionListener.java
@@ -0,0 +1,38 @@
+/*
+ * 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.company.data;
+
+import org.apache.geode.cache.*;
+
+/**
+ * A <code>TransactionListener</code> that is <code>Declarable</code>
+ *
+ * @since GemFire 4.0
+ */
+public class MyTransactionListener implements TransactionListener, Declarable {
+
+  public void afterCommit(TransactionEvent event) {}
+    
+  public void afterFailedCommit(TransactionEvent event) {}
+
+  public void afterRollback(TransactionEvent event) {}
+
+  public void init(java.util.Properties props) {}
+
+  public void close() {}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/LinkNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/LinkNode.java b/geode-core/src/test/java/com/examples/LinkNode.java
new file mode 100644
index 0000000..97a0438
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/LinkNode.java
@@ -0,0 +1,77 @@
+/*
+ * 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.examples;
+
+/**
+ * A node in a linked list that is used to test that serializing
+ * non-<code>Serializable</code> objects handle back references
+ * correctly. 
+ *
+ *
+ * @since GemFire 3.5
+ */
+public class LinkNode {
+
+  /** The value of this LinkNode */
+  private int value;
+
+  /** An object value in this LinkNode */
+  public Object object;
+
+  /** The next node in the chain */
+  public LinkNode next;
+
+  /**
+   * Creates a new <code>LinkNode</code> with the given value
+   */
+  public LinkNode(int value) {
+    this.value = value;
+  }
+
+  /**
+   * Two <code>LinkNode</code>s are equal if they have the same
+   * <code>value</code> and their <code>next</code> node have the same
+   * value.
+   */
+  public boolean equals(Object o) {
+    if (!(o instanceof LinkNode)) {
+      return false;
+    }
+
+    LinkNode other = (LinkNode) o;
+    if (this.value != other.value) {
+      return false;
+
+    } else if (this.next == null) {
+      return other.next == null;
+
+    } else if (other.next == null) {
+      return this.next == null;
+
+    } else if (other.next.value != this.next.value) {
+      return false;
+
+    } else if (this.object != null) {
+      return this.object.equals(other.object);
+
+    } else {
+      return other.object == null;
+    }
+
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/SuperClass.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/SuperClass.java b/geode-core/src/test/java/com/examples/SuperClass.java
new file mode 100644
index 0000000..6c6076f
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/SuperClass.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.examples;
+
+import java.util.*;
+
+/**
+ * The super class of another class.  Neither is
+ * <code>Serializable</code>. 
+ *
+ *
+ * @since GemFire 3.5
+ */
+public class SuperClass {
+
+  protected int intValue;
+  protected HashMap map;
+
+  /**
+   * Creates a new <code>SuperClass</code>
+   */
+  protected SuperClass() {
+    this.intValue = 42;
+    this.map = new HashMap();
+    map.put("one", new Integer(1));
+    map.put("two", new Integer(2));
+    map.put("three", new Integer(3));
+    map.put("four", new Integer(4));
+  }
+
+
+  public static class SubClass extends SuperClass {
+
+    protected Map anotherMap;
+    protected long longValue;
+
+    /**
+     * Creates a new <code>SubClass</code>
+     */
+    public SubClass() {
+      super();
+
+      this.longValue = 28L;
+      this.anotherMap = new HashMap();
+      this.anotherMap.put("five", new Integer(5));
+      this.anotherMap.put("six", new Integer(6));
+      this.anotherMap.put("seven", new Integer(7));
+      this.anotherMap.put("eight", new Integer(8));
+    }
+
+    public boolean equals(Object o) {
+      if (!(o instanceof SubClass)) {
+        return false;
+      }
+
+      SubClass other = (SubClass) o;
+      if (this.intValue != other.intValue) {
+        return false;
+
+      } else if (!this.map.equals(other.map)) {
+        return false;
+
+      } else if (this.longValue != other.longValue) {
+        return false;
+
+      } else if (!this.anotherMap.equals(other.anotherMap)) {
+        return false;
+
+      } else {
+        return true;
+      }
+    }
+
+  }
+
+
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/TestObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/TestObject.java b/geode-core/src/test/java/com/examples/TestObject.java
new file mode 100644
index 0000000..9b871a7
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/TestObject.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.examples;
+
+/**
+ * A simple test object used by the 
+ * org.apache.geode.internal.enhancer.serializer.SerializingStreamPerfTest 
+ * (this test no longer exists?) 
+ * that must be in a non-<code>org.apache</code> package.
+ *
+ *
+ * @since GemFire 3.5
+ */
+public class TestObject {
+
+  private int intField;
+  private String stringField;
+  private Object objectField;
+
+  /**
+   * Creates a new <code>TestObject</code>
+   */
+  public TestObject() {
+    this.intField = 42;
+    this.stringField = "123456789012345678901234567890";
+    this.objectField = new Integer(67);
+  }
+
+  //////////////////////  Inner Classes  //////////////////////
+
+  /**
+   * A <code>Serializable</code> object that is serialized
+   */
+  public static class SerializableTestObject extends TestObject
+    implements java.io.Serializable {
+    
+  }
+  
+}
+

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/Address.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/Address.java b/geode-core/src/test/java/com/examples/ds/Address.java
new file mode 100644
index 0000000..5a82531
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/Address.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.examples.ds;
+
+import java.io.Serializable;
+
+public class Address implements Serializable {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/Company.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/Company.java b/geode-core/src/test/java/com/examples/ds/Company.java
new file mode 100644
index 0000000..6fc93ee
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/Company.java
@@ -0,0 +1,43 @@
+/*
+ * 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.examples.ds;
+
+public class Company {
+
+  /** The name of this company */
+  private String name;
+
+  /** The address of this company */
+  private Address address;
+
+  /**
+   * Creates a new company
+   */
+  public Company(String name, Address address) {
+    this.name = name;
+    this.address = address;
+  }
+
+  public String getName() {
+    return this.name;
+  }
+
+  public Address getAddress() {
+    return this.address;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/CompanySerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/CompanySerializer.java b/geode-core/src/test/java/com/examples/ds/CompanySerializer.java
new file mode 100644
index 0000000..9d69083
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/CompanySerializer.java
@@ -0,0 +1,67 @@
+/*
+ * 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.examples.ds;
+
+import org.apache.geode.DataSerializer;
+import java.io.*;
+
+public class CompanySerializer extends DataSerializer {
+
+  static {
+    DataSerializer.register(CompanySerializer.class);
+  }
+
+  /**
+   * May be invoked reflectively if instances of Company are
+   * distributed to other VMs.
+   */
+  public CompanySerializer() {
+
+  }
+
+  public int getId() {
+    return 42;
+  }
+  
+  public Class[] getSupportedClasses() {
+    return new Class[] { Company.class };
+  }
+
+  public boolean toData(Object o, DataOutput out)
+    throws IOException {
+    if (o instanceof Company) {
+      Company company = (Company) o;
+      out.writeUTF(company.getName());
+
+      // Let's assume that Address is java.io.Serializable
+      Address address = company.getAddress();
+      writeObject(address, out);
+      return true;
+
+    } else {
+      return false;
+    }
+  }
+
+  public Object fromData(DataInput in)
+    throws IOException, ClassNotFoundException {
+
+    String name = in.readUTF();
+    Address address = (Address) readObject(in);
+    return new Company(name, address);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/Employee.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/Employee.java b/geode-core/src/test/java/com/examples/ds/Employee.java
new file mode 100644
index 0000000..9165e34
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/Employee.java
@@ -0,0 +1,53 @@
+/*
+ * 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.examples.ds;
+
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import java.io.*;
+import java.util.Date;
+
+public class Employee implements DataSerializable {
+  private int id;
+  private String name;
+  private Date birthday;
+  private Company employer;
+
+  public Employee(int id, String name, Date birthday,
+                  Company employer){
+    this.id = id;
+    this.name = name;
+    this.birthday = birthday;
+    this.employer = employer;
+  }
+
+  public void toData(DataOutput out) throws IOException {
+    out.writeInt(this.id);
+    out.writeUTF(this.name);
+    DataSerializer.writeDate(this.birthday, out);
+    DataSerializer.writeObject(this.employer, out);
+  }
+
+  public void fromData(DataInput in) 
+    throws IOException, ClassNotFoundException {
+
+    this.id = in.readInt();
+    this.name = in.readUTF();
+    this.birthday = DataSerializer.readDate(in);
+    this.employer = (Company) DataSerializer.readObject(in);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/PutDataSerializables.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/PutDataSerializables.java b/geode-core/src/test/java/com/examples/ds/PutDataSerializables.java
new file mode 100644
index 0000000..162ce5a
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/PutDataSerializables.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.examples.ds;
+
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.DistributedSystem;
+import java.util.Date;
+import java.util.Properties;
+
+/**
+ * Places various objects that use {@link org.apache.geode.DataSerializer}s 
+ * and {@link org.apache.geode.Instantiator}s into a cache {@link Region}.  
+ * Among other things, this is used to test bug 31573.
+ *
+ * @since GemFire 3.5
+ */
+public class PutDataSerializables {
+
+  public static void main(String[] args) throws Throwable {
+    Properties props = new Properties();
+    DistributedSystem system = DistributedSystem.connect(props);
+    Cache cache = CacheFactory.create(system);
+    AttributesFactory factory = new AttributesFactory();
+    Region region =
+      cache.createRegion("DataSerializable",
+                           factory.create());
+    region.put("User", new User("Fred", 42));
+
+    new CompanySerializer();
+    Address address = new Address();
+    Company company = new Company("My Company", address);
+
+    region.put("Company", company);
+    region.put("Employee",
+               new Employee(43, "Bob", new Date(), company));
+
+    Thread.sleep(60 * 1000);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/ds/User.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/ds/User.java b/geode-core/src/test/java/com/examples/ds/User.java
new file mode 100644
index 0000000..4bf4531
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/ds/User.java
@@ -0,0 +1,58 @@
+/*
+ * 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.examples.ds;
+
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
+import java.io.*;
+
+public class User implements DataSerializable {
+  private String name;
+  private int userId;
+
+  static {
+    Instantiator.register(new Instantiator(User.class, (byte) 45) {
+        public DataSerializable newInstance() {
+          return new User();
+        }
+      });
+  }
+
+  public User(String name, int userId) {
+    this.name = name;
+    this.userId = userId;
+  }
+
+  /**
+   * Creates an "empty" User whose contents are filled in by
+   * invoking its toData() method
+   */
+  protected User() {
+
+  }
+
+  public void toData(DataOutput out) throws IOException {
+    out.writeUTF(this.name);
+    out.writeInt(this.userId);
+  }
+
+  public void fromData(DataInput in)
+    throws IOException, ClassNotFoundException {
+    this.name = in.readUTF();
+    this.userId = in.readInt();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyDataSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyDataSerializer.java b/geode-core/src/test/java/com/examples/snapshot/MyDataSerializer.java
new file mode 100644
index 0000000..0b8d9e6
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyDataSerializer.java
@@ -0,0 +1,63 @@
+/*
+ * 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.examples.snapshot;
+
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+
+import org.apache.geode.DataSerializer;
+
+public class MyDataSerializer extends DataSerializer {
+  @Override
+  public Class<?>[] getSupportedClasses() {
+    return new Class[] { MyObjectDataSerializable2.class};
+  }
+
+  @Override
+  public boolean toData(Object o, DataOutput out) throws IOException {
+    MyObject obj = (MyObject) o;
+    out.writeLong(obj.f1);
+    out.writeUTF(obj.f2);
+    
+    return true;
+  }
+
+  @Override
+  public Object fromData(DataInput in) throws IOException,
+      ClassNotFoundException {
+    MyObjectDataSerializable2 obj = new MyObjectDataSerializable2();
+    obj.f1 = in.readLong();
+    obj.f2 = in.readUTF();
+    
+    return obj;
+  }
+
+  @Override
+  public int getId() {
+    return 8892;
+  }
+  
+  public static class MyObjectDataSerializable2 extends MyObject {
+    public MyObjectDataSerializable2() {
+    }
+
+    public MyObjectDataSerializable2(long number, String s) {
+      super(number, s);
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyObject.java b/geode-core/src/test/java/com/examples/snapshot/MyObject.java
new file mode 100644
index 0000000..aaada9d
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyObject.java
@@ -0,0 +1,68 @@
+/*
+ * 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.examples.snapshot;
+
+import java.io.Serializable;
+
+import org.apache.geode.pdx.PdxInstance;
+
+/**
+ * Data class for testing snapshots, cannot be located in org.apache.*.
+ * 
+ */
+public class MyObject implements Serializable {
+  protected long f1;
+  protected String f2;
+  
+  public MyObject() {
+  }
+
+  public MyObject(long number, String s) {
+    f1 = number;
+    f2 = s;
+  }
+  
+  public long getF1() {
+    return f1;
+  }
+  
+  public String getF2() {
+    return f2;
+  }
+  
+  @Override
+  public boolean equals(Object o) {
+    if (o instanceof MyObject) {
+      MyObject obj = (MyObject) o;
+      return f1 == obj.f1 && f2.equals(obj.f2);
+
+    } else if (o instanceof PdxInstance) {
+      PdxInstance pdx = (PdxInstance) o;
+      return pdx.getField("f1").equals(f1) && pdx.getField("f2").equals(f2);
+    }
+    return false;
+  }
+  
+  @Override
+  public int hashCode() {
+    return (int) (17 * f1 ^ f2.hashCode());
+  }
+  
+  public String toString() {
+    return f1 + "-" + f2;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyObjectDataSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyObjectDataSerializable.java b/geode-core/src/test/java/com/examples/snapshot/MyObjectDataSerializable.java
new file mode 100644
index 0000000..1582744
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyObjectDataSerializable.java
@@ -0,0 +1,45 @@
+/*
+ * 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.examples.snapshot;
+
+import java.io.DataInput;
+import java.io.DataOutput;
+import java.io.IOException;
+
+import org.apache.geode.DataSerializable;
+
+public class MyObjectDataSerializable extends MyObject implements DataSerializable {
+  public MyObjectDataSerializable() {
+  }
+
+  public MyObjectDataSerializable(long number, String s) {
+    super(number, s);
+  }
+  
+  @Override
+  public void toData(DataOutput out) throws IOException {
+    out.writeLong(f1);
+    out.writeUTF(f2);
+  }
+
+  @Override
+  public void fromData(DataInput in) throws IOException,
+      ClassNotFoundException {
+    f1 = in.readLong();
+    f2 = in.readUTF();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyObjectPdx.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyObjectPdx.java b/geode-core/src/test/java/com/examples/snapshot/MyObjectPdx.java
new file mode 100644
index 0000000..396049d
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyObjectPdx.java
@@ -0,0 +1,33 @@
+/*
+ * 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.examples.snapshot;
+
+public class MyObjectPdx extends MyObject {
+  public enum MyEnumPdx {
+    const1, const2, const3, const4, const5;
+  }
+  
+  private MyEnumPdx enumVal;
+  
+  public MyObjectPdx() {
+  }
+
+  public MyObjectPdx(long number, String s, MyEnumPdx enumVal) {
+    super(number, s);
+    this.enumVal = enumVal;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyObjectPdxSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyObjectPdxSerializable.java b/geode-core/src/test/java/com/examples/snapshot/MyObjectPdxSerializable.java
new file mode 100644
index 0000000..3929db4
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyObjectPdxSerializable.java
@@ -0,0 +1,42 @@
+/*
+ * 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.examples.snapshot;
+
+import org.apache.geode.pdx.PdxReader;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxWriter;
+
+public class MyObjectPdxSerializable extends MyObject implements PdxSerializable {
+  public MyObjectPdxSerializable() {
+  }
+
+  public MyObjectPdxSerializable(long number, String s) {
+    super(number, s);
+  }
+
+  @Override
+  public void toData(PdxWriter writer) {
+    writer.writeLong("f1", f1);
+    writer.writeString("f2", f2);
+  }
+
+  @Override
+  public void fromData(PdxReader reader) {
+    f1 = reader.readLong("f1");
+    f2 = reader.readString("f2");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/examples/snapshot/MyPdxSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/examples/snapshot/MyPdxSerializer.java b/geode-core/src/test/java/com/examples/snapshot/MyPdxSerializer.java
new file mode 100644
index 0000000..710e445
--- /dev/null
+++ b/geode-core/src/test/java/com/examples/snapshot/MyPdxSerializer.java
@@ -0,0 +1,64 @@
+/*
+ * 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.examples.snapshot;
+
+import java.util.Properties;
+
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.pdx.PdxReader;
+import org.apache.geode.pdx.PdxSerializer;
+import org.apache.geode.pdx.PdxWriter;
+import org.apache.geode.pdx.ReflectionBasedAutoSerializer;
+
+public class MyPdxSerializer implements PdxSerializer, Declarable {
+  private final PdxSerializer auto = new ReflectionBasedAutoSerializer("com.examples.snapshot.My.*Pdx");
+  
+  @Override
+  public void init(Properties props) {
+  }
+  @Override
+  public boolean toData(Object o, PdxWriter out) {
+    if (o instanceof MyObjectPdx2) {
+      MyObjectPdx2 obj = (MyObjectPdx2) o;
+      out.writeLong("f1", obj.f1);
+      out.writeString("f2", obj.f2);
+      return true;
+    }
+    return auto.toData(o, out);
+  }
+
+  @Override
+  public Object fromData(Class<?> clazz, PdxReader in) {
+    if (clazz == MyObjectPdx2.class) {
+      MyObjectPdx2 obj = new MyObjectPdx2();
+      obj.f1 = in.readLong("f1");
+      obj.f2 = in.readString("f2");
+      
+      return obj;
+    }
+    return auto.fromData(clazz, in);
+  }
+  
+  public static class MyObjectPdx2 extends MyObject {
+    public MyObjectPdx2() {
+    }
+
+    public MyObjectPdx2(long number, String s) {
+      super(number, s);
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/main/MyDistributedSystemListener.java b/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
new file mode 100644
index 0000000..6206441
--- /dev/null
+++ b/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
@@ -0,0 +1,114 @@
+/*
+ * 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.main;
+
+import java.io.IOException;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.wan.GatewayReceiver;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.internal.cache.wan.DistributedSystemListener;
+
+/**
+ * This is an implementation of DistributedSystemListener. When a
+ * addedDistributedSystem is called a Region is created on both sites and
+ * GatewaySender and GatewayReciever is started on site 1 and site 2
+ * respectively.
+ * 
+ * When a removedDistributedSystem is called, GatewaySender and GatewayReceiver
+ * is stopped on site1 and site2 respectively.
+ * 
+ * 
+ */
+public class MyDistributedSystemListener implements DistributedSystemListener {
+
+  Cache cache;
+  
+  public MyDistributedSystemListener() {
+  }
+  
+  /**
+   * Please note that dynamic addition of the sender id to region is not yet available.  
+   */
+  public void addedDistributedSystem(int remoteDsId) {
+    cache = CacheFactory.getAnyInstance();
+    
+    //When a site with distributed-system-id = 2 joins, create a region and a gatewaysender with remoteDsId = 2 
+    if (remoteDsId == 2) {
+      if (cache != null) {
+        GatewaySender serialSender= cache
+            .createGatewaySenderFactory()
+            .setManualStart(true)
+            .setPersistenceEnabled(false)
+            .setDiskStoreName("LN_" + remoteDsId)
+            .create("LN_"+ remoteDsId, remoteDsId);
+        System.out.println("Sender Created : " + serialSender.getId());
+        
+        Region region= cache.createRegionFactory()
+                       //.addSerialGatewaySenderId("LN_" + remoteDsId)
+                       .create("MyRegion");
+        System.out.println("Created Region : " + region.getName());
+        
+        try {
+          serialSender.start();
+          System.out.println("Sender Started: " + serialSender.getId());
+        }
+        catch (Exception e) {
+          e.printStackTrace();
+        }
+      }
+      else {
+        throw new CacheClosedException("Cache is not initialized here");
+      }
+    }else{ //When a site with distributed-system-id = 1 joins, create a region and a gatewayReceiver with  
+      if (cache != null) {
+        Region region = cache.createRegionFactory().create("MyRegion");
+        System.out.println("Created Region :" +  region.getName());
+
+        GatewayReceiver receiver= cache.createGatewayReceiverFactory()
+                                 .setStartPort(12345)
+                                 .setManualStart(true)
+                                 .create();
+        System.out.println("Created GatewayReceiver : " + receiver);
+        try {
+          receiver.start();
+          System.out.println("GatewayReceiver Started.");
+        }
+        catch (IOException e) {
+          e.printStackTrace();
+        }
+      }
+    }
+  }
+
+  public void removedDistributedSystem(int remoteDsId) {
+    cache = CacheFactory.getAnyInstance();
+    if (remoteDsId == 2) { //When a site with distributed-system-id = -2 joins, stop gatewaysender with remoteDsId = 2 
+      if (cache != null) {
+        GatewaySender sender = cache.getGatewaySender("LN_"+2);
+        sender.stop();
+      }
+    }
+    else{ // When a site with distributed-system-id = -1 joins, stop gatewayReceiver
+      GatewayReceiver receiver = cache.getGatewayReceivers().iterator().next();
+      receiver.stop();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Add.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Add.java b/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Add.java
new file mode 100644
index 0000000..9d4bbfc
--- /dev/null
+++ b/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Add.java
@@ -0,0 +1,122 @@
+/*
+ * 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.main;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.internal.DistributionConfig;
+
+import java.util.Set;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+/**
+ * This is a member representing site 1 who wants to send data to site 2
+ * 
+ * On this member a locator with distributed-system-id = 1 is created. On this
+ * member a cache is created.
+ * 
+ * A Region and a GatewaySender is created on this member through
+ * MyDistributedSustemListener#addedDistributedSystemConnection 
+ * (When a remote locator with distributed-system-id = 2 connects to this site,
+ * MyDistributedSustemListener's addedDistributedSystemConnection will be
+ * invoked who will create a region and a GatewaySender.)
+ * 
+ * This member does put for 100 keys on the region. (We have to check that this
+ * data for 100 entries are sent to remote site)
+ * 
+ * This member also check for the sender's running status.
+ * 
+ * A GatewaySender will be stopped through
+ * MyDistributedSustemListener#removedDistributedSystem 
+ * (When a remote locator with distributed-system-id = -2 connects to this site,
+ * MyDistributedSustemListener's removedDistributedSystem will be invoked who
+ * will stop a GatewaySender.)
+ * 
+ * 
+ */
+
+public class WANBootStrapping_Site1_Add {
+
+  public static void main(String[] args) {
+
+    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
+        "com.main.MyDistributedSystemListener");
+
+    // Create a locator and a cache
+    System.out.println("Creating cache ...It will take some time..");
+    Cache cache = new CacheFactory().set(MCAST_PORT,
+        "0").set(DISTRIBUTED_SYSTEM_ID, "" + 1).set(
+        LOCATORS, "localhost[" + 10101 + "]").set(
+        START_LOCATOR,
+        "localhost[" + 10101
+            + "],server=true,peer=true,hostname-for-clients=localhost").set(
+        LOG_LEVEL, "warning").create();
+    System.out.println("Cache Created");
+
+    // to create region and a gateway sender ask to run
+    // WANBootStrapping_Site2_Add program
+    System.out.println("Run WANBootStrapping_Site2_Add");
+
+    // get the region
+    Region region = cache.getRegion("MyRegion");
+    while (region == null) {
+      region = cache.getRegion("MyRegion");
+      try {
+        Thread.sleep(5000);
+      }
+      catch (InterruptedException e) {
+        e.printStackTrace();
+      }
+    }
+
+    // put data in region
+    for (int i = 0; i < 100; i++) {
+      System.out.println("Create Entry : key_" + i + ", value_" + i);
+      region.put("key_" + i, "value_" + i);
+    }
+
+    System.out.println("Entry Create Operation completed");
+
+    Set<GatewaySender> gatewaySenders = cache.getGatewaySenders();
+    GatewaySender sender = gatewaySenders.iterator().next();
+
+    // make sure that gateway sender is running
+    if (sender.isRunning()) {
+      System.out.println("Sender " + sender.getId() + " is running");
+    }
+
+    // to stop gateway sender ask to run WANBootStrapping_Site2_Remove program
+    while (sender.isRunning()) {
+      System.out
+          .println("Waitng for sender to stop through DistributedSystemListener");
+      System.out.println("Start WANBootStrapping_Site2_Remove");
+      try {
+        Thread.sleep(5000);
+      }
+      catch (InterruptedException e) {
+        e.printStackTrace();
+      }
+    }
+    
+    System.out.println("Sender " + sender.getId() + " is stopped");
+
+    System.exit(0);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Remove.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Remove.java b/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Remove.java
new file mode 100644
index 0000000..6920d7e
--- /dev/null
+++ b/geode-core/src/test/java/com/main/WANBootStrapping_Site1_Remove.java
@@ -0,0 +1,78 @@
+/*
+ * 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.main;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+
+import java.io.IOException;
+import java.util.Properties;
+
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
+
+/**
+ * This is a stand alone locator with a distributed-system-id = -1
+ * 
+ * This locator is started so that the locator information regarding the site 1
+ * is removed from site 2's locator and at the same time
+ * MyDistributedSystemListener's removeDistributedSystem is invoked on site 2's locator which will stop the GatewayReceiver
+ * 
+ * 
+ */
+public class WANBootStrapping_Site1_Remove {
+
+
+  public static void main(String[] args) {
+    
+    //On this locator, I am not expecting a listener to take any action, so a empty listener is a passed
+    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
+    "");
+    
+    System.out.println("Starting a locator with negative ds id -1");
+    
+    //start a stand alone locator with distributed-system-is = -1
+    Properties properties = new Properties();
+    properties.setProperty(MCAST_PORT, "0");
+    properties.setProperty(DISTRIBUTED_SYSTEM_ID, ""+ (-1));
+    properties.setProperty(REMOTE_LOCATORS, "localhost[" + 20202 + "]");
+    properties.setProperty(LOG_LEVEL, "warning");
+    Locator locator = null;
+    try {
+      locator = Locator.startLocatorAndDS(40445, null, properties);
+    }
+    catch (IOException e) {
+      e.printStackTrace();
+    }
+    
+    try {
+      Thread.sleep(1000);
+    }
+    catch (InterruptedException e) {
+      e.printStackTrace();
+    }
+    
+    //stop locator
+    System.out.println("Stoping locator");    
+    locator.stop();
+    System.out.println("Locator stopped ");
+    
+    System.exit(0);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
new file mode 100644
index 0000000..f5abf5d
--- /dev/null
+++ b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
@@ -0,0 +1,108 @@
+/*
+ * 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.main;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.wan.GatewayReceiver;
+import org.apache.geode.distributed.internal.DistributionConfig;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+/**
+ * This is a member representing site 2 who wants to receive data from site 1
+ * 
+ * On this member a locator with distributed-system-id = 2 is created. 
+ * On this member a cache is created.
+ * 
+ * A Region and a GatewayReceiver is created on this member through
+ * MyDistributedSustemListener#addedDistributedSystemConnection
+ *  
+ * (When this locator gets the locator information from the site 1,
+ * MyDistributedSustemListener's addedDistributedSystemConnection will be
+ * invoked who will create a region and a GatewayReceiver.)
+ * 
+ * This member expects region size to be 100. (this site received this data from site1)
+ * 
+ * This member also check for the receiver's running status.
+ * 
+ * A GatewayReceiver will be stopped through
+ * MyDistributedSustemListener#removedDistributedSystem 
+ * (When a remote locator with distributed-system-id = -1 connects to this site,
+ * MyDistributedSustemListener's removedDistributedSystem will be invoked who
+ * will stop a GatewayReceiver.)
+ * 
+ * 
+ */
+
+public class WANBootStrapping_Site2_Add {
+
+  public static void main(String[] args) {
+
+    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
+        "com.main.MyDistributedSystemListener");
+    
+    //create a locator and a cache
+    System.out.println("Creating cache ...It will take some time..");
+    Cache cache = new CacheFactory()
+        .set(MCAST_PORT, "0")
+    .set(DISTRIBUTED_SYSTEM_ID, ""+2)
+        .set(LOCATORS, "localhost[" + 20202 + "]")
+        .set(START_LOCATOR, "localhost[" + 20202 + "],server=true,peer=true,hostname-for-clients=localhost")
+    .set(REMOTE_LOCATORS, "localhost[" + 10101 + "]")
+    .set(LOG_LEVEL, "warning")
+    .create();
+    System.out.println("Cache Created");
+    
+    //get the region whose size should be 100 
+    Region region = cache.getRegion("MyRegion");
+    while(region == null){
+      region = cache.getRegion("MyRegion");
+      try {
+        Thread.sleep(5000);
+      }
+      catch (InterruptedException e) {
+        e.printStackTrace();
+      }
+    }
+    
+    //region size should be 100. This is the data which will recieve from remote site
+    while(region.size()!= 100){
+      continue;
+    }
+    System.out.println("Checked region size : " + region.size());
+
+    GatewayReceiver receiver = cache.getGatewayReceivers().iterator().next();
+    
+     // to stop gateway receiver ask to run WANBootStrapping_Site1_Remove program
+    while (receiver.isRunning()) {
+      System.out
+          .println("Waitng for receiver to stop through DistributedSystemListener");
+      System.out.println("Start WANBootStrapping_Site1_Remove ");  
+      try {
+        Thread.sleep(2000);
+      }
+      catch (InterruptedException e) {
+        e.printStackTrace();
+      }
+    }
+
+    System.out.println("GatewayReciver " + receiver + " is stopped") ;
+    System.exit(0);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Remove.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Remove.java b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Remove.java
new file mode 100644
index 0000000..30e0a22
--- /dev/null
+++ b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Remove.java
@@ -0,0 +1,74 @@
+/*
+ * 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.main;
+
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+
+import java.io.IOException;
+import java.util.Properties;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+/**
+ * This is a stand alone locator with a distributed-system-id = -2
+ * 
+ * This locator is started so that the locator information regarding the site 2
+ * is removed from site 1's locator and at the same time
+ * MyDistributedSystemListener's removeDistributedSystem is invoked on site 1's locator which will stop the GatewaySender
+ * 
+ * 
+ */
+
+public class WANBootStrapping_Site2_Remove {
+
+  public static void main(String[] args) {
+    
+    // On this locator, I am not expecting a listener to take any action, so a
+    // empty listener is a passed
+    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
+    "");
+    
+    System.out.println("Starting a locator with negative ds id -2");
+    Properties properties = new Properties();
+    properties.setProperty(MCAST_PORT, "0");
+    properties.setProperty(DISTRIBUTED_SYSTEM_ID, ""+ (-2));
+    properties.setProperty(REMOTE_LOCATORS, "localhost[" + 10101 + "]");
+    properties.setProperty(LOG_LEVEL, "warning");
+    Locator locator = null;
+    try {
+      locator = Locator.startLocatorAndDS(30445, null, properties);
+    }
+    catch (IOException e) {
+      e.printStackTrace();
+    }
+    
+    try {
+      Thread.sleep(1000);
+    }
+    catch (InterruptedException e) {
+      e.printStackTrace();
+    }
+    System.out.println("Stoping locator");    
+    locator.stop();
+    System.out.println("Locator stopped ");
+    
+    System.exit(0);
+  }
+
+  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/apache/geode/internal/ClassPathLoaderTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/apache/geode/internal/ClassPathLoaderTest.java b/geode-core/src/test/java/org/apache/geode/internal/ClassPathLoaderTest.java
index aaeab36..26b3a91 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/ClassPathLoaderTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/ClassPathLoaderTest.java
@@ -46,7 +46,7 @@ import org.apache.geode.test.junit.categories.UnitTest;
 @Category(UnitTest.class)
 public class ClassPathLoaderTest {
 
-  private static final int GENERATED_CLASS_BYTES_COUNT = 362;
+  private static final int GENERATED_CLASS_BYTES_COUNT = 354;
 
   @Rule
   public RestoreSystemProperties restoreSystemProperties = new RestoreSystemProperties();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/app/Customer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/app/Customer.java b/geode-core/src/test/java/org/company/app/Customer.java
deleted file mode 100644
index 9dc87ca..0000000
--- a/geode-core/src/test/java/org/company/app/Customer.java
+++ /dev/null
@@ -1,36 +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 com.company.app;
-
-import org.apache.geode.cache.Declarable;
-
-/**
- * A class that is <code>Declarable</code>
- *
- * @since GemFire 3.2.1
- */
-public class Customer implements Declarable {
-
-  public Customer() {
-
-  }
-
-  public void init(java.util.Properties props) {
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/app/DBLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/app/DBLoader.java b/geode-core/src/test/java/org/company/app/DBLoader.java
deleted file mode 100644
index ab22805..0000000
--- a/geode-core/src/test/java/org/company/app/DBLoader.java
+++ /dev/null
@@ -1,63 +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 com.company.app;
-
-import java.util.Properties;
-
-import org.apache.geode.cache.*;
-
-/**
- * A <code>CacheLoader</code> that is <code>Declarable</code>
- *
- * @since GemFire 3.2.1
- */
-public class DBLoader implements CacheLoader, Declarable {
-
-  private Properties props = new Properties();
-  
-  public Object load(LoaderHelper helper)
-    throws CacheLoaderException {
-
-    throw new UnsupportedOperationException("I do NOTHING");
-  }
-
-  public void init(java.util.Properties props) {
-    this.props = props; 
-  }
-
-  public void close() {
-  }
-
-  public boolean equals(Object obj)
-  {
-    if (this == obj) {
-      return true;
-    }
-
-    if (! (obj instanceof DBLoader)) {
-      return false;
-    }
-    
-    DBLoader other = (DBLoader) obj;
-    if (! this.props.equals(other.props)) {
-      return false;
-    }
-    
-    return true;
-  }
-
-}


[78/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JMXDataUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JMXDataUpdater.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JMXDataUpdater.java
deleted file mode 100644
index 41374d8..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JMXDataUpdater.java
+++ /dev/null
@@ -1,2392 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.JmxManagerFinder.JmxManagerInfo;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-
-import javax.management.Attribute;
-import javax.management.AttributeList;
-import javax.management.AttributeNotFoundException;
-import javax.management.InstanceNotFoundException;
-import javax.management.IntrospectionException;
-import javax.management.InvalidAttributeValueException;
-import javax.management.MBeanException;
-import javax.management.MBeanServerConnection;
-import javax.management.MalformedObjectNameException;
-import javax.management.Notification;
-import javax.management.NotificationListener;
-import javax.management.ObjectName;
-import javax.management.ReflectionException;
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.TabularData;
-import javax.management.remote.JMXConnector;
-import javax.management.remote.JMXConnectorFactory;
-import javax.management.remote.JMXServiceURL;
-import javax.rmi.ssl.SslRMIClientSocketFactory;
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.lang.management.ManagementFactory;
-import java.net.Inet4Address;
-import java.net.Inet6Address;
-import java.net.InetAddress;
-import java.net.UnknownHostException;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.Date;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-import java.util.ResourceBundle;
-import java.util.Set;
-
-/**
- * Class JMXDataUpdater Class used for creating JMX connection and getting all
- * the required MBeans
- *
- *
- * @since GemFire version 7.0.Beta 2012-09-23
- */
-public class JMXDataUpdater implements IClusterUpdater, NotificationListener {
-
-  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-  private final ResourceBundle resourceBundle = Repository.get()
-      .getResourceBundle();
-
-  private JMXConnector conn = null;
-  private MBeanServerConnection mbs;
-  private final String serverName;
-  private final String port;
-  private final String userName;
-  private final String userPassword;
-  private Boolean isAddedNotiListner = false;
-  private final Cluster cluster;
-
-  // MBean object names
-  private ObjectName MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED;
-  private ObjectName MBEAN_OBJECT_NAME_REGION_DISTRIBUTED;
-  private ObjectName MBEAN_OBJECT_NAME_MEMBER;
-  private ObjectName MBEAN_OBJECT_NAME_MEMBER_MANAGER;
-  private ObjectName MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED;
-  private ObjectName MBEAN_OBJECT_NAME_TABLE_AGGREGATE;
-
-  private Set<ObjectName> systemMBeans = null;
-
-  private final String opSignature[] = { String.class.getName(),
-      String.class.getName(), int.class.getName() };
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  /**
-   * constructor used for creating JMX connection
-   */
-  public JMXDataUpdater(String server, String port, Cluster cluster) {
-    this.serverName = server;
-    this.port = port;
-    this.userName = cluster.getJmxUserName();
-    this.userPassword = cluster.getJmxUserPassword();
-    this.cluster = cluster;
-
-    try {
-      // Initialize MBean object names
-      this.MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED = new ObjectName(
-          PulseConstants.OBJECT_NAME_SYSTEM_DISTRIBUTED);
-      this.MBEAN_OBJECT_NAME_REGION_DISTRIBUTED = new ObjectName(
-          PulseConstants.OBJECT_NAME_REGION_DISTRIBUTED);
-      this.MBEAN_OBJECT_NAME_MEMBER_MANAGER = new ObjectName(
-          PulseConstants.OBJECT_NAME_MEMBER_MANAGER);
-      this.MBEAN_OBJECT_NAME_MEMBER = new ObjectName(
-          PulseConstants.OBJECT_NAME_MEMBER);
-      this.MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED = new ObjectName(
-          PulseConstants.OBJECT_NAME_STATEMENT_DISTRIBUTED);
-
-      // For SQLFire
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
-          .getPulseProductSupport())) {
-        this.MBEAN_OBJECT_NAME_TABLE_AGGREGATE = new ObjectName(
-            PulseConstants.OBJECT_NAME_TABLE_AGGREGATE);
-      }
-
-    } catch (MalformedObjectNameException e) {
-      if (LOGGER.severeEnabled()) {
-        LOGGER.severe(e.getMessage(), e);
-      }
-    } catch (NullPointerException e) {
-      if (LOGGER.severeEnabled()) {
-        LOGGER.severe(e.getMessage(), e);
-      }
-    }
-
-  }
-
-  private JmxManagerInfo getManagerInfoFromLocator(Repository repository) {
-
-    try {
-      String locatorHost = repository.getJmxHost();
-      int locatorPort = Integer.parseInt(repository.getJmxPort());
-
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle.getString("LOG_MSG_HOST") + " : " + locatorHost + " & "
-            + resourceBundle.getString("LOG_MSG_PORT") + " : " + locatorPort);
-      }
-
-      InetAddress inetAddr = InetAddress.getByName(locatorHost);
-
-      if ((inetAddr instanceof Inet4Address) || (inetAddr instanceof Inet6Address)) {
-
-        if (inetAddr instanceof Inet4Address) {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_IPV4_ADDRESS") + " - " + inetAddr.toString());
-          }
-        } else {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_IPV6_ADDRESS") + " - " + inetAddr.toString());
-          }
-        }
-
-        JmxManagerInfo jmxManagerInfo = JmxManagerFinder.askLocatorForJmxManager(inetAddr, locatorPort, 15000,
-            repository.isUseSSLLocator());
-
-        if (jmxManagerInfo.port == 0) {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_COULD_NOT_FIND_MANAGER"));
-          }
-        }
-        return jmxManagerInfo;
-      } else {
-        // Locator has Invalid locator Address
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_BAD_ADDRESS"));
-        }
-        cluster.setConnectionErrorMsg(resourceBundle.getString("LOG_MSG_JMX_CONNECTION_BAD_ADDRESS"));
-        // update message to display on UI
-        cluster.setConnectionErrorMsg(resourceBundle
-            .getString("LOG_MSG_JMX_CONNECTION_BAD_ADDRESS"));
-        return null;
-      }
-    } catch (IOException e) {
-      StringWriter swBuffer = new StringWriter();
-      PrintWriter prtWriter = new PrintWriter(swBuffer);
-      e.printStackTrace(prtWriter);
-      LOGGER.severe("Exception Details : " + swBuffer.toString() + "\n");
-    }
-    return null;
-  }
-
-  /**
-   * Default connection is Pulse which uses configured userName and password
-   */
-  public JMXConnector getJMXConnection() {
-    return getJMXConnection(true);
-  }
-
-  /**
-   * Get connection for given userName and password. This is used for DataBrowser
-   * queries which has to be fired using credentials provided at pulse login page
-   */
-  public JMXConnector getJMXConnection(final boolean registerURL) {
-    JMXConnector connection = null;
-    // Reference to repository
-    Repository repository = Repository.get();
-    try {
-
-      String jmxSerURL = "";
-
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle.getString("LOG_MSG_USE_LOCATOR_VALUE") + ":"
-            + repository.getJmxUseLocator());
-      }
-
-      if (repository.getJmxUseLocator()) {
-        JmxManagerInfo jmxManagerInfo = getManagerInfoFromLocator(repository);
-
-          if (jmxManagerInfo.port == 0) {
-            if (LOGGER.infoEnabled()) {
-              LOGGER.info(resourceBundle
-                  .getString("LOG_MSG_LOCATOR_COULD_NOT_FIND_MANAGER"));
-            }
-          } else {
-            if (LOGGER.infoEnabled()) {
-              LOGGER.info(resourceBundle
-                  .getString("LOG_MSG_LOCATOR_FOUND_MANAGER")
-                  + " : "
-                  + resourceBundle.getString("LOG_MSG_HOST")
-                  + " : "
-                  + jmxManagerInfo.host
-                  + " & "
-                  + resourceBundle.getString("LOG_MSG_PORT")
-                  + " : "
-                  + jmxManagerInfo.port
-                  + (jmxManagerInfo.ssl ? resourceBundle
-                      .getString("LOG_MSG_WITH_SSL") : resourceBundle
-                      .getString("LOG_MSG_WITHOUT_SSL")));
-            }
-
-            jmxSerURL = formJMXServiceURLString(jmxManagerInfo.host,
-                String.valueOf(jmxManagerInfo.port));
-          }
-      } else {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle.getString("LOG_MSG_HOST") + " : "
-              + this.serverName + " & "
-              + resourceBundle.getString("LOG_MSG_PORT") + " : " + this.port);
-        }
-        jmxSerURL = formJMXServiceURLString(this.serverName, this.port);
-      }
-
-      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(jmxSerURL)) {
-        JMXServiceURL url = new JMXServiceURL(jmxSerURL);
-        String[] creds = { this.userName, this.userPassword };
-        Map<String, Object> env = new HashMap<String, Object>();
-        env.put(JMXConnector.CREDENTIALS, creds);
-
-        if (repository.isUseSSLManager()) {
-          // use ssl to connect
-          env.put("com.sun.jndi.rmi.factory.socket",
-              new SslRMIClientSocketFactory());
-        }
-        LOGGER.info("Connecting to jmxURL : " + jmxSerURL);
-        connection = JMXConnectorFactory.connect(url, env);
-
-        // Register Pulse URL if not already present in the JMX Manager
-        if(registerURL)
-          registerPulseUrlToManager(connection);
-      }
-    } catch (Exception e) {
-      if (e instanceof UnknownHostException) {
-        cluster.setConnectionErrorMsg(resourceBundle
-            .getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST"));
-      }
-
-      StringWriter swBuffer = new StringWriter();
-      PrintWriter prtWriter = new PrintWriter(swBuffer);
-      e.printStackTrace(prtWriter);
-      LOGGER.severe("Exception Details : " + swBuffer.toString() + "\n");
-      if (this.conn != null) {
-        try {
-          this.conn.close();
-        } catch (Exception e1) {
-          LOGGER.severe("Error closing JMX connection " + swBuffer.toString()
-              + "\n");
-        }
-        this.conn = null;
-      }
-    }
-    return connection;
-  }
-
-  private String formJMXServiceURLString(String host, String port)
-      throws UnknownHostException {
-    /*
-     * String jmxSerURL = "service:jmx:rmi://" + serverName + "/jndi/rmi://" +
-     * serverName + ":" + port + "/jmxrmi";
-     */
-    String jmxSerURL = "";
-    if (host.equalsIgnoreCase("localhost")) {
-      // Create jmx service url for 'localhost'
-      jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":"
-          + port + "/jmxrmi";
-    } else {
-      InetAddress inetAddr = InetAddress.getByName(host);
-      if (inetAddr instanceof Inet4Address) {
-        // Create jmx service url for IPv4 address
-        jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":"
-            + port + "/jmxrmi";
-      } else if (inetAddr instanceof Inet6Address) {
-        // Create jmx service url for IPv6 address
-        jmxSerURL = "service:jmx:rmi://[" + host + "]/jndi/rmi://[" + host + "]:"
-            + port + "/jmxrmi";
-      }
-    }
-
-    return jmxSerURL;
-  }
-
-  // Method registers Pulse URL if not already present in the JMX Manager
-  private void registerPulseUrlToManager(JMXConnector connection)
-      throws IOException, AttributeNotFoundException,
-      InstanceNotFoundException, MBeanException, ReflectionException,
-      MalformedObjectNameException, InvalidAttributeValueException {
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle
-          .getString("LOG_MSG_REGISTERING_APP_URL_TO_MANAGER"));
-    }
-
-    // Reference to repository
-    Repository repository = Repository.get();
-
-    // Register Pulse URL if not already present in the JMX Manager
-    if (connection != null) {
-      MBeanServerConnection mbsc = connection.getMBeanServerConnection();
-
-      Set<ObjectName> mbeans = mbsc.queryNames(
-          this.MBEAN_OBJECT_NAME_MEMBER_MANAGER, null);
-
-      for (ObjectName mbeanName : mbeans) {
-        String presentUrl = (String) mbsc.getAttribute(mbeanName,
-            PulseConstants.MBEAN_MANAGER_ATTRIBUTE_PULSEURL);
-        String pulseWebAppUrl = repository.getPulseWebAppUrl();
-        if (pulseWebAppUrl != null
-            && (presentUrl == null || !pulseWebAppUrl.equals(presentUrl))) {
-          if (LOGGER.fineEnabled()) {
-            LOGGER.fine(resourceBundle
-                .getString("LOG_MSG_SETTING_APP_URL_TO_MANAGER"));
-          }
-          Attribute pulseUrlAttr = new Attribute(
-              PulseConstants.MBEAN_MANAGER_ATTRIBUTE_PULSEURL, pulseWebAppUrl);
-          mbsc.setAttribute(mbeanName, pulseUrlAttr);
-        } else {
-          if (LOGGER.fineEnabled()) {
-            LOGGER.fine(resourceBundle
-                .getString("LOG_MSG_APP_URL_ALREADY_PRESENT_IN_MANAGER"));
-          }
-        }
-      }
-    }
-  }
-
-  private boolean isConnected() {
-    // Reference to repository
-    Repository repository = Repository.get();
-    if (repository.getIsEmbeddedMode()) {
-      if (this.mbs == null) {
-        this.mbs = ManagementFactory.getPlatformMBeanServer();
-        cluster.setConnectedFlag(true);
-      }
-    } else {
-      try {
-        if (this.conn == null) {
-          cluster.setConnectedFlag(false);
-          cluster.setConnectionErrorMsg(resourceBundle
-              .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND")
-              + " "
-              + resourceBundle.getString("LOG_MSG_JMX_GETTING_NEW_CONNECTION"));
-          if (LOGGER.fineEnabled()) {
-            LOGGER.fine(resourceBundle
-                .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND")
-                + " "
-                + resourceBundle.getString("LOG_MSG_JMX_GET_NEW_CONNECTION"));
-          }
-          this.conn = getJMXConnection();
-          if (this.conn != null) {
-            this.mbs = this.conn.getMBeanServerConnection();
-            cluster.setConnectedFlag(true);
-          } else {
-            if (LOGGER.infoEnabled()) {
-              LOGGER.info(resourceBundle
-                  .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND"));
-            }
-            return false;
-          }
-        } else {
-          if (LOGGER.fineEnabled()) {
-            LOGGER.fine(resourceBundle
-                .getString("LOG_MSG_JMX_CONNECTION_IS_AVAILABLE"));
-          }
-          cluster.setConnectedFlag(true);
-          if (this.mbs == null) {
-            this.mbs = this.conn.getMBeanServerConnection();
-          }
-        }
-      } catch (Exception e) {
-        this.mbs = null;
-        if (this.conn != null) {
-          try {
-            this.conn.close();
-          } catch (Exception e1) {
-            LOGGER.severe(e);
-          }
-        }
-        this.conn = null;
-        return false;
-      }
-    }
-
-    return true;
-  }
-
-  /**
-   * function used for updating Cluster Data.
-   */
-  @Override
-  public boolean updateData() {
-    try {
-      if (!this.isConnected()) {
-        return false;
-      }
-
-      // deleted Members
-      cluster.getDeletedMembers().clear();
-      for (Entry<String, Cluster.Member> memberSet : cluster.getMembersHMap()
-          .entrySet()) {
-        cluster.getDeletedMembers().add(memberSet.getKey());
-      }
-
-      // Deleted Regions
-      cluster.getDeletedRegions().clear();
-      for (Cluster.Region region : cluster.getClusterRegions().values()) {
-        cluster.getDeletedRegions().add(region.getFullPath());
-      }
-
-      // try {
-
-      // Cluster
-      this.systemMBeans = this.mbs.queryNames(
-          this.MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED, null);
-      for (ObjectName sysMBean : this.systemMBeans) {
-        updateClusterSystem(sysMBean);
-      }
-
-      // Cluster Regions/Tables
-      Set<ObjectName> regionMBeans = this.mbs.queryNames(
-          this.MBEAN_OBJECT_NAME_REGION_DISTRIBUTED, null);
-
-      Set<ObjectName> tableMBeans = this.mbs.queryNames(
-          this.MBEAN_OBJECT_NAME_TABLE_AGGREGATE, null);
-
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
-          .getPulseProductSupport())) {
-        // For SQLfire
-        for (ObjectName tableMBean : tableMBeans) {
-          String regNameFromTable = StringUtils
-              .getRegionNameFromTableName(tableMBean.getKeyProperty("table"));
-          for (ObjectName regionMBean : regionMBeans) {
-            String regionName = regionMBean.getKeyProperty("name");
-            if (regNameFromTable.equals(regionName)) {
-              updateClusterRegion(regionMBean);
-              // Increment cluster region count
-              cluster.setTotalRegionCount(cluster.getTotalRegionCount() + 1);
-              break;
-            }
-          }
-        }
-      } else {
-        // For Gemfire
-        for (ObjectName regMBean : regionMBeans) {
-          updateClusterRegion(regMBean);
-        }
-      }
-
-      // Remove deleted regions from cluster's regions list
-      for (Iterator<String> it = cluster.getDeletedRegions().iterator(); it
-          .hasNext();) {
-        cluster.removeClusterRegion(it.next());
-      }
-
-      // Cluster Members
-      Set<ObjectName> memberMBeans = this.mbs.queryNames(
-          this.MBEAN_OBJECT_NAME_MEMBER, null);
-      for (ObjectName memMBean : memberMBeans) {
-        String service = memMBean.getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_SERVICE);
-        if(service==null){
-          // Cluster Member
-          updateClusterMember(memMBean);
-        }
-        else {
-          switch (service) {
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_REGION:
-            if (PulseConstants.PRODUCT_NAME_SQLFIRE
-                .equalsIgnoreCase(PulseController.getPulseProductSupport())) {
-              // For SQLfire
-              for (ObjectName tableMBean : tableMBeans) {
-                String regNameFromTable = StringUtils
-                    .getRegionNameFromTableName(tableMBean
-                        .getKeyProperty("table"));
-                String regionName = memMBean.getKeyProperty("name");
-                if (regNameFromTable.equals(regionName)) {
-                  updateMemberRegion(memMBean);
-                  break;
-                }
-              }
-            } else {
-              // For Gemfire
-              updateMemberRegion(memMBean);
-            }
-            break;
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_CACHESERVER:
-            updateMemberClient(memMBean);
-            break;
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYRECEIVER:
-            updateGatewayReceiver(memMBean);
-            break;
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYSENDER:
-            updateGatewaySender(memMBean);
-            break;
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_ASYNCEVENTQUEUE:
-            updateAsyncEventQueue(memMBean);
-            break;
-          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_LOCATOR:
-            updateClusterMember(memMBean);
-            break;
-          }
-        }
-      }
-
-      // Cluster Query Statistics
-      Set<ObjectName> statementObjectNames = this.mbs.queryNames(
-          this.MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED, null);
-      //LOGGER.info("statementObjectNames = " + statementObjectNames);
-      for (ObjectName stmtObjectName : statementObjectNames) {
-        //LOGGER.info("stmtObjectName = " + stmtObjectName);
-        updateClusterStatement(stmtObjectName);
-      }
-    } catch (IOException ioe) {
-
-      // write errors
-      StringWriter swBuffer = new StringWriter();
-      PrintWriter prtWriter = new PrintWriter(swBuffer);
-      ioe.printStackTrace(prtWriter);
-      LOGGER.severe("IOException Details : " + swBuffer.toString() + "\n");
-      this.mbs = null;
-      if (this.conn != null) {
-        try {
-          this.conn.close();
-        } catch (IOException e1) {
-          LOGGER.severe("Error closing JMX connection " + swBuffer.toString()
-              + "\n");
-        }
-      }
-
-      return false;
-    }
-
-    // If there were members deleted, remove them from the membersList &
-    // physicalToMember.
-    Iterator<String> iterator = cluster.getDeletedMembers().iterator();
-    while (iterator.hasNext()) {
-      String memberKey = iterator.next();
-      if (cluster.getMembersHMap().containsKey(memberKey)) {
-        Cluster.Member member = cluster.getMembersHMap().get(memberKey);
-        List<Cluster.Member> memberArrList = cluster.getPhysicalToMember().get(
-            member.getHost());
-        if (memberArrList != null) {
-          if (memberArrList.contains(member)) {
-            String host = member.getHost();
-            cluster.getPhysicalToMember().get(member.getHost()).remove(member);
-
-            if (cluster.getPhysicalToMember().get(member.getHost()).size() == 0) {
-              cluster.getPhysicalToMember().remove(host);
-            }
-          }
-        }
-        cluster.getMembersHMap().remove(memberKey);
-      }
-
-    }
-
-    return true;
-  }
-
-  /**
-   * function used to get attribute values of Cluster System and map them to
-   * cluster vo
-   *
-   * @param mbeanName
-   *          Cluster System MBean
-   * @throws IOException
-   *
-   */
-  private void updateClusterSystem(ObjectName mbeanName) throws IOException {
-    try {
-      if (!this.isAddedNotiListner) {
-        this.mbs.addNotificationListener(mbeanName, this, null, new Object());
-        this.isAddedNotiListner = true;
-      }
-
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
-          .getPulseProductSupport())) {
-        // Reset to zero
-        cluster.setServerCount(0);
-        cluster.setTotalRegionCount(0);
-      } else {
-        String[] serverCnt = (String[]) (this.mbs.invoke(mbeanName,
-            PulseConstants.MBEAN_OPERATION_LISTSERVERS, null, null));
-        cluster.setServerCount(serverCnt.length);
-      }
-
-      TabularData table = (TabularData) (this.mbs.invoke(mbeanName,
-          PulseConstants.MBEAN_OPERATION_VIEWREMOTECLUSTERSTATUS, null, null));
-
-      Collection<CompositeData> rows = (Collection<CompositeData>) table
-          .values();
-      cluster.getWanInformationObject().clear();
-      for (CompositeData row : rows) {
-        final Object key = row.get("key");
-        final Object value = row.get("value");
-        cluster.getWanInformationObject().put((String) key, (Boolean) value);
-      }
-
-      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-          PulseConstants.CLUSTER_MBEAN_ATTRIBUTES);
-
-      for (int i = 0; i < attributeList.size(); i++) {
-
-        Attribute attribute = (Attribute) attributeList.get(i);
-        String name = attribute.getName();
-        switch (name){
-        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERCOUNT:
-          cluster.setMemberCount(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMCLIENTS:
-          cluster.setClientConnectionCount(getIntegerAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID:
-          cluster.setClusterId(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_LOCATORCOUNT:
-          cluster.setLocatorCount(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION:
-          try {
-            cluster.setRunningFunctionCount(getIntegerAttribute(
-                attribute.getValue(), attribute.getName()));
-          } catch (Exception e) {
-            cluster.setRunningFunctionCount(0);
-            continue;
-          }
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT:
-          cluster.setRegisteredCQCount(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS:
-          cluster.setSubscriptionCount(getIntegerAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMTXNCOMMITTED:
-          cluster.setTxnCommittedCount(getIntegerAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMTXNROLLBACK:
-          cluster.setTxnRollbackCount(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALHEAPSIZE:
-          cluster.setTotalHeapSize(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_USEDHEAPSIZE:
-          try {
-            cluster.setUsedHeapSize(getLongAttribute(attribute.getValue(),
-                attribute.getName()));
-          } catch (Exception e) {
-            cluster.setUsedHeapSize((long) 0);
-            continue;
-          }
-          cluster.getMemoryUsageTrend().add(cluster.getUsedHeapSize());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT:
-          cluster.setTotalRegionEntryCount(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT:
-          cluster.setCurrentQueryCount(getIntegerAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALDISKUSAGE:
-          try {
-            cluster.setTotalBytesOnDisk(getLongAttribute(attribute.getValue(),
-                attribute.getName()));
-          } catch (Exception e) {
-            cluster.setTotalBytesOnDisk((long) 0);
-            continue;
-          }
-          cluster.getTotalBytesOnDiskTrend().add(cluster.getTotalBytesOnDisk());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-          cluster.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          cluster.getThroughoutWritesTrend().add(cluster.getDiskWritesRate());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEWRITES:
-          try {
-            cluster.setWritePerSec(getDoubleAttribute(attribute.getValue(),
-                attribute.getName()));
-          } catch (Exception e) {
-            cluster.setWritePerSec(0);
-            continue;
-          }
-          cluster.getWritePerSecTrend().add(cluster.getWritePerSec());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEREADS:
-          try {
-            cluster.setReadPerSec(getDoubleAttribute(attribute.getValue(),
-                attribute.getName()));
-          } catch (Exception e) {
-            cluster.setReadPerSec(0);
-            continue;
-          }
-          cluster.getReadPerSecTrend().add(cluster.getReadPerSec());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_QUERYREQUESTRATE:
-          cluster.setQueriesPerSec(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          cluster.getQueriesPerSecTrend().add(cluster.getQueriesPerSec());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-          cluster.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          cluster.getThroughoutReadsTrend().add(cluster.getDiskReadsRate());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_JVMPAUSES:
-          long trendVal = determineCurrentJVMPauses(
-              PulseConstants.JVM_PAUSES_TYPE_CLUSTER, "",
-              getLongAttribute(attribute.getValue(), attribute.getName()));
-          cluster.setGarbageCollectionCount(trendVal);
-          cluster.getGarbageCollectionTrend().add(
-              cluster.getGarbageCollectionCount());
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONCOUNT:
-          if (!PulseConstants.PRODUCT_NAME_SQLFIRE
-              .equalsIgnoreCase(PulseController.getPulseProductSupport())){
-            // for Gemfire
-            cluster.setTotalRegionCount(getIntegerAttribute(
-                attribute.getValue(), attribute.getName()));
-          }
-          break;
-        }
-      }
-
-      // SQLFIRE attributes
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
-          .getPulseProductSupport())) {
-
-        try { // get sqlfire cluster mbean
-
-          ObjectName sfMemberMbeansObjectName = new ObjectName(
-              PulseConstants.OBJECT_NAME_SF_CLUSTER);
-
-          Set<ObjectName> sfCluserMBeans = this.mbs.queryNames(
-              sfMemberMbeansObjectName, null);
-
-          for (ObjectName sfCluserMBean : sfCluserMBeans) {
-
-            AttributeList attrList = this.mbs.getAttributes(sfCluserMBean,
-                PulseConstants.SF_CLUSTER_MBEAN_ATTRIBUTES);
-
-            for (int i = 0; i < attrList.size(); i++) {
-
-              Attribute attribute = (Attribute) attrList.get(i);
-
-              if (attribute.getName().equals(
-                  PulseConstants.MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS)) {
-                try {
-                  cluster.setRunningFunctionCount(getIntegerAttribute(
-                      attribute.getValue(), attribute.getName()));
-                } catch (Exception e) {
-                  cluster.setRunningFunctionCount(0);
-                  continue;
-                }
-              } else if (attribute
-                  .getName()
-                  .equals(
-                      PulseConstants.MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS)) {
-                // set number of cluster's clients
-                CompositeData nscConnStats = (CompositeData) attribute
-                    .getValue();
-
-                cluster.setClientConnectionCount(getLongAttribute(nscConnStats
-                    .get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE),
-                    PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE));
-              }
-            }
-            break;
-          }
-
-        } catch (MalformedObjectNameException e) {
-          LOGGER.warning(e);
-        } catch (NullPointerException e) {
-          LOGGER.warning(e);
-        }
-
-      }
-
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    } catch (MBeanException anfe) {
-      LOGGER.warning(anfe);
-    }
-  }
-
-  /**
-   * function used to get attribute values of Gateway Receiver and map them to
-   * GatewayReceiver inner class object
-   *
-   * @param mbeanName
-   * @return GatewayReceiver object
-   * @throws InstanceNotFoundException
-   * @throws IntrospectionException
-   * @throws ReflectionException
-   * @throws IOException
-   * @throws AttributeNotFoundException
-   * @throws MBeanException
-   *
-   *
-   */
-  private Cluster.GatewayReceiver initGatewayReceiver(ObjectName mbeanName)
-      throws InstanceNotFoundException, IntrospectionException,
-      ReflectionException, IOException, AttributeNotFoundException,
-      MBeanException {
-
-    Cluster.GatewayReceiver gatewayReceiver = new Cluster.GatewayReceiver();
-
-    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-        PulseConstants.GATEWAY_MBEAN_ATTRIBUTES);
-
-    for (int i = 0; i < attributeList.size(); i++) {
-      Attribute attribute = (Attribute) attributeList.get(i);
-
-      if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_PORT)) {
-        gatewayReceiver.setListeningPort(getIntegerAttribute(
-            attribute.getValue(), attribute.getName()));
-      } else if (attribute.getName().equals(
-          PulseConstants.MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE)) {
-        gatewayReceiver.setLinkThroughput(getDoubleAttribute(
-            attribute.getValue(), attribute.getName()));
-      } else if (attribute.getName().equals(
-          PulseConstants.MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME)) {
-        gatewayReceiver.setAvgBatchProcessingTime(getLongAttribute(
-            attribute.getValue(), attribute.getName()));
-      } else if (attribute.getName().equals(
-          PulseConstants.MBEAN_ATTRIBUTE_RUNNING)) {
-        gatewayReceiver.setStatus(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-      }
-    }
-    return gatewayReceiver;
-  }
-
-  /**
-   * function used to get attribute values of Gateway Sender and map them to
-   * GatewaySender inner class object
-   *
-   * @param mbeanName
-   * @return
-   * @throws InstanceNotFoundException
-   * @throws IntrospectionException
-   * @throws ReflectionException
-   * @throws IOException
-   * @throws AttributeNotFoundException
-   * @throws MBeanException
-   */
-  private Cluster.GatewaySender initGatewaySender(ObjectName mbeanName)
-      throws InstanceNotFoundException, IntrospectionException,
-      ReflectionException, IOException, AttributeNotFoundException,
-      MBeanException {
-
-    Cluster.GatewaySender gatewaySender = new Cluster.GatewaySender();
-    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-        PulseConstants.GATEWAYSENDER_MBEAN_ATTRIBUTES);
-
-    for (int i = 0; i < attributeList.size(); i++) {
-      Attribute attribute = (Attribute) attributeList.get(i);
-      String name = attribute.getName();
-      switch (name){
-      case PulseConstants.MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE:
-        gatewaySender.setLinkThroughput(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_BATCHSIZE:
-        gatewaySender.setBatchSize(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_SENDERID:
-        gatewaySender.setId(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_EVENTQUEUESIZE:
-        gatewaySender.setQueueSize(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_RUNNING:
-        gatewaySender.setStatus(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_PRIMARY:
-        gatewaySender.setPrimary(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_PERSISTENCEENABLED:
-        gatewaySender.setPersistenceEnabled(getBooleanAttribute(
-            attribute.getValue(), attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_PARALLEL:
-        gatewaySender.setSenderType(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_REMOTE_DS_ID:
-        gatewaySender.setRemoteDSId(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD:
-        gatewaySender.setEventsExceedingAlertThreshold(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      }
-    }
-    return gatewaySender;
-  }
-
-  /**
-   * function used for getting list of Gateway Senders from mBean for giving
-   * member and update the list of gateway senders for respective member object
-   */
-  private void updateGatewaySender(ObjectName mbeanName) throws IOException {
-
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      if (cluster.getMembersHMap().containsKey(memberName)) {
-        Cluster.Member existingMember = cluster.getMembersHMap()
-            .get(memberName);
-        Cluster.GatewaySender gatewaySender = initGatewaySender(mbeanName);
-        for (Iterator<Cluster.GatewaySender> it = existingMember
-            .getGatewaySenderList().iterator(); it.hasNext();) {
-          Cluster.GatewaySender exisGatewaySender = it.next();
-          if ((exisGatewaySender.getId()).equals(gatewaySender.getId())) {
-            it.remove();
-            break;
-          }
-        }
-
-        // Add gateway sender
-        existingMember.getGatewaySenderList().add(gatewaySender);
-
-      } else {
-        Cluster.Member member = new Cluster.Member();
-        member.setName(memberName);
-        member.setId(memberName);
-        Cluster.GatewaySender gatewaySender = initGatewaySender(mbeanName);
-        member.getGatewaySenderList().add(gatewaySender);
-        cluster.getMembersHMap().put(memberName, member);
-      }
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    } catch (MBeanException me) {
-      LOGGER.warning(me);
-    } catch (AttributeNotFoundException anfe) {
-      LOGGER.warning(anfe);
-    } catch (IntrospectionException ire) {
-      LOGGER.warning(ire);
-    }
-  }
-
-  /**
-   * function used to get attribute values of Async Event Queue and map them to
-   * Async Event Queue  inner class object
-   *
-   * @param mbeanName
-   * @return
-   * @throws InstanceNotFoundException
-   * @throws IntrospectionException
-   * @throws ReflectionException
-   * @throws IOException
-   * @throws AttributeNotFoundException
-   * @throws MBeanException
-   */
-  private Cluster.AsyncEventQueue initAsyncEventQueue(ObjectName mbeanName)
-      throws InstanceNotFoundException, IntrospectionException,
-      ReflectionException, IOException, AttributeNotFoundException,
-      MBeanException {
-
-    Cluster.AsyncEventQueue asyncEventQueue = new Cluster.AsyncEventQueue();
-    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-        PulseConstants.ASYNC_EVENT_QUEUE_MBEAN_ATTRIBUTES);
-
-    for (int i = 0; i < attributeList.size(); i++) {
-      Attribute attribute = (Attribute) attributeList.get(i);
-      String name = attribute.getName();
-      switch (name){
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID:
-        asyncEventQueue.setId(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER:
-        asyncEventQueue.setAsyncEventListener(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED:
-        asyncEventQueue.setBatchConflationEnabled(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL:
-        asyncEventQueue.setBatchTimeInterval(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE:
-        asyncEventQueue.setBatchSize(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE:
-        asyncEventQueue.setEventQueueSize(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_PARALLEL:
-        asyncEventQueue.setParallel(getBooleanAttribute(
-            attribute.getValue(), attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_PRIMARY:
-        asyncEventQueue.setPrimary(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      }
-    }
-    return asyncEventQueue;
-  }
-
-  /**
-   * function used for getting list of Gateway Senders from mBean for giving
-   * member and update the list of gateway senders for respective member object
-   */
-  private void updateAsyncEventQueue(ObjectName mbeanName) throws IOException {
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      if (cluster.getMembersHMap().containsKey(memberName)) {
-        Cluster.Member existingMember = cluster.getMembersHMap()
-            .get(memberName);
-        Cluster.AsyncEventQueue asyncQ = initAsyncEventQueue(mbeanName);
-        for (Iterator<Cluster.AsyncEventQueue> it = existingMember.getAsyncEventQueueList().iterator(); it.hasNext();) {
-          Cluster.AsyncEventQueue exisAsyncEventQueue = it.next();
-          if ((exisAsyncEventQueue.getId()).equals(asyncQ.getId())) {
-            it.remove();
-            break;
-          }
-        }
-
-        // Add async event queue
-        existingMember.getAsyncEventQueueList().add(asyncQ);
-      } else {
-        Cluster.Member member = new Cluster.Member();
-        member.setName(memberName);
-        member.setId(memberName);
-
-        Cluster.AsyncEventQueue asyncQ = initAsyncEventQueue(mbeanName);
-        member.getAsyncEventQueueList().add(asyncQ);
-
-        cluster.getMembersHMap().put(memberName, member);
-      }
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    } catch (MBeanException me) {
-      LOGGER.warning(me);
-    } catch (AttributeNotFoundException anfe) {
-      LOGGER.warning(anfe);
-    } catch (IntrospectionException ire) {
-      LOGGER.warning(ire);
-    }
-  }
-
-  /**
-   * function used for getting a Gateway Receiver from mBean for giving member
-   * and update the gateway receiver for respective member object
-   */
-  private void updateGatewayReceiver(ObjectName mbeanName) throws IOException {
-
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      if (cluster.getMembersHMap().containsKey(memberName)) {
-        Cluster.Member existingMember = cluster.getMembersHMap()
-            .get(memberName);
-        Cluster.GatewayReceiver gatewayReceiver = initGatewayReceiver(mbeanName);
-        existingMember.setGatewayReceiver(gatewayReceiver);
-      } else {
-        Cluster.Member member = new Cluster.Member();
-        member.setName(memberName);
-        member.setId(memberName);
-        Cluster.GatewayReceiver gatewayReceiver = initGatewayReceiver(mbeanName);
-        member.setGatewayReceiver(gatewayReceiver);
-        cluster.getMembersHMap().put(memberName, member);
-      }
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    } catch (MBeanException me) {
-      LOGGER.warning(me);
-    } catch (AttributeNotFoundException anfe) {
-      LOGGER.warning(anfe);
-    } catch (IntrospectionException ire) {
-      LOGGER.warning(ire);
-    }
-  }
-
-  /**
-   * function used for getting member clients from mbean and update the clients
-   * information in member object's client arraylist
-   */
-  private void updateMemberClient(ObjectName mbeanName) throws IOException {
-
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      if (cluster.getMembersHMap().containsKey(memberName)) {
-        Cluster.Member existingMember = cluster.getMembersHMap()
-            .get(memberName);
-        HashMap<String, Cluster.Client> memberClientsHM = new HashMap<String, Cluster.Client>();
-
-        existingMember.setMemberPort(""
-            + this.mbs.getAttribute(mbeanName,
-                PulseConstants.MBEAN_ATTRIBUTE_PORT));
-
-        this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT);
-        existingMember.setHostnameForClients((String)this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT));
-        existingMember.setBindAddress((String)this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_BINDADDRESS));
-
-        CompositeData[] compositeData = (CompositeData[]) (this.mbs.invoke(
-            mbeanName, PulseConstants.MBEAN_OPERATION_SHOWALLCLIENTS, null,
-            null));
-        for (CompositeData cmd : compositeData) {
-          Cluster.Client client = new Cluster.Client();
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CLIENTID)) {
-            client.setId((String) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_CLIENTID));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NAME)) {
-            client.setName((String) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_NAME));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_HOSTNAME)) {
-            client.setHost((String) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_HOSTNAME));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_QUEUESIZE)) {
-            client.setQueueSize((Integer) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_QUEUESIZE));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_PROCESSCPUTIME)) {
-            client.setProcessCpuTime((Long) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_PROCESSCPUTIME));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_UPTIME)) {
-            client.setUptime((Long) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_UPTIME));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFTHREADS)) {
-            client.setThreads((Integer) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFTHREADS));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFGETS)) {
-            client.setGets((Integer) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFGETS));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFPUTS)) {
-            client.setPuts((Integer) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFPUTS));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CPUS)) {
-            client.setCpus((Integer) cmd
-                .get(PulseConstants.COMPOSITE_DATA_KEY_CPUS));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CPUS)) {
-            client.setCpuUsage(0);
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CONNECTED)){
-            client.setConnected((Boolean) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTED));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CLIENTCQCOUNT)){
-        	client.setClientCQCount((Integer) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_CLIENTCQCOUNT));
-          }
-          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED)){
-            client.setSubscriptionEnabled((Boolean) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED));
-          }
-          memberClientsHM.put(client.getId(), client);
-        }
-        existingMember.updateMemberClientsHMap(memberClientsHM);
-      }
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    } catch (MBeanException me) {
-      LOGGER.warning(me);
-    } catch (AttributeNotFoundException anfe) {
-      LOGGER.warning(anfe);
-    }
-  }
-
-  /**
-   * Add member specific region information on the region
-   *
-   * @param regionObjectName: used to construct the jmx objectname. For region name that has special characters in, it will have double quotes around it.
-   * @param region
-   */
-  private void updateRegionOnMembers(String regionObjectName, String regionFullPath, Cluster.Region region) throws IOException {
-
-    try{
-        List<String> memberNamesTemp = region.getMemberName();
-        ArrayList<String> memberNames = new ArrayList<String>(memberNamesTemp);
-
-        List<Cluster.RegionOnMember> regionOnMemberList = new ArrayList<Cluster.RegionOnMember>();
-        List<Cluster.RegionOnMember> regionOnMemberListNew = new ArrayList<Cluster.RegionOnMember>();
-        Cluster.RegionOnMember[] regionOnMemberNames = region.getRegionOnMembers();
-
-        if ((regionOnMemberNames != null) && (regionOnMemberNames.length > 0)) {
-          regionOnMemberList = new ArrayList<Cluster.RegionOnMember>(Arrays.asList(regionOnMemberNames));
-        }
-        LOGGER.fine("updateRegionOnMembers : # regionOnMembers objects in region = " + regionOnMemberList.size());
-
-        for(Cluster.RegionOnMember anRom : regionOnMemberList) {
-
-          for(String memberName : memberNames){
-            if(anRom.getMemberName().equals(memberName)){
-              // Add regionOnMember object in new list
-              regionOnMemberListNew.add(anRom);
-
-              LOGGER.fine("updateRegionOnMembers : Processing existing Member name = " + anRom.getMemberName());
-              String objectNameROM = PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObjectName + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + anRom.getMemberName();
-              ObjectName regionOnMemberMBean = new ObjectName(objectNameROM);
-              LOGGER.fine("updateRegionOnMembers : Object name = " + regionOnMemberMBean.getCanonicalName());
-
-              AttributeList attributeList = this.mbs.getAttributes(regionOnMemberMBean, PulseConstants.REGION_ON_MEMBER_MBEAN_ATTRIBUTES);
-              for (int i = 0; i < attributeList.size(); i++) {
-                Attribute attribute = (Attribute) attributeList.get(i);
-                String name = attribute.getName();
-                switch(name){
-                case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
-                  anRom.setEntrySize(getLongAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getEntrySize() = " + anRom.getEntrySize());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_ENTRYCOUNT:
-                  anRom.setEntryCount(getLongAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getEntryCount() = " + anRom.getEntryCount());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
-                  anRom.setPutsRate(getDoubleAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getPutsRate() = " + anRom.getPutsRate());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
-                  anRom.setGetsRate(getDoubleAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getGetsRate() = " + anRom.getGetsRate());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-                  anRom.setDiskGetsRate(getDoubleAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getDiskGetsRate() = " + anRom.getDiskGetsRate());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-                  anRom.setDiskPutsRate(getDoubleAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getDiskPutsRate() = " + anRom.getDiskPutsRate());
-                  break;
-                case PulseConstants.MBEAN_ATTRIBUTE_LOCALMAXMEMORY:
-                  anRom.setLocalMaxMemory(getIntegerAttribute(attribute.getValue(),
-                      attribute.getName()));
-                  LOGGER.fine("updateRegionOnMembers : anRom.getLocalMaxMemory() = " + anRom.getLocalMaxMemory());
-                  break;
-                }
-              }
-
-              anRom.getGetsPerSecTrend().add(anRom.getGetsRate());
-              anRom.getPutsPerSecTrend().add(anRom.getPutsRate());
-              anRom.getDiskReadsPerSecTrend().add(anRom.getDiskGetsRate());
-              anRom.getDiskWritesPerSecTrend().add(anRom.getDiskPutsRate());
-              LOGGER.fine("updateRegionOnMembers : Existing member on region : getGetsRate() = " + anRom.getGetsPerSecTrend().size() + ", getPutsRate() = "
-                  + anRom.getPutsPerSecTrend().size() + ", getDiskGetsRate() = " + anRom.getDiskReadsPerSecTrend().size() + ", getDiskPutsRate() = "
-                  + anRom.getDiskWritesPerSecTrend().size());
-
-              //remove existing member names from list so only new ones will remain
-              memberNames.remove(anRom.getMemberName());
-
-              break;
-            }
-          }
-        }
-
-        LOGGER.fine("updateRegionOnMembers : Loop over remaining member names and adding new member in region. Existing count = " + regionOnMemberList.size());
-        LOGGER.fine("updateRegionOnMembers : Remaining new members in this region = " + memberNames.size());
-        //loop over the remaining regions members and add new members for this region
-        for(String memberName : memberNames) {
-          String objectNameROM = PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObjectName + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + memberName;
-          ObjectName regionOnMemberMBean = new ObjectName(objectNameROM);
-          Cluster.RegionOnMember regionOnMember = new Cluster.RegionOnMember();
-          regionOnMember.setMemberName(memberName);
-          regionOnMember.setRegionFullPath(regionFullPath);
-          AttributeList attributeList = this.mbs.getAttributes(regionOnMemberMBean, PulseConstants.REGION_ON_MEMBER_MBEAN_ATTRIBUTES);
-          for (int i = 0; i < attributeList.size(); i++) {
-            Attribute attribute = (Attribute) attributeList.get(i);
-            String name=attribute.getName();
-            switch (name){
-            case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
-              regionOnMember.setEntrySize(getLongAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_ENTRYCOUNT:
-              regionOnMember.setEntryCount(getLongAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
-              regionOnMember.setPutsRate(getDoubleAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
-              regionOnMember.setGetsRate(getDoubleAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-              regionOnMember.setDiskGetsRate(getDoubleAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-              regionOnMember.setDiskPutsRate(getDoubleAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            case PulseConstants.MBEAN_ATTRIBUTE_LOCALMAXMEMORY:
-              regionOnMember.setLocalMaxMemory(getIntegerAttribute(attribute.getValue(),
-                  attribute.getName()));
-              break;
-            }
-          }
-
-          regionOnMember.getGetsPerSecTrend().add(regionOnMember.getGetsRate());
-          regionOnMember.getPutsPerSecTrend().add(regionOnMember.getPutsRate());
-          regionOnMember.getDiskReadsPerSecTrend().add(regionOnMember.getDiskGetsRate());
-          regionOnMember.getDiskWritesPerSecTrend().add(regionOnMember.getDiskPutsRate());
-
-          LOGGER.fine("updateRegionOnMembers : Adding New member on region : getGetsRate() = " + regionOnMember.getGetsRate() + ", getPutsRate() = "
-              + regionOnMember.getPutsRate() + ", getDiskGetsRate() = " + regionOnMember.getDiskGetsRate() + ", getDiskPutsRate() = "
-              + regionOnMember.getDiskPutsRate());
-
-          regionOnMemberListNew.add(regionOnMember);
-        }
-
-        //set region on member
-        region.setRegionOnMembers(regionOnMemberListNew);
-        LOGGER.fine("updateRegionOnMembers : Total regions on member in region " + region.getFullPath() + " after update = " + region.getRegionOnMembers().length);
-    } catch (MalformedObjectNameException e) {
-      LOGGER.warning(e);
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    }
-  }
-
-  /**
-   * function used to get attribute values of Cluster Region and map them to
-   * cluster region vo
-   *
-   * @param mbeanName
-   *          Cluster Region MBean
-   */
-  private void updateClusterRegion(ObjectName mbeanName) throws IOException {
-
-    try {
-
-      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-          PulseConstants.REGION_MBEAN_ATTRIBUTES);
-
-      // retrieve the full path of the region
-      String regionObjectName = mbeanName.getKeyProperty("name");
-      String regionFullPath = null;
-      for (int i = 0; i < attributeList.size(); i++) {
-        Attribute attribute = (Attribute) attributeList.get(i);
-
-        if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_FULLPATH)) {
-          regionFullPath = getStringAttribute(attribute.getValue(),
-              attribute.getName());
-          break;
-        }
-      }
-
-      Cluster.Region region = cluster.getClusterRegions().get(regionFullPath);
-
-      if (null == region) {
-        region = new Cluster.Region();
-      }
-
-      for (int i = 0; i < attributeList.size(); i++) {
-
-        Attribute attribute = (Attribute) attributeList.get(i);
-
-        String name = attribute.getName();
-        switch (name){
-        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERS:
-          String memName[] = (String[]) attribute.getValue();
-          region.getMemberName().clear();
-          for (int k = 0; k < memName.length; k++) {
-            region.getMemberName().add(memName[k]);
-          }
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_FULLPATH:
-          region.setFullPath(getStringAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-          region.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-          region.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_EMPTYNODES:
-          region.setEmptyNode(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
-          region.setGetsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_LRUEVICTIONRATE:
-          region.setLruEvictionRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
-          region.setPutsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_REGIONTYPE:
-          region.setRegionType(getStringAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
-          region.setEntrySize(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT:
-          region.setSystemRegionEntryCount(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERCOUNT:
-          region.setMemberCount(getIntegerAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_PERSISTENTENABLED:
-          region.setPersistentEnabled(getBooleanAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NAME:
-          region.setName(getStringAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_GATEWAYENABLED:
-          region.setWanEnabled(getBooleanAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKUSAGE:
-          region.setDiskUsage(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        }
-      }
-
-      //add for each member
-      updateRegionOnMembers(regionObjectName, regionFullPath, region);
-
-      cluster.addClusterRegion(regionFullPath, region);
-      cluster.getDeletedRegions().remove(region.getFullPath());
-      // Memory Reads and writes
-      region.getPutsPerSecTrend().add(region.getPutsRate());
-      region.getGetsPerSecTrend().add(region.getGetsRate());
-      // Disk Reads and Writes
-      region.getDiskReadsPerSecTrend().add(region.getDiskReadsRate());
-      region.getDiskWritesPerSecTrend().add(region.getDiskWritesRate());
-
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    }
-  }
-
-  private static boolean isQuoted(String value) {
-    final int len = value.length();
-    if (len < 2 || value.charAt(0) != '"' || value.charAt(len - 1) != '"') {
-      return false;
-    } else {
-      return true;
-    }
-  }
-
-  private void updateClusterStatement(ObjectName mbeanName) throws IOException {
-
-    try {
-
-      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-          PulseConstants.STATEMENT_MBEAN_ATTRIBUTES);
-      // retrieve the full path of the region
-      String statementDefinition = mbeanName.getKeyProperty("name");
-
-      if (isQuoted(statementDefinition)) {
-        statementDefinition = ObjectName.unquote(statementDefinition);
-      }
-
-      Cluster.Statement statement = cluster.getClusterStatements().get(
-          statementDefinition);
-
-      if (null == statement) {
-        statement = new Cluster.Statement();
-        statement.setQueryDefinition(statementDefinition);
-      }
-
-      for (int i = 0; i < attributeList.size(); i++) {
-        Attribute attribute = (Attribute) attributeList.get(i);
-        String name = attribute.getName();
-        switch (name){
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED:
-          statement.setNumTimesCompiled(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION:
-          statement.setNumExecution(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS:
-          statement.setNumExecutionsInProgress(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP:
-          statement.setNumTimesGlobalIndexLookup(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED:
-          statement.setNumRowsModified(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_PARSETIME:
-          statement.setParseTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_BINDTIME:
-          statement.setBindTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME:
-          statement.setOptimizeTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME:
-          statement.setRoutingInfoTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME:
-          statement.setGenerateTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME:
-          statement.setTotalCompilationTime(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME:
-          statement.setExecutionTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME:
-          statement.setProjectionTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME:
-          statement.setTotalExecutionTime(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME:
-          statement.setRowsModificationTime(getLongAttribute(
-              attribute.getValue(), attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN:
-          statement.setqNNumRowsSeen(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME:
-          statement.setqNMsgSendTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME:
-          statement.setqNMsgSerTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME:
-          statement.setqNRespDeSerTime(getLongAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        }
-      }
-
-      cluster.addClusterStatement(statementDefinition, statement);
-      // TODO : to store data for sparklines later
-      /*
-       * region.getPutsPerSecTrend().add(region.getPutsRate());
-       * region.getGetsPerSecTrend().add(region.getGetsRate());
-       */
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    }
-  }
-
-  /**
-   * function used to iterate through all member attributes and return the
-   * updated member
-   */
-  private Cluster.Member initializeMember(ObjectName mbeanName,
-      Cluster.Member member) throws InstanceNotFoundException,
-                                    ReflectionException, IOException {
-
-    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-        PulseConstants.MEMBER_MBEAN_ATTRIBUTES);
-
-    for (int i = 0; i < attributeList.size(); i++) {
-
-      Attribute attribute = (Attribute) attributeList.get(i);
-      String name = attribute.getName();
-      switch (name) {
-      case PulseConstants.MBEAN_ATTRIBUTE_GEMFIREVERSION:
-        if (member.getGemfireVersion() == null) {
-          // Set Member's GemFire Version if not set already
-          String gemfireVersion = obtainGemfireVersion(getStringAttribute(
-              attribute.getValue(), attribute.getName()));
-          member.setGemfireVersion(gemfireVersion);
-        }
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_MANAGER:
-        member.setManager(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONCOUNT:
-        member.setTotalRegionCount(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_LOCATOR:
-        member.setLocator(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_TOTALDISKUSAGE:
-        member.setTotalDiskUsage(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_SERVER:
-        member.setServer(getBooleanAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN:
-        member.setTotalFileDescriptorOpen(getLongAttribute(
-            attribute.getValue(), attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_LOADAVERAGE:
-        member.setLoadAverage(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-        member.setThroughputWrites(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getThroughputWritesTrend().add(member.getThroughputWrites());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-        member.setThroughputReads(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getThroughputReadsTrend().add(member.getThroughputReads());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_JVMPAUSES:
-        long trendVal = determineCurrentJVMPauses(
-            PulseConstants.JVM_PAUSES_TYPE_MEMBER, member.getName(),
-            getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.setGarbageCollectionCount(trendVal);
-        member.getGarbageCollectionSamples().add(
-            member.getGarbageCollectionCount());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_USEDMEMORY:
-        member.setCurrentHeapSize(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getHeapUsageSamples().add(member.getCurrentHeapSize());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_MAXMEMORY:
-        member.setMaxHeapSize(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_NUMTHREADS:
-        member.setNumThreads(getIntegerAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_MEMBERUPTIME:
-        member.setUptime(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_HOST:
-        member.setHost(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS:
-        member.setHostnameForClients(getStringAttribute(attribute.getValue(),
-                attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_BINDADDRESS:
-        member.setBindAddress(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_TOTALBYTESONDISK:
-        member.setTotalBytesOnDisk(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getTotalBytesOnDiskSamples().add(member.getTotalBytesOnDisk());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_CPUUSAGE:
-        member.setCpuUsage(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getCpuUsageSamples().add(member.getCpuUsage());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_HOSTCPUUSAGE:
-        // Float value is expected for host cpu usage.
-        // TODO Remove Float.valueOf() when float value is provided in mbean
-        member.setHostCpuUsage(Double.valueOf(getIntegerAttribute(
-            attribute.getValue(), attribute.getName())));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_MEMBER:
-        member.setName(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_ID:
-        member.setId(getStringAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEREADS:
-        member.setGetsRate(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getGetsPerSecond().add(member.getGetsRate());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEWRITES:
-        member.setPutsRate(getDoubleAttribute(attribute.getValue(),
-            attribute.getName()));
-        member.getPutsPerSecond().add(member.getPutsRate());
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_OFFHEAPFREESIZE:
-        member.setOffHeapFreeSize(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE:
-        member.setOffHeapUsedSize(getLongAttribute(attribute.getValue(),
-            attribute.getName()));
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_SERVERGROUPS:
-        String sgValues[] = (String[]) attribute.getValue();
-        member.getServerGroups().clear();
-        for (int k = 0; k < sgValues.length; k++) {
-          member.getServerGroups().add(sgValues[k]);
-        }
-        break;
-      case PulseConstants.MBEAN_ATTRIBUTE_REDUNDANCYZONES:
-        String rzValue = "";
-        if(null != attribute.getValue()){
-          rzValue = getStringAttribute(attribute.getValue(),
-              attribute.getName());
-        }
-        member.getRedundancyZones().clear();
-        if(!rzValue.isEmpty()){
-          member.getRedundancyZones().add(rzValue);
-        }
-        break;
-      }
-    }
-
-    // SQLFire specific attributes
-    if (PulseController.getPulseProductSupport().equalsIgnoreCase(
-        PulseConstants.PRODUCT_NAME_SQLFIRE)) {
-
-      try {
-        // get sqlfire mbeans
-        String memberName = mbeanName
-            .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-        ObjectName sfMemberMbeansObjectName = new ObjectName(
-            PulseConstants.OBJECT_NAME_SF_MEMBER_PATTERN + memberName);
-
-        Set<ObjectName> sfMemberMBeans = this.mbs.queryNames(
-            sfMemberMbeansObjectName, null);
-        for (ObjectName sfMemberMBean : sfMemberMBeans) {
-
-          AttributeList attrList = this.mbs.getAttributes(sfMemberMBean,
-              PulseConstants.SF_MEMBER_MBEAN_ATTRIBUTES);
-          for (int i = 0; i < attrList.size(); i++) {
-
-            Attribute attribute = (Attribute) attrList.get(i);
-
-            if (attribute.getName().equals(
-                PulseConstants.MBEAN_ATTRIBUTE_DATASTORE)) {
-              member.setServer(getBooleanAttribute(attribute.getValue(),
-                  attribute.getName()));
-
-              // Update Server count
-              if (member.isServer()) {
-                cluster.setServerCount(cluster.getServerCount() + 1);
-              }
-            } else if (attribute.getName().equals(
-                    PulseConstants.MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS)) {
-
-              CompositeData nscConnStats = (CompositeData) attribute.getValue();
-
-              // Update sqlfire client count
-              member.setNumSqlfireClients(getLongAttribute(nscConnStats
-                  .get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE),
-                  PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE));
-            }
-          }
-          break;
-        }
-
-      } catch (MalformedObjectNameException e) {
-        LOGGER.warning(e);
-      } catch (NullPointerException e) {
-        LOGGER.warning(e);
-      }
-
-    }
-
-    return member;
-  }
-
-  /**
-   * function used to get attribute values of Cluster Member and map them to
-   * cluster member vo
-   *
-   * @param mbeanName
-   *          Cluster Member MBean
-   */
-  private void updateClusterMember(ObjectName mbeanName) throws IOException {
-
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      Cluster.Member clusterMember = cluster.getMembersHMap().get(memberName);
-
-      if (clusterMember != null) // checking if member exists or not
-      {
-        cluster.getDeletedMembers().remove(memberName);
-      } else {
-        clusterMember = new Cluster.Member();
-        cluster.getMembersHMap().put(memberName, clusterMember);
-      }
-
-      // initialize member and add to cluster's member list
-      clusterMember = initializeMember(mbeanName, clusterMember);
-      ArrayList<Cluster.Member> memberArrList = (ArrayList<Cluster.Member>) cluster
-          .getPhysicalToMember().get(clusterMember.getHost());
-      if (memberArrList != null) {
-        if (!memberArrList.contains(clusterMember)) {
-          memberArrList.add(clusterMember);
-        }
-      } else {
-        ArrayList<Cluster.Member> memberList = new ArrayList<Cluster.Member>();
-        memberList.add(clusterMember);
-        cluster.getPhysicalToMember().put(clusterMember.getHost(), memberList);
-      }
-    } catch (InstanceNotFoundException infe) {
-      LOGGER.warning(infe);
-    } catch (ReflectionException re) {
-      LOGGER.warning(re);
-    }
-  }
-
-  /**
-   * function used to handle Float data type if the value for mbean for an
-   * attribute is null then return 0.0 as default value else return the
-   * attribute value
-   */
-  private Float getFloatAttribute(Object object, String name) {
-    if (object == null) {
-      return Float.valueOf(0.0f);
-    }
-
-    try {
-      if (!(object.getClass().equals(Float.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + Float.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return Float.valueOf(0.0f);
-      } else {
-        return (Float) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception occurred: " + e.getMessage());
-      }
-      return Float.valueOf(0.0f);
-    }
-  }
-
-  /**
-   * function used to handle Integer data type if the value for mbean for an
-   * attribute is null then return 0 as default value else return the attribute
-   * value
-   */
-  private Integer getIntegerAttribute(Object object, String name) {
-    if (object == null) {
-      return Integer.valueOf(0);
-    }
-
-    try {
-      if (!(object.getClass().equals(Integer.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + Integer.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return Integer.valueOf(0);
-      } else {
-        return (Integer) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception occurred: " + e.getMessage());
-      }
-      return Integer.valueOf(0);
-    }
-  }
-
-  /**
-   * function used to handle Long data type if the value for mbean for an
-   * attribute is null then return 0 as default value else return the attribute
-   * value
-   */
-  private Long getLongAttribute(Object object, String name) {
-    if (object == null) {
-      return Long.valueOf(0);
-    }
-
-    try {
-      if (!(object.getClass().equals(Long.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + Long.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return Long.valueOf(0);
-      } else {
-        return (Long) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception occurred: " + e.getMessage());
-      }
-      return Long.valueOf(0);
-    }
-
-  }
-
-  /**
-   * function used to handle String data type if the value for mbean for an
-   * attribute is null then return the empty string as default value else return
-   * the attribute value
-   */
-  private String getStringAttribute(Object object, String name) {
-    if (object == null) {
-      return "";
-    }
-
-    try {
-      if (!(object.getClass().equals(String.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + String.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return "";
-      } else {
-        return (String) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception occurred: " + e.getMessage());
-      }
-      return "";
-    }
-  }
-
-  /**
-   * function used to handle Boolean data type if the value for mbean for an
-   * attribute is null then return false as default value else return the
-   * attribute value
-   */
-  private Boolean getBooleanAttribute(Object object, String name) {
-    if (object == null) {
-      return Boolean.FALSE;
-    }
-
-    try {
-      if (!(object.getClass().equals(Boolean.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + Boolean.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return Boolean.FALSE;
-      } else {
-        return (Boolean) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception Occured: " + e.getMessage());
-      }
-      return Boolean.FALSE;
-    }
-  }
-
-  /**
-   * function used to handle Double data type if the value for mbean for an
-   * attribute is null then return 0.0 as default value else return the
-   * attribute value
-   */
-  private Double getDoubleAttribute(Object object, String name) {
-    if (object == null) {
-      return Double.valueOf(0);
-    }
-
-    try {
-      if (!(object.getClass().equals(Double.class))) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("************************Unexpected type for attribute: "
-              + name + " Expected type: " + Double.class.getName()
-              + " Received type: " + object.getClass().getName()
-              + "************************");
-        }
-        return Double.valueOf(0);
-      } else {
-        return (Double) object;
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("Exception occurred: " + e.getMessage());
-      }
-      return Double.valueOf(0);
-    }
-  }
-
-  /**
-   * function used to get attribute values of Member Region and map them to
-   * Member vo
-   *
-   * @param mbeanName
-   *          Member Region MBean
-   */
-  private void updateMemberRegion(ObjectName mbeanName) throws IOException {
-
-    try {
-      String memberName = mbeanName
-          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
-
-      Cluster.Member member = cluster.getMembersHMap().get(memberName);
-
-      //Following attributes are not present in 9.0
-      //"Members"
-      //"EmptyNodes"
-      //"SystemRegionEntryCount"
-      //"MemberCount"
-      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
-          PulseConstants.REGION_MBEAN_ATTRIBUTES);
-
-      // retrieve the full path of the region
-      String regionFullPathKey = null;
-      for (int i = 0; i < attributeList.size(); i++) {
-        Attribute attribute = (Attribute) attributeList.get(i);
-
-        if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_FULLPATH)) {
-          regionFullPathKey = getStringAttribute(attribute.getValue(),
-              attribute.getName());
-          break;
-        }
-      }
-
-      // if member does not exists defined for this region then create a member
-      if (null == member) {
-        member = new Cluster.Member();
-        member.setName(memberName);
-        cluster.getMembersHMap().put(memberName, member);
-      }
-
-      // if region with given path exists then update same else add new region
-      Cluster.Region region = member.getMemberRegions().get(regionFullPathKey);
-      if (null == region) {
-        region = new Cluster.Region();
-        member.getMemberRegions().put(regionFullPathKey, region);
-        member.setTotalRegionCount(member.getTotalRegionCount() + 1);
-      }
-      region.setFullPath(regionFullPathKey); // use already retrieved values
-
-      // update the existing or new region
-      for (int i = 0; i < attributeList.size(); i++) {
-        Attribute attribute = (Attribute) attributeList.get(i);
-        String name = attribute.getName();
-        switch (name){
-        case PulseConstants.MBEAN_ATTRIBUTE_FULLPATH:
-          region.setFullPath(getStringAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
-          region.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
-          region.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
-          region.setGetsRate(getDoubleAttribute(attribute.getValue(),
-              attribute.getName()));
-          break;
-        case PulseCon

<TRUNCATED>


[67/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JmxManagerFinder.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JmxManagerFinder.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JmxManagerFinder.java
new file mode 100644
index 0000000..f8dbcf9
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JmxManagerFinder.java
@@ -0,0 +1,169 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import java.io.DataInputStream;
+import java.io.DataOutputStream;
+import java.io.IOException;
+import java.net.InetAddress;
+import java.net.InetSocketAddress;
+import java.net.Socket;
+import java.net.SocketAddress;
+
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.ConnectionUtil;
+
+/**
+ * This class can be used to connect to a locator and ask it to find a jmx
+ * manager. If the locator can find a jmx manager that is already running it
+ * returns it. Otherwise the locator will attempt to start a jmx manager and
+ * then return it.
+ * 
+ * This code does not depend on gemfire.jar but in order to do this some of
+ * GemFire's internal serialization codes and byte sequences have been hard
+ * coded into this code.
+ * 
+ * @since GemFire version 7.0.Beta 2012-09-23
+ * 
+ */
+public class JmxManagerFinder {
+
+  private final static PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+
+  /*
+   * public static void main(String[] args) throws IOException { if (args.length
+   * != 2) { System.err.println(
+   * "Usage: JmxManagerFinder locatorHost locatorPort. Expected two arguments but found "
+   * + args.length); return; } String locatorHost = args[0]; int locatorPort =
+   * Integer.parseInt(args[1]);
+   * 
+   * InetAddress addr = InetAddress.getByName(locatorHost); JmxManagerInfo
+   * locRes = askLocatorForJmxManager(addr, locatorPort, 15000);
+   * 
+   * if (locRes.port == 0) {
+   * System.out.println("Locator could not find a jmx manager"); } else {
+   * System.out.println("Locator on host " + locRes.host + " port " +
+   * locRes.port + (locRes.ssl ? " ssl" : "")); } }
+   */
+  private static final short JMX_MANAGER_LOCATOR_REQUEST = 2150;
+  private static final short JMX_MANAGER_LOCATOR_RESPONSE = 2151;
+  private static final byte DS_FIXED_ID_SHORT = 2;
+  private static final int GOSSIPVERSION = 1001;
+  private static final byte STRING_BYTES = 87;
+  private static final byte NULL_STRING = 69;
+
+  /**
+   * Describes the location of a jmx manager. If a jmx manager does not exist
+   * then port will be 0.
+   * 
+   * 
+   */
+  public static class JmxManagerInfo {
+    JmxManagerInfo(String host, int port, boolean ssl) {
+      this.host = host;
+      this.port = port;
+      this.ssl = ssl;
+    }
+
+    /**
+     * The host/address the jmx manager is listening on.
+     */
+    public final String host;
+    /**
+     * The port the jmx manager is listening on.
+     */
+    public final int port;
+    /**
+     * True if the jmx manager is using SSL.
+     */
+    public final boolean ssl;
+  }
+
+  /**
+   * Ask a locator to find a jmx manager. The locator will start one if one is
+   * not already running.
+   * 
+   * @param addr
+   *          the host address the locator is listening on
+   * @param port
+   *          the port the locator is listening on
+   * @param timeout
+   *          the number of milliseconds to wait for a response; 15000 is a
+   *          reasonable default
+   * @return describes the location of the jmx manager. The port will be zero if
+   *         no jmx manager was found.
+   * @throws IOException
+   *           if a problem occurs trying to connect to the locator or
+   *           communicate with it.
+   */
+  public static JmxManagerInfo askLocatorForJmxManager(InetAddress addr,
+      int port, int timeout, boolean usessl) throws IOException {
+    SocketAddress sockaddr = new InetSocketAddress(addr, port);
+    Socket sock = ConnectionUtil.getSocketFactory(usessl).createSocket();
+    try {
+      sock.connect(sockaddr, timeout);
+      sock.setSoTimeout(timeout);
+      DataOutputStream out = new DataOutputStream(sock.getOutputStream());
+
+      out.writeInt(GOSSIPVERSION);
+      out.writeByte(DS_FIXED_ID_SHORT);
+      out.writeShort(JMX_MANAGER_LOCATOR_REQUEST);
+      out.flush();
+
+      DataInputStream in = new DataInputStream(sock.getInputStream());
+      byte header = in.readByte();
+      if (header != DS_FIXED_ID_SHORT) {
+        throw new IllegalStateException("Expected " + DS_FIXED_ID_SHORT
+            + " but found " + header);
+      }
+      int msgType = in.readShort();
+      if (msgType != JMX_MANAGER_LOCATOR_RESPONSE) {
+        throw new IllegalStateException("Expected "
+            + JMX_MANAGER_LOCATOR_RESPONSE + " but found " + msgType);
+      }
+      byte hostHeader = in.readByte();
+      String host;
+      if (hostHeader == NULL_STRING) {
+        host = "";
+      } else if (hostHeader == STRING_BYTES) {
+        int len = in.readUnsignedShort();
+        byte[] buf = new byte[len];
+        in.readFully(buf, 0, len);
+        @SuppressWarnings("deprecation")
+        String str = new String(buf, 0);
+        host = str;
+      } else {
+        throw new IllegalStateException("Expected " + STRING_BYTES + " or "
+            + NULL_STRING + " but found " + hostHeader);
+      }
+      int jmport = in.readInt();
+      boolean ssl = in.readBoolean();
+      if (host.equals("")) {
+        jmport = 0;
+      }
+      return new JmxManagerInfo(host, jmport, ssl);
+    } finally {
+      try {
+        sock.close();
+      } catch (Exception e) {
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConfig.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConfig.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConfig.java
new file mode 100644
index 0000000..a0b279b
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConfig.java
@@ -0,0 +1,139 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import java.util.logging.Level;
+
+/**
+ * Class PulseConfig
+ * 
+ * PulseConfig is used for configuring Pulse application.
+ * 
+ * @since GemFire 7.0.1
+ * 
+ */
+public class PulseConfig {
+
+  // Log file name
+  private String LogFileName;
+
+  // Log file location
+  private String LogFileLocation;
+
+  // Log file size in MBs
+  private int logFileSize;
+
+  // Number of cyclic log files
+  private int logFileCount;
+
+  // Log messages date pattern
+  private String logDatePattern;
+
+  // Log level
+  private Level logLevel;
+
+  // Flag for appending log messages
+  private Boolean logAppend;
+
+  // Query history log file
+  private String queryHistoryFileName;
+
+  public PulseConfig() {
+    this.setLogFileName(PulseConstants.PULSE_LOG_FILE_NAME);
+    this.LogFileLocation = PulseConstants.PULSE_LOG_FILE_LOCATION;
+    this.logFileSize = PulseConstants.PULSE_LOG_FILE_SIZE;
+    this.logFileCount = PulseConstants.PULSE_LOG_FILE_COUNT;
+    this.logDatePattern = PulseConstants.PULSE_LOG_MESSAGE_DATE_PATTERN;
+    this.logLevel = PulseConstants.PULSE_LOG_LEVEL;
+    this.logAppend = PulseConstants.PULSE_LOG_APPEND;
+    this.queryHistoryFileName = PulseConstants.PULSE_QUERY_HISTORY_FILE_LOCATION
+      + System.getProperty("file.separator")
+      + PulseConstants.PULSE_QUERY_HISTORY_FILE_NAME;
+
+  }
+
+  public String getLogFileName() {
+    return LogFileName;
+  }
+
+  public void setLogFileName(String logFileName) {
+    this.LogFileName = logFileName + "_%g.log";
+  }
+
+  public String getLogFileLocation() {
+    return LogFileLocation;
+  }
+
+  public void setLogFileLocation(String logFileLocation) {
+    this.LogFileLocation = logFileLocation;
+  }
+
+  public String getLogFileFullName() {
+    return this.LogFileLocation + "/" + this.LogFileName;
+  }
+
+  public int getLogFileSize() {
+    return logFileSize;
+  }
+
+  public void setLogFileSize(int logFileSize) {
+    this.logFileSize = logFileSize;
+  }
+
+  public int getLogFileCount() {
+    return logFileCount;
+  }
+
+  public void setLogFileCount(int logFileCount) {
+    this.logFileCount = logFileCount;
+  }
+
+  public String getLogDatePattern() {
+    return logDatePattern;
+  }
+
+  public void setLogDatePattern(String logDatePattern) {
+    this.logDatePattern = logDatePattern;
+  }
+
+  public Level getLogLevel() {
+    return logLevel;
+  }
+
+  public void setLogLevel(Level logLevel) {
+    this.logLevel = logLevel;
+  }
+
+  public Boolean getLogAppend() {
+    return logAppend;
+  }
+
+  public void setLogAppend(Boolean logAppend) {
+    this.logAppend = logAppend;
+  }
+
+  public String getQueryHistoryFileName() {
+    return queryHistoryFileName;
+  }
+
+  public void setQueryHistoryFileName(String queryHistoryFileName) {
+    this.queryHistoryFileName = queryHistoryFileName;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConstants.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConstants.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConstants.java
new file mode 100644
index 0000000..9da8248
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseConstants.java
@@ -0,0 +1,434 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import java.util.logging.Level;
+
+public class PulseConstants {
+
+  public static final String APP_NAME = "PULSE";
+  public static final String PULSE_LOG_FILE = APP_NAME + ".log";
+  // public static final String PULSE_LOG_FILE_LOCATION =
+  // System.getProperty("user.home");
+  public static final String PULSE_PROPERTIES_FILE = "pulse.properties";
+  public static final String PULSE_SECURITY_PROPERTIES_FILE = "pulsesecurity.properties";
+  public static final String PULSE_NOTIFICATION_ALERT_DATE_PATTERN = "yyyy-MM-dd'T'HH:mm'Z'";
+  public static final String LOG_MESSAGE_DATE_PATTERN = "yyyy/MM/dd HH:mm:ss.SSS z";
+
+  public static final String LOG_MESSAGES_FILE = "LogMessages";
+  public static final String APPLICATION_LANGUAGE = "en";
+  public static final String APPLICATION_COUNTRY = "US";
+
+  // Pulse version details properties from properties file
+  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";
+  public static final String PROPERTY_SOURCE_REVISION = "Source-Revision";
+  public static final String PROPERTY_SOURCE_REPOSITORY = "Source-Repository";
+
+  // DEFAULT CONFIGUARTION VALUES FOR PULSE LOGGER
+  // Log File
+  public static final String PULSE_QUERY_HISTORY_FILE_NAME = APP_NAME
+      + "_QueryHistory.json";
+  // Log File location
+  public static final String PULSE_QUERY_HISTORY_FILE_LOCATION = System
+      .getProperty("user.home");
+  // Date pattern to be used in log messages
+  public static final String PULSE_QUERY_HISTORY_DATE_PATTERN = "EEE, MMM dd yyyy, HH:mm:ss z";
+
+  // Decimal format pattern "###.##" and "0.0000"
+  public static final String DECIMAL_FORMAT_PATTERN = "###.##";
+  public static final String DECIMAL_FORMAT_PATTERN_2 = "0.0000";
+
+  // DEFAULT VALUES
+  public static final String GEMFIRE_DEFAULT_HOST = "localhost";
+  public static final String GEMFIRE_DEFAULT_PORT = "1099";
+
+  // DEFAULT CONFIGUARTION VALUES FOR PULSE LOGGER
+  // Log File
+  public static final String PULSE_LOG_FILE_NAME = APP_NAME;
+  // Log File location
+  public static final String PULSE_LOG_FILE_LOCATION = System
+      .getProperty("user.home");
+  // Date pattern to be used in log messages
+  public static final String PULSE_LOG_MESSAGE_DATE_PATTERN = "yyyy/MM/dd HH:mm:ss.SSS z";
+  // Log file size - 1MB.
+  public static final int PULSE_LOG_FILE_SIZE = 1024 * 1024;
+  // The log file count - 4 files.
+  public static final int PULSE_LOG_FILE_COUNT = 4;
+  // Append logs - true.
+  public static final boolean PULSE_LOG_APPEND = true;
+  // Log level - FINE
+  public static final Level PULSE_LOG_LEVEL = Level.FINE;
+
+  // SYSTEM PROPERTIES
+  public static final String SYSTEM_PROPERTY_PULSE_EMBEDDED = "pulse.embedded";
+  public static final String SYSTEM_PROPERTY_PULSE_EMBEDDED_SQLF = "pulse.embedded.sqlf";
+  public static final String SYSTEM_PROPERTY_PULSE_USELOCATOR = "pulse.useLocator";
+  public static final String SYSTEM_PROPERTY_PULSE_HOST = "pulse.host";
+  public static final String SYSTEM_PROPERTY_PULSE_PORT = "pulse.port";
+
+  // APPLICATION PROPERTIES
+  public static final String APPLICATION_PROPERTY_PULSE_USELOCATOR = "pulse.useLocator";
+  public static final String APPLICATION_PROPERTY_PULSE_HOST = "pulse.host";
+  public static final String APPLICATION_PROPERTY_PULSE_PORT = "pulse.port";
+  public static final String APPLICATION_PROPERTY_PULSE_JMXUSERNAME = "pulse.jmxUserName";
+  public static final String APPLICATION_PROPERTY_PULSE_JMXPASSWORD = "pulse.jmxUserPassword";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGFILENAME = "pulse.Log-File-Name";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGFILELOCATION = "pulse.Log-File-Location";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGFILESIZE = "pulse.Log-File-Size";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGFILECOUNT = "pulse.Log-File-Count";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN = "pulse.Log-Date-Pattern";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGLEVEL = "pulse.Log-Level";
+  public static final String APPLICATION_PROPERTY_PULSE_LOGAPPEND = "pulse.Log-Append";
+  public static final String APPLICATION_PROPERTY_PULSE_PRODUCTSUPPORT = "pulse.product";
+  public static final String APPLICATION_PROPERTY_PULSE_SEC_PROFILE_GEMFIRE = "pulse.authentication.gemfire";
+  public static final String APPLICATION_PROPERTY_PULSE_SEC_PROFILE_DEFAULT = "pulse.authentication.default";
+  public static final String APPLICATION_PROPERTY_PULSE_SPRING_PROFILE_KEY = "spring.profiles.default";
+
+  // STRING FLAGS
+  public static final String STRING_FLAG_TRUE = "true";
+  public static final String STRING_FLAG_FALSE = "false";
+  public static final String DEFAULT_SERVER_GROUP = "Default";
+  public static final String DEFAULT_REDUNDANCY_ZONE = "Default";
+  public static final String JVM_PAUSES_TYPE_CLUSTER = "cluster";
+  public static final String JVM_PAUSES_TYPE_MEMBER = "member";
+
+  // CONSTANTS FOR MBEAN DATA
+  public static final String OBJECT_DOMAIN_NAME_GEMFIRE = "GemFire";
+  public static final String OBJECT_DOMAIN_NAME_SQLFIRE = "GemFireXD";
+  public static final String OBJECT_NAME_MEMBER = OBJECT_DOMAIN_NAME_GEMFIRE + ":type=Member,*";
+  public static final String OBJECT_NAME_MEMBER_MANAGER = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Manager,type=Member,*";
+  public static final String OBJECT_NAME_SYSTEM_DISTRIBUTED = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=System,type=Distributed";
+  public static final String OBJECT_NAME_REGION_DISTRIBUTED = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Region,type=Distributed,*";
+  public static final String OBJECT_NAME_STATEMENT_DISTRIBUTED = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Statement,type=Aggregate,*";
+  public static final String OBJECT_NAME_SF_CLUSTER = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Cluster";
+  public static final String OBJECT_NAME_SF_MEMBER_PATTERN = OBJECT_DOMAIN_NAME_SQLFIRE + ":group=*,type=Member,member=";
+  public static final String OBJECT_NAME_TABLE_AGGREGATE = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Table,type=Aggregate,table=*";
+  public static final String OBJECT_NAME_TABLE_AGGREGATE_PATTERN = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Table,type=Aggregate,table=";
+  public static final String OBJECT_NAME_REGION_ON_MEMBER_REGION = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Region,name=";
+  public static final String OBJECT_NAME_REGION_ON_MEMBER_MEMBER = ",type=Member,member=";
+  public static final String OBJECT_NAME_ACCESSCONTROL_MBEAN = "GemFire:service=AccessControl,type=Distributed";
+
+  public static final String MBEAN_KEY_PROPERTY_SERVICE = "service";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_REGION = "Region";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_CACHESERVER = "CacheServer";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYRECEIVER = "GatewayReceiver";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYSENDER = "GatewaySender";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_ASYNCEVENTQUEUE = "AsyncEventQueue";
+  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_LOCATOR = "Locator";
+  public static final String MBEAN_KEY_PROPERTY_REGION_NAME = "name";
+
+  public static final String MBEAN_KEY_PROPERTY_MEMBER = "member";
+
+  public static final String MBEAN_ATTRIBUTE_MEMBER = "Member";
+  public static final String MBEAN_ATTRIBUTE_MEMBERS = "Members";
+  public static final String MBEAN_ATTRIBUTE_MANAGER = "Manager";
+  public static final String MBEAN_ATTRIBUTE_LOCATOR = "Locator";
+  public static final String MBEAN_ATTRIBUTE_SERVER = "Server";
+  public static final String MBEAN_ATTRIBUTE_SERVERGROUPS = "Groups";
+  public static final String MBEAN_ATTRIBUTE_REDUNDANCYZONES = "RedundancyZone";
+  public static final String MBEAN_ATTRIBUTE_DATASTORE = "DataStore";
+  public static final String MBEAN_ATTRIBUTE_ID = "Id";
+
+  public static final String MBEAN_ATTRIBUTE_GEMFIREVERSION = "Version";
+  public static final String MBEAN_ATTRIBUTE_MEMBERCOUNT = "MemberCount";
+  public static final String MBEAN_ATTRIBUTE_NUMCLIENTS = "NumClients";
+  public static final String MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS = "NetworkServerClientConnectionStats";
+  public static final String MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID = "DistributedSystemId";
+  public static final String MBEAN_ATTRIBUTE_LOCATORCOUNT = "LocatorCount";
+  public static final String MBEAN_ATTRIBUTE_TOTALREGIONCOUNT = "TotalRegionCount";
+  public static final String MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION = "NumRunningFunctions";
+  public static final String MBEAN_ATTRIBUTE_PROCEDURECALLSCOMPLETED = "ProcedureCallsCompleted";
+  public static final String MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS = "ProcedureCallsInProgress";
+  public static final String MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT = "RegisteredCQCount";
+  public static final String MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS = "NumSubscriptions";
+  public static final String MBEAN_ATTRIBUTE_NUMTXNCOMMITTED = "TransactionCommitted";
+  public static final String MBEAN_ATTRIBUTE_NUMTXNROLLBACK = "TransactionRolledBack";
+  public static final String MBEAN_ATTRIBUTE_TOTALHEAPSIZE = "TotalHeapSize";
+  public static final String MBEAN_ATTRIBUTE_USEDHEAPSIZE = "UsedHeapSize";
+  public static final String MBEAN_ATTRIBUTE_OFFHEAPFREESIZE = "OffHeapFreeSize";
+  public static final String MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE = "OffHeapUsedSize";
+  public static final String MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT = "TotalRegionEntryCount";
+  public static final String MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT = "CurrentQueryCount";
+  public static final String MBEAN_ATTRIBUTE_TOTALDISKUSAGE = "TotalDiskUsage";
+  public static final String MBEAN_ATTRIBUTE_DISKWRITESRATE = "DiskWritesRate";
+  public static final String MBEAN_ATTRIBUTE_AVERAGEWRITES = "AverageWrites";
+  public static final String MBEAN_ATTRIBUTE_DISKREADSRATE = "DiskReadsRate";
+  public static final String MBEAN_ATTRIBUTE_AVERAGEREADS = "AverageReads";
+  public static final String MBEAN_ATTRIBUTE_QUERYREQUESTRATE = "QueryRequestRate";
+  public static final String MBEAN_ATTRIBUTE_JVMPAUSES = "JVMPauses";
+  public static final String MBEAN_ATTRIBUTE_HOST = "Host";
+  public static final String MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS = "HostnameForClients";
+  public static final String MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT = "HostNameForClients";
+  public static final String MBEAN_ATTRIBUTE_BINDADDRESS = "BindAddress";
+  public static final String MBEAN_ATTRIBUTE_PORT = "Port";
+  public static final String MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE = "EventsReceivedRate";
+  public static final String MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME = "AverageBatchProcessingTime";
+  public static final String MBEAN_ATTRIBUTE_RUNNING = "Running";
+  public static final String MBEAN_ATTRIBUTE_BATCHSIZE = "BatchSize";
+  public static final String MBEAN_ATTRIBUTE_SENDERID = "SenderId";
+  public static final String MBEAN_ATTRIBUTE_EVENTQUEUESIZE = "EventQueueSize";
+  public static final String MBEAN_ATTRIBUTE_PRIMARY = "Primary";
+  public static final String MBEAN_ATTRIBUTE_PERSISTENCEENABLED = "PersistenceEnabled";
+  public static final String MBEAN_ATTRIBUTE_PARALLEL = "Parallel";
+  public static final String MBEAN_ATTRIBUTE_REMOTE_DS_ID = "RemoteDSId";
+  public static final String MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD = "EventsExceedingAlertThreshold";
+  public static final String MBEAN_ATTRIBUTE_FULLPATH = "FullPath";
+  public static final String MBEAN_ATTRIBUTE_EMPTYNODES = "EmptyNodes";
+  public static final String MBEAN_ATTRIBUTE_GETSRATE = "GetsRate";
+  public static final String MBEAN_ATTRIBUTE_PUTSRATE = "PutsRate";
+  public static final String MBEAN_ATTRIBUTE_LRUEVICTIONRATE = "LruEvictionRate";
+  public static final String MBEAN_ATTRIBUTE_REGIONTYPE = "RegionType";
+  public static final String MBEAN_ATTRIBUTE_ENTRYSIZE = "EntrySize";
+  public static final String MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT = "SystemRegionEntryCount";
+  public static final String MBEAN_ATTRIBUTE_PERSISTENTENABLED = "PersistentEnabled";
+  public static final String MBEAN_ATTRIBUTE_NAME = "Name";
+  public static final String MBEAN_ATTRIBUTE_GATEWAYENABLED = "GatewayEnabled";
+  public static final String MBEAN_ATTRIBUTE_DISKUSAGE = "DiskUsage";
+  public static final String MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN = "TotalFileDescriptorOpen";
+  public static final String MBEAN_ATTRIBUTE_LOADAVERAGE = "LoadAverage";
+  public static final String MBEAN_ATTRIBUTE_CURRENTHEAPSIZE = "CurrentHeapSize"; // deprecated in Gemfire8.1
+  public static final String MBEAN_ATTRIBUTE_USEDMEMORY = "UsedMemory";
+  public static final String MBEAN_ATTRIBUTE_MAXIMUMHEAPSIZE = "MaximumHeapSize"; // deprecated in Gemfire8.1
+  public static final String MBEAN_ATTRIBUTE_MAXMEMORY = "MaxMemory";
+  public static final String MBEAN_ATTRIBUTE_NUMTHREADS = "NumThreads";
+  public static final String MBEAN_ATTRIBUTE_MEMBERUPTIME = "MemberUpTime";
+  public static final String MBEAN_ATTRIBUTE_TOTALBYTESONDISK = "TotalBytesOnDisk";
+  public static final String MBEAN_ATTRIBUTE_CPUUSAGE = "CpuUsage";
+  public static final String MBEAN_ATTRIBUTE_HOSTCPUUSAGE = "HostCpuUsage";
+  public static final String MBEAN_ATTRIBUTE_ENTRYCOUNT = "EntryCount";
+  public static final String MBEAN_ATTRIBUTE_NUMBEROFROWS = "NumberOfRows";
+  public static final String MBEAN_ATTRIBUTE_LOCALMAXMEMORY = "LocalMaxMemory";
+
+  public static final String MBEAN_ATTRIBUTE_NUMTIMESCOMPILED = "NumTimesCompiled";
+  public static final String MBEAN_ATTRIBUTE_NUMEXECUTION = "NumExecution";
+  public static final String MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS = "NumExecutionsInProgress";
+  public static final String MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP = "NumTimesGlobalIndexLookup";
+  public static final String MBEAN_ATTRIBUTE_NUMROWSMODIFIED = "NumRowsModified";
+  public static final String MBEAN_ATTRIBUTE_PARSETIME = "ParseTime";
+  public static final String MBEAN_ATTRIBUTE_BINDTIME = "BindTime";
+  public static final String MBEAN_ATTRIBUTE_OPTIMIZETIME = "OptimizeTime";
+  public static final String MBEAN_ATTRIBUTE_ROUTINGINFOTIME = "RoutingInfoTime";
+  public static final String MBEAN_ATTRIBUTE_GENERATETIME = "GenerateTime";
+  public static final String MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME = "TotalCompilationTime";
+  public static final String MBEAN_ATTRIBUTE_EXECUTIONTIME = "ExecutionTime";
+  public static final String MBEAN_ATTRIBUTE_PROJECTIONTIME = "ProjectionTime";
+  public static final String MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME = "TotalExecutionTime";
+  public static final String MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME = "RowsModificationTime";
+  public static final String MBEAN_ATTRIBUTE_QNNUMROWSSEEN = "QNNumRowsSeen";
+  public static final String MBEAN_ATTRIBUTE_QNMSGSENDTIME = "QNMsgSendTime";
+  public static final String MBEAN_ATTRIBUTE_QNMSGSERTIME = "QNMsgSerTime";
+  public static final String MBEAN_ATTRIBUTE_QNRESPDESERTIME = "QNRespDeSerTime";
+  public static final String MBEAN_ATTRIBUTE_QUERYDEFINITION = "Query";
+
+  public static final String MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID = "Id";
+  public static final String MBEAN_ATTRIBUTE_AEQ_PRIMARY = "Primary";
+  public static final String MBEAN_ATTRIBUTE_AEQ_PARALLEL = "Parallel";
+  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE = "BatchSize";
+  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL = "BatchTimeInterval";
+  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED = "BatchConflationEnabled";
+  public static final String MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER = "AsyncEventListener";
+  public static final String MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE = "EventQueueSize";
+
+  // column names
+  public static final String MBEAN_COLNAME_NUMTIMESCOMPILED = "NumTimesCompiled";
+  public static final String MBEAN_COLNAME_NUMEXECUTION = "NumExecution";
+  public static final String MBEAN_COLNAME_NUMEXECUTIONSINPROGRESS = "NumExecutionsInProgress";
+  public static final String MBEAN_COLNAME_NUMTIMESGLOBALINDEXLOOKUP = "NumTimesGlobalIndexLookup";
+  public static final String MBEAN_COLNAME_NUMROWSMODIFIED = "NumRowsModified";
+  public static final String MBEAN_COLNAME_PARSETIME = "ParseTime(ms)";
+  public static final String MBEAN_COLNAME_BINDTIME = "BindTime(ms)";
+  public static final String MBEAN_COLNAME_OPTIMIZETIME = "OptimizeTime(ms)";
+  public static final String MBEAN_COLNAME_ROUTINGINFOTIME = "RoutingInfoTime(ms)";
+  public static final String MBEAN_COLNAME_GENERATETIME = "GenerateTime(ms)";
+  public static final String MBEAN_COLNAME_TOTALCOMPILATIONTIME = "TotalCompilationTime(ms)";
+  public static final String MBEAN_COLNAME_EXECUTIONTIME = "ExecutionTime(ns)";
+  public static final String MBEAN_COLNAME_PROJECTIONTIME = "ProjectionTime(ns)";
+  public static final String MBEAN_COLNAME_TOTALEXECUTIONTIME = "TotalExecutionTime(ns)";
+  public static final String MBEAN_COLNAME_ROWSMODIFICATIONTIME = "RowsModificationTime(ns)";
+  public static final String MBEAN_COLNAME_QNNUMROWSSEEN = "QNNumRowsSeen";
+  public static final String MBEAN_COLNAME_QNMSGSENDTIME = "QNMsgSendTime(ns)";
+  public static final String MBEAN_COLNAME_QNMSGSERTIME = "QNMsgSerTime(ns)";
+  public static final String MBEAN_COLNAME_QNRESPDESERTIME = "QNRespDeSerTime(ns)";
+  public static final String MBEAN_COLNAME_QUERYDEFINITION = "Query";
+
+  // TODO : add attributes for aggregate statistics
+  // public static final String MBEAN_ATTRIBUTE_ENTRYCOUNT = "EntryCount";
+
+  public static final String MBEAN_MANAGER_ATTRIBUTE_PULSEURL = "PulseURL";
+
+  public static final String MBEAN_OPERATION_LISTCACHESERVER = "listCacheServers";
+  public static final String MBEAN_OPERATION_LISTSERVERS = "listServers";
+  public static final String MBEAN_OPERATION_VIEWREMOTECLUSTERSTATUS = "viewRemoteClusterStatus";
+  public static final String MBEAN_OPERATION_SHOWALLCLIENTS = "showAllClientStats";
+  public static final String MBEAN_OPERATION_LISTREGIONATTRIBUTES = "listRegionAttributes";
+  public static final String MBEAN_OPERATION_QUERYDATABROWSER = "queryData";
+
+  // COMPOSITE DATA KEYS
+  public static final String COMPOSITE_DATA_KEY_CLIENTID = "clientId";
+  public static final String COMPOSITE_DATA_KEY_NAME = "name";
+  public static final String COMPOSITE_DATA_KEY_HOSTNAME = "hostName";
+  public static final String COMPOSITE_DATA_KEY_QUEUESIZE = "queueSize";
+  public static final String COMPOSITE_DATA_KEY_PROCESSCPUTIME = "processCpuTime";
+  public static final String COMPOSITE_DATA_KEY_UPTIME = "upTime";
+  public static final String COMPOSITE_DATA_KEY_NUMOFTHREADS = "numOfThreads";
+  public static final String COMPOSITE_DATA_KEY_NUMOFGETS = "numOfGets";
+  public static final String COMPOSITE_DATA_KEY_NUMOFPUTS = "numOfPuts";
+  public static final String COMPOSITE_DATA_KEY_CPUS = "cpus";
+  public static final String COMPOSITE_DATA_KEY_CLIENTCQCOUNT = "clientCQCount"; 
+  public static final String COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED = "subscriptionEnabled"; 
+  public static final String COMPOSITE_DATA_KEY_SCOPE = "scope";
+  public static final String COMPOSITE_DATA_KEY_DISKSTORENAME = "diskStoreName";
+  public static final String COMPOSITE_DATA_KEY_DISKSYNCHRONOUS = "diskSynchronous";
+  public static final String COMPOSITE_DATA_KEY_COMPRESSIONCODEC = "compressionCodec";
+  public static final String COMPOSITE_DATA_KEY_ENABLEOFFHEAPMEMORY = "enableOffHeapMemory";
+  public static final String COMPOSITE_DATA_KEY_CONNECTIONSACTIVE = "connectionsActive";
+  public static final String COMPOSITE_DATA_KEY_CONNECTED = "connected";
+
+  public static final String ALERT_DESC_SEVERE = "Severe Alert! The cluster is on fire !";
+  public static final String ALERT_DESC_ERROR = "Error Alert! There is a problem with your cluster ! Better fix it !";
+  public static final String ALERT_DESC_WARNING = "Warning Alert! Look at this cluster after you finish your coffee !";
+  public static final String ALERT_DESC_INFO = "Info Alert! For your kind information !";
+
+  public static final String NOTIFICATION_TYPE_SYSTEM_ALERT = "system.alert";
+  public static final String NOTIFICATION_TYPE_CACHE_MEMBER_DEPARTED = "gemfire.distributedsystem.cache.member.departed";
+  public static final String NOTIFICATION_TYPE_REGION_DESTROYED = "gemfire.distributedsystem.cache.region.closed";
+
+  public static final String PRODUCT_NAME_GEMFIRE = "gemfire"; // For GemFire
+  public static final String PRODUCT_NAME_SQLFIRE = "gemfirexd"; // For SQLFire
+
+  //Following attributes are not present in 9.0
+  //"Members"
+  //"EmptyNodes"
+  //"SystemRegionEntryCount"
+  //"MemberCount"
+  public static final String[] REGION_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_MEMBERS, MBEAN_ATTRIBUTE_FULLPATH,
+      MBEAN_ATTRIBUTE_DISKREADSRATE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
+      MBEAN_ATTRIBUTE_EMPTYNODES, MBEAN_ATTRIBUTE_GETSRATE,
+      MBEAN_ATTRIBUTE_LRUEVICTIONRATE, MBEAN_ATTRIBUTE_PUTSRATE,
+      MBEAN_ATTRIBUTE_REGIONTYPE, MBEAN_ATTRIBUTE_ENTRYSIZE,
+      MBEAN_ATTRIBUTE_ENTRYCOUNT, MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT,
+      MBEAN_ATTRIBUTE_MEMBERCOUNT, MBEAN_ATTRIBUTE_PERSISTENTENABLED,
+      MBEAN_ATTRIBUTE_NAME, MBEAN_ATTRIBUTE_GATEWAYENABLED,
+      MBEAN_ATTRIBUTE_DISKUSAGE, MBEAN_ATTRIBUTE_LOCALMAXMEMORY };
+
+  public static final String[] CLUSTER_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_MEMBERCOUNT, MBEAN_ATTRIBUTE_NUMCLIENTS,
+      MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID, MBEAN_ATTRIBUTE_LOCATORCOUNT,
+      MBEAN_ATTRIBUTE_TOTALREGIONCOUNT, MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION,
+      MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT, MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS,
+      MBEAN_ATTRIBUTE_NUMTXNCOMMITTED, MBEAN_ATTRIBUTE_NUMTXNROLLBACK,
+      MBEAN_ATTRIBUTE_TOTALHEAPSIZE, MBEAN_ATTRIBUTE_USEDHEAPSIZE,
+      MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT, MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT,
+      MBEAN_ATTRIBUTE_TOTALDISKUSAGE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
+      MBEAN_ATTRIBUTE_AVERAGEWRITES, MBEAN_ATTRIBUTE_AVERAGEREADS,
+      MBEAN_ATTRIBUTE_QUERYREQUESTRATE, MBEAN_ATTRIBUTE_DISKREADSRATE,
+      MBEAN_ATTRIBUTE_JVMPAUSES };
+
+  public static final String[] GATEWAY_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_PORT, MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE,
+      MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME, MBEAN_ATTRIBUTE_RUNNING };
+
+  public static final String[] GATEWAYSENDER_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE, MBEAN_ATTRIBUTE_BATCHSIZE,
+      MBEAN_ATTRIBUTE_SENDERID, MBEAN_ATTRIBUTE_EVENTQUEUESIZE,
+      MBEAN_ATTRIBUTE_RUNNING, MBEAN_ATTRIBUTE_PRIMARY,
+      MBEAN_ATTRIBUTE_PERSISTENCEENABLED, MBEAN_ATTRIBUTE_PARALLEL,
+      MBEAN_ATTRIBUTE_REMOTE_DS_ID, MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD};
+
+  public static final String[] ASYNC_EVENT_QUEUE_MBEAN_ATTRIBUTES = {
+    MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID, MBEAN_ATTRIBUTE_AEQ_PRIMARY,
+    MBEAN_ATTRIBUTE_AEQ_PARALLEL, MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE,
+    MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL, MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED,
+    MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER, MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE};
+
+  public static final String[] MEMBER_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_MANAGER, MBEAN_ATTRIBUTE_TOTALREGIONCOUNT,
+      MBEAN_ATTRIBUTE_LOCATOR, MBEAN_ATTRIBUTE_TOTALDISKUSAGE,
+      MBEAN_ATTRIBUTE_SERVER, MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN,
+      MBEAN_ATTRIBUTE_LOADAVERAGE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
+      MBEAN_ATTRIBUTE_DISKREADSRATE, MBEAN_ATTRIBUTE_JVMPAUSES,
+      MBEAN_ATTRIBUTE_USEDMEMORY, MBEAN_ATTRIBUTE_MAXMEMORY,
+      MBEAN_ATTRIBUTE_NUMTHREADS, MBEAN_ATTRIBUTE_MEMBERUPTIME,
+      MBEAN_ATTRIBUTE_HOST, MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS,
+      MBEAN_ATTRIBUTE_BINDADDRESS, MBEAN_ATTRIBUTE_TOTALBYTESONDISK,
+      MBEAN_ATTRIBUTE_CPUUSAGE, MBEAN_ATTRIBUTE_HOSTCPUUSAGE,
+      MBEAN_ATTRIBUTE_MEMBER, MBEAN_ATTRIBUTE_ID, MBEAN_ATTRIBUTE_AVERAGEREADS,
+      MBEAN_ATTRIBUTE_AVERAGEWRITES, MBEAN_ATTRIBUTE_OFFHEAPFREESIZE,
+      MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE, MBEAN_ATTRIBUTE_SERVERGROUPS,
+      MBEAN_ATTRIBUTE_REDUNDANCYZONES, MBEAN_ATTRIBUTE_GEMFIREVERSION };
+
+  public static final String[] STATEMENT_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_NAME, MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
+      MBEAN_ATTRIBUTE_NUMEXECUTION, MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
+      MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
+      MBEAN_ATTRIBUTE_NUMROWSMODIFIED, MBEAN_ATTRIBUTE_PARSETIME,
+      MBEAN_ATTRIBUTE_BINDTIME, MBEAN_ATTRIBUTE_OPTIMIZETIME,
+      MBEAN_ATTRIBUTE_ROUTINGINFOTIME, MBEAN_ATTRIBUTE_GENERATETIME,
+      MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME, MBEAN_ATTRIBUTE_EXECUTIONTIME,
+      MBEAN_ATTRIBUTE_PROJECTIONTIME, MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
+      MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME, MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
+      MBEAN_ATTRIBUTE_QNMSGSENDTIME, MBEAN_ATTRIBUTE_QNMSGSERTIME };
+
+  public static final String[] REGION_ON_MEMBER_MBEAN_ATTRIBUTES = {
+    MBEAN_ATTRIBUTE_ENTRYSIZE,
+    MBEAN_ATTRIBUTE_ENTRYCOUNT,
+    MBEAN_ATTRIBUTE_PUTSRATE,
+    MBEAN_ATTRIBUTE_GETSRATE,
+    MBEAN_ATTRIBUTE_DISKREADSRATE,
+    MBEAN_ATTRIBUTE_DISKWRITESRATE,
+    MBEAN_ATTRIBUTE_LOCALMAXMEMORY
+    };
+
+  public static final String[] SF_CLUSTER_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS,
+      MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS };
+
+  public static final String[] SF_MEMBER_MBEAN_ATTRIBUTES = {
+    MBEAN_ATTRIBUTE_DATASTORE,
+    MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS };
+
+  public static final String[] SF_TABLE_MBEAN_ATTRIBUTES = {
+      MBEAN_ATTRIBUTE_ENTRYSIZE, MBEAN_ATTRIBUTE_NUMBEROFROWS };
+  
+  public static final String PULSE_ROLES[] = {
+    "CLUSTER:READ",
+    "DATA:READ"
+  };
+
+  // SSL Related attributes
+
+  public static final String SSL_KEYSTORE = "javax.net.ssl.keyStore";
+  public static final String SSL_KEYSTORE_PASSWORD = "javax.net.ssl.keyStorePassword";
+  public static final String SSL_TRUSTSTORE = "javax.net.ssl.trustStore";
+  public static final String SSL_TRUSTSTORE_PASSWORD = "javax.net.ssl.trustStorePassword";
+  public static final String SSL_ENABLED_CIPHERS = "javax.rmi.ssl.client.enabledCipherSuites";
+  public static final String SSL_ENABLED_PROTOCOLS = "javax.rmi.ssl.client.enabledProtocols";
+
+  public static final String SYSTEM_PROPERTY_PULSE_USESSL_LOCATOR = "pulse.useSSL.locator";
+  public static final String SYSTEM_PROPERTY_PULSE_USESSL_MANAGER = "pulse.useSSL.manager";
+
+  public static final String REQUEST_PARAM_REGION_FULL_PATH = "regionFullPath";
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseVersion.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseVersion.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseVersion.java
new file mode 100644
index 0000000..23e4895
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/PulseVersion.java
@@ -0,0 +1,103 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import java.util.ResourceBundle;
+
+/**
+ * Class PulseVersion
+ * 
+ * This class is for holding Pulse Applications Version's details (like version
+ * details, build details, source details, etc) from properties file
+ * 
+ * @since GemFire version Helios
+ */
+
+public class PulseVersion {
+
+  private String pulseVersion;
+
+  public String getPulseVersion() {
+    return pulseVersion;
+  }
+
+  public void setPulseVersion(String pulseVersion) {
+    this.pulseVersion = pulseVersion;
+  }
+
+  private String pulseBuildId;
+
+  public String getPulseBuildId() {
+    return pulseBuildId;
+  }
+
+  public void setPulseBuildId(String pulseBuildId) {
+    this.pulseBuildId = pulseBuildId;
+  }
+
+  private String pulseBuildDate;
+
+  public String getPulseBuildDate() {
+    return pulseBuildDate;
+  }
+
+  public void setPulseBuildDate(String pulseBuildDate) {
+    this.pulseBuildDate = pulseBuildDate;
+  }
+
+  private String pulseSourceDate;
+
+  public String getPulseSourceDate() {
+    return pulseSourceDate;
+  }
+
+  public void setPulseSourceDate(String pulseSourceDate) {
+    this.pulseSourceDate = pulseSourceDate;
+  }
+
+  private String pulseSourceRevision;
+
+  public String getPulseSourceRevision() {
+    return pulseSourceRevision;
+  }
+
+  public void setPulseSourceRevision(String pulseSourceRevision) {
+    this.pulseSourceRevision = pulseSourceRevision;
+  }
+
+  private String pulseSourceRepository;
+
+  public String getPulseSourceRepository() {
+    return pulseSourceRepository;
+  }
+
+  public void setPulseSourceRepository(String pulseSourceRepository) {
+    this.pulseSourceRepository = pulseSourceRepository;
+  }
+
+  public String getPulseVersionLogMessage() {
+    ResourceBundle resourceBundle = Repository.get().getResourceBundle();
+    String logMessage = resourceBundle.getString("LOG_MSG_PULSE_VERSION") + " "
+        + this.getPulseVersion() + " " + this.getPulseBuildId() + " "
+        + this.getPulseBuildDate();
+    return logMessage;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Repository.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Repository.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Repository.java
new file mode 100644
index 0000000..be06f20
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Repository.java
@@ -0,0 +1,246 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.springframework.security.core.Authentication;
+import org.springframework.security.core.context.SecurityContextHolder;
+
+import java.net.ConnectException;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Locale;
+import java.util.Map;
+import java.util.ResourceBundle;
+
+/**
+ * A Singleton instance of the memory cache for clusters.
+ * 
+ * @since GemFire version 7.0.Beta 2012-09-23
+ */
+public class Repository {
+  private PulseLogWriter LOGGER;
+
+  private static Repository instance = new Repository();
+  private HashMap<String, Cluster> clusterMap = new HashMap<String, Cluster>();
+  private Boolean jmxUseLocator;
+  private String jmxHost;
+  private String jmxPort;
+  private String jmxUserName;
+  private String jmxUserPassword;
+  private Boolean isEmbeddedMode;
+  private boolean useSSLLocator = false;
+  private boolean useSSLManager = false;
+  private boolean useGemFireCredentials = false;
+  
+
+  private String pulseWebAppUrl;
+
+  Locale locale = new Locale(PulseConstants.APPLICATION_LANGUAGE,
+      PulseConstants.APPLICATION_COUNTRY);
+
+  private ResourceBundle resourceBundle = ResourceBundle.getBundle(
+      PulseConstants.LOG_MESSAGES_FILE, locale);
+
+  private PulseConfig pulseConfig = new PulseConfig();
+
+  private Repository() {
+
+  }
+
+  public static Repository get() {
+    return instance;
+  }
+
+  public Boolean getJmxUseLocator() {
+    return this.jmxUseLocator;
+  }
+
+  public void setJmxUseLocator(Boolean jmxUseLocator) {
+    this.jmxUseLocator = jmxUseLocator;
+  }
+
+  public String getJmxHost() {
+    return this.jmxHost;
+  }
+
+  public void setJmxHost(String jmxHost) {
+    this.jmxHost = jmxHost;
+  }
+
+  public String getJmxPort() {
+    return this.jmxPort;
+  }
+
+  public void setJmxPort(String jmxPort) {
+    this.jmxPort = jmxPort;
+  }
+
+  public String getJmxUserName() {
+    return this.jmxUserName;
+  }
+
+  public void setJmxUserName(String jmxUserName) {
+    this.jmxUserName = jmxUserName;
+  }
+
+  public String getJmxUserPassword() {
+    return this.jmxUserPassword;
+  }
+
+  public void setJmxUserPassword(String jmxUserPassword) {
+    this.jmxUserPassword = jmxUserPassword;
+  }
+
+  public Boolean getIsEmbeddedMode() {
+    return this.isEmbeddedMode;
+  }
+
+  public void setIsEmbeddedMode(Boolean isEmbeddedMode) {
+    this.isEmbeddedMode = isEmbeddedMode;
+  }
+
+  public boolean isUseSSLLocator() {
+    return useSSLLocator;
+  }
+
+  public void setUseSSLLocator(boolean useSSLLocator) {
+    this.useSSLLocator = useSSLLocator;
+  }
+
+  public boolean isUseSSLManager() {
+    return useSSLManager;
+  }
+
+  public void setUseSSLManager(boolean useSSLManager) {
+    this.useSSLManager = useSSLManager;
+  }
+
+  public String getPulseWebAppUrl() {
+    return this.pulseWebAppUrl;
+  }
+
+  public void setPulseWebAppUrl(String pulseWebAppUrl) {
+    this.pulseWebAppUrl = pulseWebAppUrl;
+  }
+
+  public PulseConfig getPulseConfig() {
+    return this.pulseConfig;
+  }
+
+  public void setPulseConfig(PulseConfig pulseConfig) {
+    this.pulseConfig = pulseConfig;
+  }
+
+  /**
+   * we're maintaining a 1:1 mapping between webapp and cluster, there is no need for a map of clusters based on the host and port
+   * We are using this clusterMap to maintain cluster for different users now.
+   * For a single-user connection to gemfire JMX, we will use the default username/password in the pulse.properties
+   * (# JMX User Properties )
+   * pulse.jmxUserName=admin
+   * pulse.jmxUserPassword=admin
+   *
+   * But for multi-user connections to gemfireJMX, i.e pulse that uses gemfire integrated security, we will need to get the username form the context
+   */
+  public Cluster getCluster() {
+    String username = null;
+    String password = null;
+    if(useGemFireCredentials) {
+      Authentication auth = SecurityContextHolder.getContext().getAuthentication();
+      if(auth!=null) {
+        username = auth.getName();
+        password = (String) auth.getCredentials();
+      }
+    }
+    else{
+      username = this.jmxUserName;
+      password = this.jmxUserPassword;
+    }
+    return this.getCluster(username, password);
+  }
+
+  public Cluster getCluster(String username, String password) {
+    synchronized (this.clusterMap) {
+      String key = username;
+      Cluster data = this.clusterMap.get(key);
+
+      LOGGER = PulseLogWriter.getLogger();
+
+      if (data == null) {
+        try {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(resourceBundle.getString("LOG_MSG_CREATE_NEW_THREAD")
+                + " : " + key);
+          }
+          data = new Cluster(this.jmxHost, this.jmxPort, username, password);
+          // Assign name to thread created
+          data.setName(PulseConstants.APP_NAME + "-" + this.jmxHost + ":" + this.jmxPort + ":" + username);
+          // Start Thread
+          data.start();
+          this.clusterMap.put(key, data);
+        } catch (ConnectException e) {
+          data = null;
+          if (LOGGER.fineEnabled()) {
+            LOGGER.fine(e.getMessage());
+          }
+        }
+      }
+      return data;
+    }
+  }
+
+  private String getClusterKey(String host, String port) {
+    return host + ":" + port;
+  }
+
+  // This method is used to remove all cluster threads
+  public void removeAllClusters() {
+
+    Iterator<Map.Entry<String, Cluster>> iter = clusterMap.entrySet()
+        .iterator();
+
+    while (iter.hasNext()) {
+      Map.Entry<String, Cluster> entry = iter.next();
+      Cluster c = entry.getValue();
+      String clusterKey = entry.getKey();
+      c.stopThread();
+      iter.remove();
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle.getString("LOG_MSG_REMOVE_THREAD") + " : "
+            + clusterKey.toString());
+      }
+    }
+  }
+
+  public ResourceBundle getResourceBundle() {
+    return this.resourceBundle;
+  }
+
+  public boolean isUseGemFireCredentials() {
+    return useGemFireCredentials;
+  }
+
+  public void setUseGemFireCredentials(boolean useGemFireCredentials) {
+    this.useGemFireCredentials = useGemFireCredentials;
+  }
+  
+  
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CDL.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CDL.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CDL.java
new file mode 100644
index 0000000..8d513e3
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CDL.java
@@ -0,0 +1,274 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+/**
+ * This provides static methods to convert comma delimited text into a
+ * JSONArray, and to covert a JSONArray into comma delimited text. Comma
+ * delimited text is a very popular format for data interchange. It is
+ * understood by most database, spreadsheet, and organizer programs.
+ * <p>
+ * Each row of text represents a row in a table or a data record. Each row
+ * ends with a NEWLINE character. Each row contains one or more values.
+ * Values are separated by commas. A value can contain any character except
+ * for comma, unless is is wrapped in single quotes or double quotes.
+ * <p>
+ * The first row usually contains the names of the columns.
+ * <p>
+ * A comma delimited list can be converted into a JSONArray of JSONObjects.
+ * The names for the elements in the JSONObjects can be taken from the names
+ * in the first row.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class CDL {
+
+    /**
+     * Get the next value. The value can be wrapped in quotes. The value can
+     * be empty.
+     * @param x A JSONTokener of the source text.
+     * @return The value string, or null if empty.
+     * @throws JSONException if the quoted string is badly formed.
+     */
+    private static String getValue(JSONTokener x) throws JSONException {
+        char c;
+        char q;
+        StringBuffer sb;
+        do {
+            c = x.next();
+        } while (c == ' ' || c == '\t');
+        switch (c) {
+        case 0:
+            return null;
+        case '"':
+        case '\'':
+            q = c;
+            sb = new StringBuffer();
+            for (;;) {
+                c = x.next();
+                if (c == q) {
+                    break;
+                }
+                if (c == 0 || c == '\n' || c == '\r') {
+                    throw x.syntaxError("Missing close quote '" + q + "'.");
+                }
+                sb.append(c);
+            }
+            return sb.toString();
+        case ',':
+            x.back();
+            return "";
+        default:
+            x.back();
+            return x.nextTo(',');
+        }
+    }
+
+    /**
+     * Produce a JSONArray of strings from a row of comma delimited values.
+     * @param x A JSONTokener of the source text.
+     * @return A JSONArray of strings.
+     * @throws JSONException
+     */
+    public static JSONArray rowToJSONArray(JSONTokener x) throws JSONException {
+        JSONArray ja = new JSONArray();
+        for (;;) {
+            String value = getValue(x);
+            char c = x.next();
+            if (value == null || 
+                    (ja.length() == 0 && value.length() == 0 && c != ',')) {
+                return null;
+            }
+            ja.put(value);
+            for (;;) {                
+                if (c == ',') {
+                    break;
+                }
+                if (c != ' ') {
+                    if (c == '\n' || c == '\r' || c == 0) {
+                        return ja;
+                    }
+                    throw x.syntaxError("Bad character '" + c + "' (" +
+                            (int)c + ").");
+                }
+                c = x.next();
+            }
+        }
+    }
+
+    /**
+     * Produce a JSONObject from a row of comma delimited text, using a
+     * parallel JSONArray of strings to provides the names of the elements.
+     * @param names A JSONArray of names. This is commonly obtained from the
+     *  first row of a comma delimited text file using the rowToJSONArray
+     *  method.
+     * @param x A JSONTokener of the source text.
+     * @return A JSONObject combining the names and values.
+     * @throws JSONException
+     */
+    public static JSONObject rowToJSONObject(JSONArray names, JSONTokener x)
+            throws JSONException {
+        JSONArray ja = rowToJSONArray(x);
+        return ja != null ? ja.toJSONObject(names) :  null;
+    }
+
+    /**
+     * Produce a comma delimited text row from a JSONArray. Values containing
+     * the comma character will be quoted. Troublesome characters may be 
+     * removed.
+     * @param ja A JSONArray of strings.
+     * @return A string ending in NEWLINE.
+     */
+    public static String rowToString(JSONArray ja) {
+        StringBuffer sb = new StringBuffer();
+        for (int i = 0; i < ja.length(); i += 1) {
+            if (i > 0) {
+                sb.append(',');
+            }
+            Object object = ja.opt(i);
+            if (object != null) {
+                String string = object.toString();
+                if (string.length() > 0 && (string.indexOf(',') >= 0 || 
+                        string.indexOf('\n') >= 0 || string.indexOf('\r') >= 0 || 
+                        string.indexOf(0) >= 0 || string.charAt(0) == '"')) {
+                    sb.append('"');
+                    int length = string.length();
+                    for (int j = 0; j < length; j += 1) {
+                        char c = string.charAt(j);
+                        if (c >= ' ' && c != '"') {
+                            sb.append(c);
+                        }
+                    }
+                    sb.append('"');
+                } else {
+                    sb.append(string);
+                }
+            }
+        }
+        sb.append('\n');
+        return sb.toString();
+    }
+
+    /**
+     * Produce a JSONArray of JSONObjects from a comma delimited text string,
+     * using the first row as a source of names.
+     * @param string The comma delimited text.
+     * @return A JSONArray of JSONObjects.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(String string) throws JSONException {
+        return toJSONArray(new JSONTokener(string));
+    }
+
+    /**
+     * Produce a JSONArray of JSONObjects from a comma delimited text string,
+     * using the first row as a source of names.
+     * @param x The JSONTokener containing the comma delimited text.
+     * @return A JSONArray of JSONObjects.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(JSONTokener x) throws JSONException {
+        return toJSONArray(rowToJSONArray(x), x);
+    }
+
+    /**
+     * Produce a JSONArray of JSONObjects from a comma delimited text string
+     * using a supplied JSONArray as the source of element names.
+     * @param names A JSONArray of strings.
+     * @param string The comma delimited text.
+     * @return A JSONArray of JSONObjects.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(JSONArray names, String string)
+            throws JSONException {
+        return toJSONArray(names, new JSONTokener(string));
+    }
+
+    /**
+     * Produce a JSONArray of JSONObjects from a comma delimited text string
+     * using a supplied JSONArray as the source of element names.
+     * @param names A JSONArray of strings.
+     * @param x A JSONTokener of the source text.
+     * @return A JSONArray of JSONObjects.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(JSONArray names, JSONTokener x)
+            throws JSONException {
+        if (names == null || names.length() == 0) {
+            return null;
+        }
+        JSONArray ja = new JSONArray();
+        for (;;) {
+            JSONObject jo = rowToJSONObject(names, x);
+            if (jo == null) {
+                break;
+            }
+            ja.put(jo);
+        }
+        if (ja.length() == 0) {
+            return null;
+        }
+        return ja;
+    }
+
+
+    /**
+     * Produce a comma delimited text from a JSONArray of JSONObjects. The
+     * first row will be a list of names obtained by inspecting the first
+     * JSONObject.
+     * @param ja A JSONArray of JSONObjects.
+     * @return A comma delimited text.
+     * @throws JSONException
+     */
+    public static String toString(JSONArray ja) throws JSONException {
+        JSONObject jo = ja.optJSONObject(0);
+        if (jo != null) {
+            JSONArray names = jo.names();
+            if (names != null) {
+                return rowToString(names) + toString(names, ja);
+            }
+        }
+        return null;
+    }
+
+    /**
+     * Produce a comma delimited text from a JSONArray of JSONObjects using
+     * a provided list of names. The list of names is not included in the
+     * output.
+     * @param names A JSONArray of strings.
+     * @param ja A JSONArray of JSONObjects.
+     * @return A comma delimited text.
+     * @throws JSONException
+     */
+    public static String toString(JSONArray names, JSONArray ja)
+            throws JSONException {
+        if (names == null || names.length() == 0) {
+            return null;
+        }
+        StringBuffer sb = new StringBuffer();
+        for (int i = 0; i < ja.length(); i += 1) {
+            JSONObject jo = ja.optJSONObject(i);
+            if (jo != null) {
+                sb.append(rowToString(jo.toJSONArray(names)));
+            }
+        }
+        return sb.toString();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/Cookie.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/Cookie.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/Cookie.java
new file mode 100644
index 0000000..a1250bf
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/Cookie.java
@@ -0,0 +1,164 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+/**
+ * Convert a web browser cookie specification to a JSONObject and back.
+ * JSON and Cookies are both notations for name/value pairs.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class Cookie {
+
+    /**
+     * Produce a copy of a string in which the characters '+', '%', '=', ';'
+     * and control characters are replaced with "%hh". This is a gentle form
+     * of URL encoding, attempting to cause as little distortion to the
+     * string as possible. The characters '=' and ';' are meta characters in
+     * cookies. By convention, they are escaped using the URL-encoding. This is
+     * only a convention, not a standard. Often, cookies are expected to have
+     * encoded values. We encode '=' and ';' because we must. We encode '%' and
+     * '+' because they are meta characters in URL encoding.
+     * @param string The source string.
+     * @return       The escaped result.
+     */
+    public static String escape(String string) {
+        char         c;
+        String       s = string.trim();
+        StringBuffer sb = new StringBuffer();
+        int          length = s.length();
+        for (int i = 0; i < length; i += 1) {
+            c = s.charAt(i);
+            if (c < ' ' || c == '+' || c == '%' || c == '=' || c == ';') {
+                sb.append('%');
+                sb.append(Character.forDigit((char)((c >>> 4) & 0x0f), 16));
+                sb.append(Character.forDigit((char)(c & 0x0f), 16));
+            } else {
+                sb.append(c);
+            }
+        }
+        return sb.toString();
+    }
+
+
+    /**
+     * Convert a cookie specification string into a JSONObject. The string
+     * will contain a name value pair separated by '='. The name and the value
+     * will be unescaped, possibly converting '+' and '%' sequences. The
+     * cookie properties may follow, separated by ';', also represented as
+     * name=value (except the secure property, which does not have a value).
+     * The name will be stored under the key "name", and the value will be
+     * stored under the key "value". This method does not do checking or
+     * validation of the parameters. It only converts the cookie string into
+     * a JSONObject.
+     * @param string The cookie specification string.
+     * @return A JSONObject containing "name", "value", and possibly other
+     *  members.
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(String string) throws JSONException {
+        String         name;
+        JSONObject     jo = new JSONObject();
+        Object         value;
+        JSONTokener x = new JSONTokener(string);
+        jo.put("name", x.nextTo('='));
+        x.next('=');
+        jo.put("value", x.nextTo(';'));
+        x.next();
+        while (x.more()) {
+            name = unescape(x.nextTo("=;"));
+            if (x.next() != '=') {
+                if (name.equals("secure")) {
+                    value = Boolean.TRUE;
+                } else {
+                    throw x.syntaxError("Missing '=' in cookie parameter.");
+                }
+            } else {
+                value = unescape(x.nextTo(';'));
+                x.next();
+            }
+            jo.put(name, value);
+        }
+        return jo;
+    }
+
+
+    /**
+     * Convert a JSONObject into a cookie specification string. The JSONObject
+     * must contain "name" and "value" members.
+     * If the JSONObject contains "expires", "domain", "path", or "secure"
+     * members, they will be appended to the cookie specification string.
+     * All other members are ignored.
+     * @param jo A JSONObject
+     * @return A cookie specification string
+     * @throws JSONException
+     */
+    public static String toString(JSONObject jo) throws JSONException {
+        StringBuffer sb = new StringBuffer();
+
+        sb.append(escape(jo.getString("name")));
+        sb.append("=");
+        sb.append(escape(jo.getString("value")));
+        if (jo.has("expires")) {
+            sb.append(";expires=");
+            sb.append(jo.getString("expires"));
+        }
+        if (jo.has("domain")) {
+            sb.append(";domain=");
+            sb.append(escape(jo.getString("domain")));
+        }
+        if (jo.has("path")) {
+            sb.append(";path=");
+            sb.append(escape(jo.getString("path")));
+        }
+        if (jo.optBoolean("secure")) {
+            sb.append(";secure");
+        }
+        return sb.toString();
+    }
+
+    /**
+     * Convert <code>%</code><i>hh</i> sequences to single characters, and
+     * convert plus to space.
+     * @param string A string that may contain
+     *      <code>+</code>&nbsp;<small>(plus)</small> and
+     *      <code>%</code><i>hh</i> sequences.
+     * @return The unescaped string.
+     */
+    public static String unescape(String string) {
+        int length = string.length();
+        StringBuffer sb = new StringBuffer();
+        for (int i = 0; i < length; ++i) {
+            char c = string.charAt(i);
+            if (c == '+') {
+                c = ' ';
+            } else if (c == '%' && i + 2 < length) {
+                int d = JSONTokener.dehexchar(string.charAt(i + 1));
+                int e = JSONTokener.dehexchar(string.charAt(i + 2));
+                if (d >= 0 && e >= 0) {
+                    c = (char)(d * 16 + e);
+                    i += 2;
+                }
+            }
+            sb.append(c);
+        }
+        return sb.toString();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CookieList.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CookieList.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CookieList.java
new file mode 100644
index 0000000..b206efe
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/CookieList.java
@@ -0,0 +1,85 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.util.Iterator;
+
+/**
+ * Convert a web browser cookie list string to a JSONObject and back.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class CookieList {
+
+    /**
+     * Convert a cookie list into a JSONObject. A cookie list is a sequence
+     * of name/value pairs. The names are separated from the values by '='.
+     * The pairs are separated by ';'. The names and the values
+     * will be unescaped, possibly converting '+' and '%' sequences.
+     *
+     * To add a cookie to a cooklist,
+     * cookielistJSONObject.put(cookieJSONObject.getString("name"),
+     *     cookieJSONObject.getString("value"));
+     * @param string  A cookie list string
+     * @return A JSONObject
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(String string) throws JSONException {
+        JSONObject jo = new JSONObject();
+        JSONTokener x = new JSONTokener(string);
+        while (x.more()) {
+            String name = Cookie.unescape(x.nextTo('='));
+            x.next('=');
+            jo.put(name, Cookie.unescape(x.nextTo(';')));
+            x.next();
+        }
+        return jo;
+    }
+
+
+    /**
+     * Convert a JSONObject into a cookie list. A cookie list is a sequence
+     * of name/value pairs. The names are separated from the values by '='.
+     * The pairs are separated by ';'. The characters '%', '+', '=', and ';'
+     * in the names and values are replaced by "%hh".
+     * @param jo A JSONObject
+     * @return A cookie list string
+     * @throws JSONException
+     */
+    public static String toString(JSONObject jo) throws JSONException {
+        boolean      b = false;
+        Iterator     keys = jo.keys();
+        String       string;
+        StringBuffer sb = new StringBuffer();
+        while (keys.hasNext()) {
+            string = keys.next().toString();
+            if (!jo.isNull(string)) {
+                if (b) {
+                    sb.append(';');
+                }
+                sb.append(Cookie.escape(string));
+                sb.append("=");
+                sb.append(Cookie.escape(jo.getString(string)));
+                b = true;
+            }
+        }
+        return sb.toString();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTP.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTP.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTP.java
new file mode 100644
index 0000000..5fd0afa
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTP.java
@@ -0,0 +1,158 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.util.Iterator;
+
+/**
+ * Convert an HTTP header to a JSONObject and back.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class HTTP {
+
+    /** Carriage return/line feed. */
+    public static final String CRLF = "\r\n";
+
+    /**
+     * Convert an HTTP header string into a JSONObject. It can be a request
+     * header or a response header. A request header will contain
+     * <pre>{
+     *    Method: "POST" (for example),
+     *    "Request-URI": "/" (for example),
+     *    "HTTP-Version": "HTTP/1.1" (for example)
+     * }</pre>
+     * A response header will contain
+     * <pre>{
+     *    "HTTP-Version": "HTTP/1.1" (for example),
+     *    "Status-Code": "200" (for example),
+     *    "Reason-Phrase": "OK" (for example)
+     * }</pre>
+     * In addition, the other parameters in the header will be captured, using
+     * the HTTP field names as JSON names, so that <pre>
+     *    Date: Sun, 26 May 2002 18:06:04 GMT
+     *    Cookie: Q=q2=PPEAsg--; B=677gi6ouf29bn&b=2&f=s
+     *    Cache-Control: no-cache</pre>
+     * become
+     * <pre>{...
+     *    Date: "Sun, 26 May 2002 18:06:04 GMT",
+     *    Cookie: "Q=q2=PPEAsg--; B=677gi6ouf29bn&b=2&f=s",
+     *    "Cache-Control": "no-cache",
+     * ...}</pre>
+     * It does no further checking or conversion. It does not parse dates.
+     * It does not do '%' transforms on URLs.
+     * @param string An HTTP header string.
+     * @return A JSONObject containing the elements and attributes
+     * of the XML string.
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(String string) throws JSONException {
+        JSONObject     jo = new JSONObject();
+        HTTPTokener    x = new HTTPTokener(string);
+        String         token;
+
+        token = x.nextToken();
+        if (token.toUpperCase().startsWith("HTTP")) {
+
+// Response
+
+            jo.put("HTTP-Version", token);
+            jo.put("Status-Code", x.nextToken());
+            jo.put("Reason-Phrase", x.nextTo('\0'));
+            x.next();
+
+        } else {
+
+// Request
+
+            jo.put("Method", token);
+            jo.put("Request-URI", x.nextToken());
+            jo.put("HTTP-Version", x.nextToken());
+        }
+
+// Fields
+
+        while (x.more()) {
+            String name = x.nextTo(':');
+            x.next(':');
+            jo.put(name, x.nextTo('\0'));
+            x.next();
+        }
+        return jo;
+    }
+
+
+    /**
+     * Convert a JSONObject into an HTTP header. A request header must contain
+     * <pre>{
+     *    Method: "POST" (for example),
+     *    "Request-URI": "/" (for example),
+     *    "HTTP-Version": "HTTP/1.1" (for example)
+     * }</pre>
+     * A response header must contain
+     * <pre>{
+     *    "HTTP-Version": "HTTP/1.1" (for example),
+     *    "Status-Code": "200" (for example),
+     *    "Reason-Phrase": "OK" (for example)
+     * }</pre>
+     * Any other members of the JSONObject will be output as HTTP fields.
+     * The result will end with two CRLF pairs.
+     * @param jo A JSONObject
+     * @return An HTTP header string.
+     * @throws JSONException if the object does not contain enough
+     *  information.
+     */
+    public static String toString(JSONObject jo) throws JSONException {
+        Iterator     keys = jo.keys();
+        String       string;
+        StringBuffer sb = new StringBuffer();
+        if (jo.has("Status-Code") && jo.has("Reason-Phrase")) {
+            sb.append(jo.getString("HTTP-Version"));
+            sb.append(' ');
+            sb.append(jo.getString("Status-Code"));
+            sb.append(' ');
+            sb.append(jo.getString("Reason-Phrase"));
+        } else if (jo.has("Method") && jo.has("Request-URI")) {
+            sb.append(jo.getString("Method"));
+            sb.append(' ');
+            sb.append('"');
+            sb.append(jo.getString("Request-URI"));
+            sb.append('"');
+            sb.append(' ');
+            sb.append(jo.getString("HTTP-Version"));
+        } else {
+            throw new JSONException("Not enough material for an HTTP header.");
+        }
+        sb.append(CRLF);
+        while (keys.hasNext()) {
+            string = keys.next().toString();
+            if (!"HTTP-Version".equals(string)      && !"Status-Code".equals(string) &&
+                    !"Reason-Phrase".equals(string) && !"Method".equals(string) &&
+                    !"Request-URI".equals(string)   && !jo.isNull(string)) {
+                sb.append(string);
+                sb.append(": ");
+                sb.append(jo.getString(string));
+                sb.append(CRLF);
+            }
+        }
+        sb.append(CRLF);
+        return sb.toString();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTPTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTPTokener.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTPTokener.java
new file mode 100644
index 0000000..b7b7c38
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/HTTPTokener.java
@@ -0,0 +1,72 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+/**
+ * The HTTPTokener extends the JSONTokener to provide additional methods
+ * for the parsing of HTTP headers.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class HTTPTokener extends JSONTokener {
+
+    /**
+     * Construct an HTTPTokener from a string.
+     * @param string A source string.
+     */
+    public HTTPTokener(String string) {
+        super(string);
+    }
+
+
+    /**
+     * Get the next token or string. This is used in parsing HTTP headers.
+     * @throws JSONException
+     * @return A String.
+     */
+    public String nextToken() throws JSONException {
+        char c;
+        char q;
+        StringBuffer sb = new StringBuffer();
+        do {
+            c = next();
+        } while (Character.isWhitespace(c));
+        if (c == '"' || c == '\'') {
+            q = c;
+            for (;;) {
+                c = next();
+                if (c < ' ') {
+                    throw syntaxError("Unterminated string.");
+                }
+                if (c == q) {
+                    return sb.toString();
+                }
+                sb.append(c);
+            }
+        } 
+        for (;;) {
+            if (c == 0 || Character.isWhitespace(c)) {
+                return sb.toString();
+            }
+            sb.append(c);
+            c = next();
+        }
+    }
+}


[66/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONArray.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONArray.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONArray.java
new file mode 100644
index 0000000..3fe7a2d
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONArray.java
@@ -0,0 +1,901 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.io.IOException;
+import java.io.StringWriter;
+import java.io.Writer;
+import java.lang.reflect.Array;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Iterator;
+import java.util.Map;
+
+/**
+ * A JSONArray is an ordered sequence of values. Its external text form is a
+ * string wrapped in square brackets with commas separating the values. The
+ * internal form is an object having <code>get</code> and <code>opt</code>
+ * methods for accessing the values by index, and <code>put</code> methods for
+ * adding or replacing values. The values can be any of these types:
+ * <code>Boolean</code>, <code>JSONArray</code>, <code>JSONObject</code>,
+ * <code>Number</code>, <code>String</code>, or the
+ * <code>JSONObject.NULL object</code>.
+ * <p>
+ * The constructor can convert a JSON text into a Java object. The
+ * <code>toString</code> method converts to JSON text.
+ * <p>
+ * A <code>get</code> method returns a value if one can be found, and throws an
+ * exception if one cannot be found. An <code>opt</code> method returns a
+ * default value instead of throwing an exception, and so is useful for
+ * obtaining optional values.
+ * <p>
+ * The generic <code>get()</code> and <code>opt()</code> methods return an
+ * object which you can cast or query for type. There are also typed
+ * <code>get</code> and <code>opt</code> methods that do type checking and type
+ * coercion for you.
+ * <p>
+ * The texts produced by the <code>toString</code> methods strictly conform to
+ * JSON syntax rules. The constructors are more forgiving in the texts they will
+ * accept:
+ * <ul>
+ * <li>An extra <code>,</code>&nbsp;<small>(comma)</small> may appear just
+ * before the closing bracket.</li>
+ * <li>The <code>null</code> value will be inserted when there is <code>,</code>
+ * &nbsp;<small>(comma)</small> elision.</li>
+ * <li>Strings may be quoted with <code>'</code>&nbsp;<small>(single
+ * quote)</small>.</li>
+ * <li>Strings do not need to be quoted at all if they do not begin with a quote
+ * or single quote, and if they do not contain leading or trailing spaces, and
+ * if they do not contain any of these characters:
+ * <code>{ } [ ] / \ : , = ; #</code> and if they do not look like numbers and
+ * if they are not the reserved words <code>true</code>, <code>false</code>, or
+ * <code>null</code>.</li>
+ * <li>Values can be separated by <code>;</code> <small>(semicolon)</small> as
+ * well as by <code>,</code> <small>(comma)</small>.</li>
+ * </ul>
+ *
+ * @author JSON.org
+ * @version 2012-04-20
+ */
+public class JSONArray {
+
+
+    /**
+     * The arrayList where the JSONArray's properties are kept.
+     */
+    private final ArrayList myArrayList;
+
+
+    /**
+     * Construct an empty JSONArray.
+     */
+    public JSONArray() {
+        this.myArrayList = new ArrayList();
+    }
+
+    /**
+     * Construct a JSONArray from a JSONTokener.
+     * @param x A JSONTokener
+     * @throws JSONException If there is a syntax error.
+     */
+    public JSONArray(JSONTokener x) throws JSONException {
+        this();
+        if (x.nextClean() != '[') {
+            throw x.syntaxError("A JSONArray text must start with '['");
+        }
+        if (x.nextClean() != ']') {
+            x.back();
+            for (;;) {
+                if (x.nextClean() == ',') {
+                    x.back();
+                    this.myArrayList.add(JSONObject.NULL);
+                } else {
+                    x.back();
+                    this.myArrayList.add(x.nextValue());
+                }
+                switch (x.nextClean()) {
+                case ';':
+                case ',':
+                    if (x.nextClean() == ']') {
+                        return;
+                    }
+                    x.back();
+                    break;
+                case ']':
+                    return;
+                default:
+                    throw x.syntaxError("Expected a ',' or ']'");
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONArray from a source JSON text.
+     * @param source     A string that begins with
+     * <code>[</code>&nbsp;<small>(left bracket)</small>
+     *  and ends with <code>]</code>&nbsp;<small>(right bracket)</small>.
+     *  @throws JSONException If there is a syntax error.
+     */
+    public JSONArray(String source) throws JSONException {
+        this(new JSONTokener(source));
+    }
+
+
+    /**
+     * Construct a JSONArray from a Collection.
+     * @param collection     A Collection.
+     */
+    public JSONArray(Collection collection) {
+        this.myArrayList = new ArrayList();
+        if (collection != null) {
+            Iterator iter = collection.iterator();
+            while (iter.hasNext()) {
+                this.myArrayList.add(JSONObject.wrap(iter.next()));
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONArray from an array
+     * @throws JSONException If not an array.
+     */
+    public JSONArray(Object array) throws JSONException {
+        this();
+        if (array.getClass().isArray()) {
+            int length = Array.getLength(array);
+            for (int i = 0; i < length; i += 1) {
+                this.put(JSONObject.wrap(Array.get(array, i)));
+            }
+        } else {
+            throw new JSONException(
+"JSONArray initial value should be a string or collection or array.");
+        }
+    }
+
+
+    /**
+     * Get the object value associated with an index.
+     * @param index
+     *  The index must be between 0 and length() - 1.
+     * @return An object value.
+     * @throws JSONException If there is no value for the index.
+     */
+    public Object get(int index) throws JSONException {
+        Object object = this.opt(index);
+        if (object == null) {
+            throw new JSONException("JSONArray[" + index + "] not found.");
+        }
+        return object;
+    }
+
+
+    /**
+     * Get the boolean value associated with an index.
+     * The string values "true" and "false" are converted to boolean.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The truth.
+     * @throws JSONException If there is no value for the index or if the
+     *  value is not convertible to boolean.
+     */
+    public boolean getBoolean(int index) throws JSONException {
+        Object object = this.get(index);
+        if (object.equals(Boolean.FALSE) ||
+                (object instanceof String &&
+                ((String)object).equalsIgnoreCase("false"))) {
+            return false;
+        } else if (object.equals(Boolean.TRUE) ||
+                (object instanceof String &&
+                ((String)object).equalsIgnoreCase("true"))) {
+            return true;
+        }
+        throw new JSONException("JSONArray[" + index + "] is not a boolean.");
+    }
+
+
+    /**
+     * Get the double value associated with an index.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     * @throws   JSONException If the key is not found or if the value cannot
+     *  be converted to a number.
+     */
+    public double getDouble(int index) throws JSONException {
+        Object object = this.get(index);
+        try {
+            return object instanceof Number
+                ? ((Number)object).doubleValue()
+                : Double.parseDouble((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONArray[" + index +
+                "] is not a number.");
+        }
+    }
+
+
+    /**
+     * Get the int value associated with an index.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     * @throws   JSONException If the key is not found or if the value is not a number.
+     */
+    public int getInt(int index) throws JSONException {
+        Object object = this.get(index);
+        try {
+            return object instanceof Number
+                ? ((Number)object).intValue()
+                : Integer.parseInt((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONArray[" + index +
+                "] is not a number.");
+        }
+    }
+
+
+    /**
+     * Get the JSONArray associated with an index.
+     * @param index The index must be between 0 and length() - 1.
+     * @return      A JSONArray value.
+     * @throws JSONException If there is no value for the index. or if the
+     * value is not a JSONArray
+     */
+    public JSONArray getJSONArray(int index) throws JSONException {
+        Object object = this.get(index);
+        if (object instanceof JSONArray) {
+            return (JSONArray)object;
+        }
+        throw new JSONException("JSONArray[" + index +
+                "] is not a JSONArray.");
+    }
+
+
+    /**
+     * Get the JSONObject associated with an index.
+     * @param index subscript
+     * @return      A JSONObject value.
+     * @throws JSONException If there is no value for the index or if the
+     * value is not a JSONObject
+     */
+    public JSONObject getJSONObject(int index) throws JSONException {
+        Object object = this.get(index);
+        if (object instanceof JSONObject) {
+            return (JSONObject)object;
+        }
+        throw new JSONException("JSONArray[" + index +
+            "] is not a JSONObject.");
+    }
+
+
+    /**
+     * Get the long value associated with an index.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     * @throws   JSONException If the key is not found or if the value cannot
+     *  be converted to a number.
+     */
+    public long getLong(int index) throws JSONException {
+        Object object = this.get(index);
+        try {
+            return object instanceof Number
+                ? ((Number)object).longValue()
+                : Long.parseLong((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONArray[" + index +
+                "] is not a number.");
+        }
+    }
+
+
+    /**
+     * Get the string associated with an index.
+     * @param index The index must be between 0 and length() - 1.
+     * @return      A string value.
+     * @throws JSONException If there is no string value for the index.
+     */
+    public String getString(int index) throws JSONException {
+        Object object = this.get(index);
+        if (object instanceof String) {
+            return (String)object;
+        }
+        throw new JSONException("JSONArray[" + index + "] not a string.");
+    }
+
+
+    /**
+     * Determine if the value is null.
+     * @param index The index must be between 0 and length() - 1.
+     * @return true if the value at the index is null, or if there is no value.
+     */
+    public boolean isNull(int index) {
+        return JSONObject.NULL.equals(this.opt(index));
+    }
+
+
+    /**
+     * Make a string from the contents of this JSONArray. The
+     * <code>separator</code> string is inserted between each element.
+     * Warning: This method assumes that the data structure is acyclical.
+     * @param separator A string that will be inserted between the elements.
+     * @return a string.
+     * @throws JSONException If the array contains an invalid number.
+     */
+    public String join(String separator) throws JSONException {
+        int len = this.length();
+        StringBuffer sb = new StringBuffer();
+
+        for (int i = 0; i < len; i += 1) {
+            if (i > 0) {
+                sb.append(separator);
+            }
+            sb.append(JSONObject.valueToString(this.myArrayList.get(i)));
+        }
+        return sb.toString();
+    }
+
+
+    /**
+     * Get the number of elements in the JSONArray, included nulls.
+     *
+     * @return The length (or size).
+     */
+    public int length() {
+        return this.myArrayList.size();
+    }
+
+
+    /**
+     * Get the optional object value associated with an index.
+     * @param index The index must be between 0 and length() - 1.
+     * @return      An object value, or null if there is no
+     *              object at that index.
+     */
+    public Object opt(int index) {
+        return (index < 0 || index >= this.length())
+            ? null
+            : this.myArrayList.get(index);
+    }
+
+
+    /**
+     * Get the optional boolean value associated with an index.
+     * It returns false if there is no value at that index,
+     * or if the value is not Boolean.TRUE or the String "true".
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The truth.
+     */
+    public boolean optBoolean(int index)  {
+        return this.optBoolean(index, false);
+    }
+
+
+    /**
+     * Get the optional boolean value associated with an index.
+     * It returns the defaultValue if there is no value at that index or if
+     * it is not a Boolean or the String "true" or "false" (case insensitive).
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @param defaultValue     A boolean default.
+     * @return      The truth.
+     */
+    public boolean optBoolean(int index, boolean defaultValue)  {
+        try {
+            return this.getBoolean(index);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get the optional double value associated with an index.
+     * NaN is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     */
+    public double optDouble(int index) {
+        return this.optDouble(index, Double.NaN);
+    }
+
+
+    /**
+     * Get the optional double value associated with an index.
+     * The defaultValue is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     *
+     * @param index subscript
+     * @param defaultValue     The default value.
+     * @return      The value.
+     */
+    public double optDouble(int index, double defaultValue) {
+        try {
+            return this.getDouble(index);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get the optional int value associated with an index.
+     * Zero is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     */
+    public int optInt(int index) {
+        return this.optInt(index, 0);
+    }
+
+
+    /**
+     * Get the optional int value associated with an index.
+     * The defaultValue is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     * @param index The index must be between 0 and length() - 1.
+     * @param defaultValue     The default value.
+     * @return      The value.
+     */
+    public int optInt(int index, int defaultValue) {
+        try {
+            return this.getInt(index);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get the optional JSONArray associated with an index.
+     * @param index subscript
+     * @return      A JSONArray value, or null if the index has no value,
+     * or if the value is not a JSONArray.
+     */
+    public JSONArray optJSONArray(int index) {
+        Object o = this.opt(index);
+        return o instanceof JSONArray ? (JSONArray)o : null;
+    }
+
+
+    /**
+     * Get the optional JSONObject associated with an index.
+     * Null is returned if the key is not found, or null if the index has
+     * no value, or if the value is not a JSONObject.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      A JSONObject value.
+     */
+    public JSONObject optJSONObject(int index) {
+        Object o = this.opt(index);
+        return o instanceof JSONObject ? (JSONObject)o : null;
+    }
+
+
+    /**
+     * Get the optional long value associated with an index.
+     * Zero is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      The value.
+     */
+    public long optLong(int index) {
+        return this.optLong(index, 0);
+    }
+
+
+    /**
+     * Get the optional long value associated with an index.
+     * The defaultValue is returned if there is no value for the index,
+     * or if the value is not a number and cannot be converted to a number.
+     * @param index The index must be between 0 and length() - 1.
+     * @param defaultValue     The default value.
+     * @return      The value.
+     */
+    public long optLong(int index, long defaultValue) {
+        try {
+            return this.getLong(index);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get the optional string value associated with an index. It returns an
+     * empty string if there is no value at that index. If the value
+     * is not a string and is not null, then it is coverted to a string.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @return      A String value.
+     */
+    public String optString(int index) {
+        return this.optString(index, "");
+    }
+
+
+    /**
+     * Get the optional string associated with an index.
+     * The defaultValue is returned if the key is not found.
+     *
+     * @param index The index must be between 0 and length() - 1.
+     * @param defaultValue     The default value.
+     * @return      A String value.
+     */
+    public String optString(int index, String defaultValue) {
+        Object object = this.opt(index);
+        return JSONObject.NULL.equals(object)
+ ? defaultValue : object
+                .toString();
+    }
+
+
+    /**
+     * Append a boolean value. This increases the array's length by one.
+     *
+     * @param value A boolean value.
+     * @return this.
+     */
+    public JSONArray put(boolean value) {
+        this.put(value ? Boolean.TRUE : Boolean.FALSE);
+        return this;
+    }
+
+
+    /**
+     * Put a value in the JSONArray, where the value will be a
+     * JSONArray which is produced from a Collection.
+     * @param value A Collection value.
+     * @return      this.
+     */
+    public JSONArray put(Collection value) {
+        this.put(new JSONArray(value));
+        return this;
+    }
+
+
+    /**
+     * Append a double value. This increases the array's length by one.
+     *
+     * @param value A double value.
+     * @throws JSONException if the value is not finite.
+     * @return this.
+     */
+    public JSONArray put(double value) throws JSONException {
+        Double d = new Double(value);
+        JSONObject.testValidity(d);
+        this.put(d);
+        return this;
+    }
+
+
+    /**
+     * Append an int value. This increases the array's length by one.
+     *
+     * @param value An int value.
+     * @return this.
+     */
+    public JSONArray put(int value) {
+        this.put(new Integer(value));
+        return this;
+    }
+
+
+    /**
+     * Append an long value. This increases the array's length by one.
+     *
+     * @param value A long value.
+     * @return this.
+     */
+    public JSONArray put(long value) {
+        this.put(new Long(value));
+        return this;
+    }
+
+
+    /**
+     * Put a value in the JSONArray, where the value will be a
+     * JSONObject which is produced from a Map.
+     * @param value A Map value.
+     * @return      this.
+     */
+    public JSONArray put(Map value) {
+        this.put(new JSONObject(value));
+        return this;
+    }
+
+
+    /**
+     * Append an object value. This increases the array's length by one.
+     * @param value An object value.  The value should be a
+     *  Boolean, Double, Integer, JSONArray, JSONObject, Long, or String, or the
+     *  JSONObject.NULL object.
+     * @return this.
+     */
+    public JSONArray put(Object value) {
+        this.myArrayList.add(value);
+        return this;
+    }
+
+
+    /**
+     * Put or replace a boolean value in the JSONArray. If the index is greater
+     * than the length of the JSONArray, then null elements will be added as
+     * necessary to pad it out.
+     * @param index The subscript.
+     * @param value A boolean value.
+     * @return this.
+     * @throws JSONException If the index is negative.
+     */
+    public JSONArray put(int index, boolean value) throws JSONException {
+        this.put(index, value ? Boolean.TRUE : Boolean.FALSE);
+        return this;
+    }
+
+
+    /**
+     * Put a value in the JSONArray, where the value will be a
+     * JSONArray which is produced from a Collection.
+     * @param index The subscript.
+     * @param value A Collection value.
+     * @return      this.
+     * @throws JSONException If the index is negative or if the value is
+     * not finite.
+     */
+    public JSONArray put(int index, Collection value) throws JSONException {
+        this.put(index, new JSONArray(value));
+        return this;
+    }
+
+
+    /**
+     * Put or replace a double value. If the index is greater than the length of
+     *  the JSONArray, then null elements will be added as necessary to pad
+     *  it out.
+     * @param index The subscript.
+     * @param value A double value.
+     * @return this.
+     * @throws JSONException If the index is negative or if the value is
+     * not finite.
+     */
+    public JSONArray put(int index, double value) throws JSONException {
+        this.put(index, new Double(value));
+        return this;
+    }
+
+
+    /**
+     * Put or replace an int value. If the index is greater than the length of
+     *  the JSONArray, then null elements will be added as necessary to pad
+     *  it out.
+     * @param index The subscript.
+     * @param value An int value.
+     * @return this.
+     * @throws JSONException If the index is negative.
+     */
+    public JSONArray put(int index, int value) throws JSONException {
+        this.put(index, new Integer(value));
+        return this;
+    }
+
+
+    /**
+     * Put or replace a long value. If the index is greater than the length of
+     *  the JSONArray, then null elements will be added as necessary to pad
+     *  it out.
+     * @param index The subscript.
+     * @param value A long value.
+     * @return this.
+     * @throws JSONException If the index is negative.
+     */
+    public JSONArray put(int index, long value) throws JSONException {
+        this.put(index, new Long(value));
+        return this;
+    }
+
+
+    /**
+     * Put a value in the JSONArray, where the value will be a
+     * JSONObject that is produced from a Map.
+     * @param index The subscript.
+     * @param value The Map value.
+     * @return      this.
+     * @throws JSONException If the index is negative or if the the value is
+     *  an invalid number.
+     */
+    public JSONArray put(int index, Map value) throws JSONException {
+        this.put(index, new JSONObject(value));
+        return this;
+    }
+
+
+    /**
+     * Put or replace an object value in the JSONArray. If the index is greater
+     *  than the length of the JSONArray, then null elements will be added as
+     *  necessary to pad it out.
+     * @param index The subscript.
+     * @param value The value to put into the array. The value should be a
+     *  Boolean, Double, Integer, JSONArray, JSONObject, Long, or String, or the
+     *  JSONObject.NULL object.
+     * @return this.
+     * @throws JSONException If the index is negative or if the the value is
+     *  an invalid number.
+     */
+    public JSONArray put(int index, Object value) throws JSONException {
+        JSONObject.testValidity(value);
+        if (index < 0) {
+            throw new JSONException("JSONArray[" + index + "] not found.");
+        }
+        if (index < this.length()) {
+            this.myArrayList.set(index, value);
+        } else {
+            while (index != this.length()) {
+                this.put(JSONObject.NULL);
+            }
+            this.put(value);
+        }
+        return this;
+    }
+
+
+    /**
+     * Remove an index and close the hole.
+     * @param index The index of the element to be removed.
+     * @return The value that was associated with the index,
+     * or null if there was no value.
+     */
+    public Object remove(int index) {
+        Object o = this.opt(index);
+        this.myArrayList.remove(index);
+        return o;
+    }
+
+
+    /**
+     * Produce a JSONObject by combining a JSONArray of names with the values
+     * of this JSONArray.
+     * @param names A JSONArray containing a list of key strings. These will be
+     * paired with the values.
+     * @return A JSONObject, or null if there are no names or if this JSONArray
+     * has no values.
+     * @throws JSONException If any of the names are null.
+     */
+    public JSONObject toJSONObject(JSONArray names) throws JSONException {
+        if (names == null || names.length() == 0 || this.length() == 0) {
+            return null;
+        }
+        JSONObject jo = new JSONObject();
+        for (int i = 0; i < names.length(); i += 1) {
+            jo.put(names.getString(i), this.opt(i));
+        }
+        return jo;
+    }
+
+
+    /**
+     * Make a JSON text of this JSONArray. For compactness, no
+     * unnecessary whitespace is added. If it is not possible to produce a
+     * syntactically correct JSON text then null will be returned instead. This
+     * could occur if the array contains an invalid number.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     *
+     * @return a printable, displayable, transmittable
+     *  representation of the array.
+     */
+    public String toString() {
+        try {
+            return '[' + this.join(",") + ']';
+        } catch (Exception e) {
+            return null;
+        }
+    }
+
+
+    /**
+     * Make a prettyprinted JSON text of this JSONArray.
+     * Warning: This method assumes that the data structure is acyclical.
+     * @param indentFactor The number of spaces to add to each level of
+     *  indentation.
+     * @return a printable, displayable, transmittable
+     *  representation of the object, beginning
+     *  with <code>[</code>&nbsp;<small>(left bracket)</small> and ending
+     *  with <code>]</code>&nbsp;<small>(right bracket)</small>.
+     * @throws JSONException
+     */
+    public String toString(int indentFactor) throws JSONException {
+        StringWriter sw = new StringWriter();
+        synchronized (sw.getBuffer()) {
+            return this.write(sw, indentFactor, 0).toString();
+        }
+    }
+
+    /**
+     * Write the contents of the JSONArray as JSON text to a writer. For
+     * compactness, no whitespace is added.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     *
+     * @return The writer.
+     * @throws JSONException
+     */
+    public Writer write(Writer writer) throws JSONException {
+        return this.write(writer, 0, 0);
+    }
+
+    /**
+     * Write the contents of the JSONArray as JSON text to a writer. For
+     * compactness, no whitespace is added.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     *
+     * @param indentFactor
+     *            The number of spaces to add to each level of indentation.
+     * @param indent
+     *            The indention of the top level.
+     * @return The writer.
+     * @throws JSONException
+     */
+    Writer write(Writer writer, int indentFactor, int indent)
+            throws JSONException {
+        try {
+            boolean commanate = false;
+            int length = this.length();
+            writer.write('[');
+
+            if (length == 1) {
+                JSONObject.writeValue(writer, this.myArrayList.get(0),
+                        indentFactor, indent);
+            } else if (length != 0) {
+                final int newindent = indent + indentFactor;
+
+                for (int i = 0; i < length; i += 1) {
+                    if (commanate) {
+                        writer.write(',');
+                    }
+                    if (indentFactor > 0) {
+                        writer.write('\n');
+                    }
+                    JSONObject.indent(writer, newindent);
+                    JSONObject.writeValue(writer, this.myArrayList.get(i),
+                            indentFactor, newindent);
+                    commanate = true;
+                }
+                if (indentFactor > 0) {
+                    writer.write('\n');
+                }
+                JSONObject.indent(writer, indent);
+            }
+            writer.write(']');
+            return writer;
+        } catch (IOException e) {
+           throw new JSONException(e);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONException.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONException.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONException.java
new file mode 100644
index 0000000..c4cd7ad
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONException.java
@@ -0,0 +1,47 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+/**
+ * The JSONException is thrown by the JSON.org classes when things are amiss.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class JSONException extends Exception {
+    private static final long serialVersionUID = 0;
+    private Throwable cause;
+
+    /**
+     * Constructs a JSONException with an explanatory message.
+     * @param message Detail about the reason for the exception.
+     */
+    public JSONException(String message) {
+        super(message);
+    }
+
+    public JSONException(Throwable cause) {
+        super(cause.getMessage());
+        this.cause = cause;
+    }
+
+    public Throwable getCause() {
+        return this.cause;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONML.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONML.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONML.java
new file mode 100644
index 0000000..cfbbbc6
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONML.java
@@ -0,0 +1,462 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.util.Iterator;
+
+
+/**
+ * This provides static methods to convert an XML text into a JSONArray or
+ * JSONObject, and to covert a JSONArray or JSONObject into an XML text using
+ * the JsonML transform.
+ * 
+ * @author JSON.org
+ * @version 2012-03-28
+ */
+public class JSONML {
+
+    /**
+     * Parse XML values and store them in a JSONArray.
+     * @param x       The XMLTokener containing the source string.
+     * @param arrayForm true if array form, false if object form.
+     * @param ja      The JSONArray that is containing the current tag or null
+     *     if we are at the outermost level.
+     * @return A JSONArray if the value is the outermost tag, otherwise null.
+     * @throws JSONException
+     */
+    private static Object parse(
+        XMLTokener x,
+        boolean    arrayForm,
+        JSONArray  ja
+    ) throws JSONException {
+        String     attribute;
+        char       c;
+        String       closeTag = null;
+        int        i;
+        JSONArray  newja = null;
+        JSONObject newjo = null;
+        Object     token;
+        String       tagName = null;
+
+// Test for and skip past these forms:
+//      <!-- ... -->
+//      <![  ... ]]>
+//      <!   ...   >
+//      <?   ...  ?>
+
+        while (true) {
+            if (!x.more()) {
+                throw x.syntaxError("Bad XML");
+            }
+            token = x.nextContent();
+            if (token == XML.LT) {
+                token = x.nextToken();
+                if (token instanceof Character) {
+                    if (token == XML.SLASH) {
+
+// Close tag </
+
+                        token = x.nextToken();
+                        if (!(token instanceof String)) {
+                            throw new JSONException(
+                                    "Expected a closing name instead of '" +
+                                    token + "'.");
+                        }
+                        if (x.nextToken() != XML.GT) {
+                            throw x.syntaxError("Misshaped close tag");
+                        }
+                        return token;
+                    } else if (token == XML.BANG) {
+
+// <!
+
+                        c = x.next();
+                        if (c == '-') {
+                            if (x.next() == '-') {
+                                x.skipPast("-->");
+                            } else {
+                                x.back();
+                            }
+                        } else if (c == '[') {
+                            token = x.nextToken();
+                            if (token.equals("CDATA") && x.next() == '[') {
+                                if (ja != null) {
+                                    ja.put(x.nextCDATA());
+                                }
+                            } else {
+                                throw x.syntaxError("Expected 'CDATA['");
+                            }
+                        } else {
+                            i = 1;
+                            do {
+                                token = x.nextMeta();
+                                if (token == null) {
+                                    throw x.syntaxError("Missing '>' after '<!'.");
+                                } else if (token == XML.LT) {
+                                    i += 1;
+                                } else if (token == XML.GT) {
+                                    i -= 1;
+                                }
+                            } while (i > 0);
+                        }
+                    } else if (token == XML.QUEST) {
+
+// <?
+
+                        x.skipPast("?>");
+                    } else {
+                        throw x.syntaxError("Misshaped tag");
+                    }
+
+// Open tag <
+
+                } else {
+                    if (!(token instanceof String)) {
+                        throw x.syntaxError("Bad tagName '" + token + "'.");
+                    }
+                    tagName = (String)token;
+                    newja = new JSONArray();
+                    newjo = new JSONObject();
+                    if (arrayForm) {
+                        newja.put(tagName);
+                        if (ja != null) {
+                            ja.put(newja);
+                        }
+                    } else {
+                        newjo.put("tagName", tagName);
+                        if (ja != null) {
+                            ja.put(newjo);
+                        }
+                    }
+                    token = null;
+                    for (;;) {
+                        if (token == null) {
+                            token = x.nextToken();
+                        }
+                        if (token == null) {
+                            throw x.syntaxError("Misshaped tag");
+                        }
+                        if (!(token instanceof String)) {
+                            break;
+                        }
+
+// attribute = value
+
+                        attribute = (String)token;
+                        if (!arrayForm && ("tagName".equals(attribute) || "childNode".equals(attribute))) {
+                            throw x.syntaxError("Reserved attribute.");
+                        }
+                        token = x.nextToken();
+                        if (token == XML.EQ) {
+                            token = x.nextToken();
+                            if (!(token instanceof String)) {
+                                throw x.syntaxError("Missing value");
+                            }
+                            newjo.accumulate(attribute, XML.stringToValue((String)token));
+                            token = null;
+                        } else {
+                            newjo.accumulate(attribute, "");
+                        }
+                    }
+                    if (arrayForm && newjo.length() > 0) {
+                        newja.put(newjo);
+                    }
+
+// Empty tag <.../>
+
+                    if (token == XML.SLASH) {
+                        if (x.nextToken() != XML.GT) {
+                            throw x.syntaxError("Misshaped tag");
+                        }
+                        if (ja == null) {
+                            if (arrayForm) {
+                                return newja;
+                            } else {
+                                return newjo;
+                            }
+                        }
+
+// Content, between <...> and </...>
+
+                    } else {
+                        if (token != XML.GT) {
+                            throw x.syntaxError("Misshaped tag");
+                        }
+                        closeTag = (String)parse(x, arrayForm, newja);
+                        if (closeTag != null) {
+                            if (!closeTag.equals(tagName)) {
+                                throw x.syntaxError("Mismatched '" + tagName +
+                                        "' and '" + closeTag + "'");
+                            }
+                            tagName = null;
+                            if (!arrayForm && newja.length() > 0) {
+                                newjo.put("childNodes", newja);
+                            }
+                            if (ja == null) {
+                                if (arrayForm) {
+                                    return newja;
+                                } else {
+                                    return newjo;
+                                }
+                            }
+                        }
+                    }
+                }
+            } else {
+                if (ja != null) {
+                    ja.put(token instanceof String
+                        ? XML.stringToValue((String)token)
+                        : token);
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Convert a well-formed (but not necessarily valid) XML string into a
+     * JSONArray using the JsonML transform. Each XML tag is represented as
+     * a JSONArray in which the first element is the tag name. If the tag has
+     * attributes, then the second element will be JSONObject containing the
+     * name/value pairs. If the tag contains children, then strings and
+     * JSONArrays will represent the child tags.
+     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
+     * @param string The source string.
+     * @return A JSONArray containing the structured data from the XML string.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(String string) throws JSONException {
+        return toJSONArray(new XMLTokener(string));
+    }
+
+
+    /**
+     * Convert a well-formed (but not necessarily valid) XML string into a
+     * JSONArray using the JsonML transform. Each XML tag is represented as
+     * a JSONArray in which the first element is the tag name. If the tag has
+     * attributes, then the second element will be JSONObject containing the
+     * name/value pairs. If the tag contains children, then strings and
+     * JSONArrays will represent the child content and tags.
+     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
+     * @param x An XMLTokener.
+     * @return A JSONArray containing the structured data from the XML string.
+     * @throws JSONException
+     */
+    public static JSONArray toJSONArray(XMLTokener x) throws JSONException {
+        return (JSONArray)parse(x, true, null);
+    }
+
+
+    /**
+     * Convert a well-formed (but not necessarily valid) XML string into a
+     * JSONObject using the JsonML transform. Each XML tag is represented as
+     * a JSONObject with a "tagName" property. If the tag has attributes, then
+     * the attributes will be in the JSONObject as properties. If the tag
+     * contains children, the object will have a "childNodes" property which
+     * will be an array of strings and JsonML JSONObjects.
+
+     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
+     * @param x An XMLTokener of the XML source text.
+     * @return A JSONObject containing the structured data from the XML string.
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(XMLTokener x) throws JSONException {
+           return (JSONObject)parse(x, false, null);
+    }
+
+
+    /**
+     * Convert a well-formed (but not necessarily valid) XML string into a
+     * JSONObject using the JsonML transform. Each XML tag is represented as
+     * a JSONObject with a "tagName" property. If the tag has attributes, then
+     * the attributes will be in the JSONObject as properties. If the tag
+     * contains children, the object will have a "childNodes" property which
+     * will be an array of strings and JsonML JSONObjects.
+
+     * Comments, prologs, DTDs, and <code>&lt;[ [ ]]></code> are ignored.
+     * @param string The XML source text.
+     * @return A JSONObject containing the structured data from the XML string.
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(String string) throws JSONException {
+        return toJSONObject(new XMLTokener(string));
+    }
+
+
+    /**
+     * Reverse the JSONML transformation, making an XML text from a JSONArray.
+     * @param ja A JSONArray.
+     * @return An XML string.
+     * @throws JSONException
+     */
+    public static String toString(JSONArray ja) throws JSONException {
+        int             i;
+        JSONObject   jo;
+        String       key;
+        Iterator     keys;
+        int             length;
+        Object         object;
+        StringBuffer sb = new StringBuffer();
+        String       tagName;
+        String       value;
+
+// Emit <tagName
+
+        tagName = ja.getString(0);
+        XML.noSpace(tagName);
+        tagName = XML.escape(tagName);
+        sb.append('<');
+        sb.append(tagName);
+
+        object = ja.opt(1);
+        if (object instanceof JSONObject) {
+            i = 2;
+            jo = (JSONObject)object;
+
+// Emit the attributes
+
+            keys = jo.keys();
+            while (keys.hasNext()) {
+                key = keys.next().toString();
+                XML.noSpace(key);
+                value = jo.optString(key);
+                if (value != null) {
+                    sb.append(' ');
+                    sb.append(XML.escape(key));
+                    sb.append('=');
+                    sb.append('"');
+                    sb.append(XML.escape(value));
+                    sb.append('"');
+                }
+            }
+        } else {
+            i = 1;
+        }
+
+//Emit content in body
+
+        length = ja.length();
+        if (i >= length) {
+            sb.append('/');
+            sb.append('>');
+        } else {
+            sb.append('>');
+            do {
+                object = ja.get(i);
+                i += 1;
+                if (object != null) {
+                    if (object instanceof String) {
+                        sb.append(XML.escape(object.toString()));
+                    } else if (object instanceof JSONObject) {
+                        sb.append(toString((JSONObject)object));
+                    } else if (object instanceof JSONArray) {
+                        sb.append(toString((JSONArray)object));
+                    }
+                }
+            } while (i < length);
+            sb.append('<');
+            sb.append('/');
+            sb.append(tagName);
+            sb.append('>');
+        }
+        return sb.toString();
+    }
+
+    /**
+     * Reverse the JSONML transformation, making an XML text from a JSONObject.
+     * The JSONObject must contain a "tagName" property. If it has children,
+     * then it must have a "childNodes" property containing an array of objects.
+     * The other properties are attributes with string values.
+     * @param jo A JSONObject.
+     * @return An XML string.
+     * @throws JSONException
+     */
+    public static String toString(JSONObject jo) throws JSONException {
+        StringBuffer sb = new StringBuffer();
+        int          i;
+        JSONArray    ja;
+        String       key;
+        Iterator     keys;
+        int          length;
+        Object         object;
+        String       tagName;
+        String       value;
+
+//Emit <tagName
+
+        tagName = jo.optString("tagName");
+        if (tagName == null) {
+            return XML.escape(jo.toString());
+        }
+        XML.noSpace(tagName);
+        tagName = XML.escape(tagName);
+        sb.append('<');
+        sb.append(tagName);
+
+//Emit the attributes
+
+        keys = jo.keys();
+        while (keys.hasNext()) {
+            key = keys.next().toString();
+            if (!"tagName".equals(key) && !"childNodes".equals(key)) {
+                XML.noSpace(key);
+                value = jo.optString(key);
+                if (value != null) {
+                    sb.append(' ');
+                    sb.append(XML.escape(key));
+                    sb.append('=');
+                    sb.append('"');
+                    sb.append(XML.escape(value));
+                    sb.append('"');
+                }
+            }
+        }
+
+//Emit content in body
+
+        ja = jo.optJSONArray("childNodes");
+        if (ja == null) {
+            sb.append('/');
+            sb.append('>');
+        } else {
+            sb.append('>');
+            length = ja.length();
+            for (i = 0; i < length; i += 1) {
+                object = ja.get(i);
+                if (object != null) {
+                    if (object instanceof String) {
+                        sb.append(XML.escape(object.toString()));
+                    } else if (object instanceof JSONObject) {
+                        sb.append(toString((JSONObject)object));
+                    } else if (object instanceof JSONArray) {
+                        sb.append(toString((JSONArray)object));
+                    } else {
+                        sb.append(object.toString());
+                    }
+                }
+            }
+            sb.append('<');
+            sb.append('/');
+            sb.append(tagName);
+            sb.append('>');
+        }
+        return sb.toString();
+    }
+}


[08/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapIntKey.java
index 5ff06b8..9655d32 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapIntKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapLongKey.java
index c6868ea..847cb7e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapLongKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapObjectKey.java
index 6c92d90..fb87503 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapObjectKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey1.java
index 6a8d955..9166b52 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey1.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey2.java
index 363852b..cf9cf64 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapStringKey2.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapUUIDKey.java
index 5461e2d..ea24e6c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeapUUIDKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntry.java
index de8239d..dcbe372 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntry.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
-//import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.distributed.internal.DM;
+//import org.apache.geode.cache.*;
+//import org.apache.geode.distributed.internal.DM;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeap.java
index e656576..a3ae40e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapIntKey.java
index 6eb4bb9..70db2e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapIntKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapLongKey.java
index 970a7e8..18c8f43 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapLongKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapObjectKey.java
index e154981..badc8db 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapObjectKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey1.java
index 7822abf..593fb9f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey1.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey2.java
index d627873..29722ca 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapStringKey2.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapUUIDKey.java
index 072ad3c..0dcaf8a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryHeapUUIDKey.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeap.java
index a0d72d6..44533e9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapIntKey.java
index 76d7ad1..2444cc3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapIntKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapLongKey.java
index 8d6b5bb..d5f3981 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapLongKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapObjectKey.java
index 9a3c612..69848b1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapObjectKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey1.java
index f0f4385..61548b7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey1.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey2.java
index 90ed6a3..2124175 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapStringKey2.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapUUIDKey.java
index 942a5e0..160e524 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskRegionEntryOffHeapUUIDKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntry.java
index 19c6425..07fc874 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeap.java
index 186fecd..27f33e3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapIntKey.java
index 0f2a231..fd5fc82 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapIntKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapLongKey.java
index 30174b9..cceb293 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapLongKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapObjectKey.java
index 56c7f46..67bc41b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapObjectKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey1.java
index bd5ac3f..3aa36a9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey1.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey2.java
index 485bd3f..d1798bb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapStringKey2.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapUUIDKey.java
index b0ff0dd..98e5c16 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryHeapUUIDKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeap.java
index 7162f2f..8539cef 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapIntKey.java
index 49648c6..be4304a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapIntKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapLongKey.java
index 70911a9..ecca255 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapLongKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapObjectKey.java
index 88b0f46..3f25abe 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapObjectKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey1.java
index 57b39b6..840565d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey1.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey2.java
index 1a23b90..b3839ba 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapStringKey2.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapUUIDKey.java
index f866351..c0ed7c6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinLRURegionEntryOffHeapUUIDKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntry.java
index c212163..d74d604 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeap.java
index 3822b39..0f05968 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapIntKey.java
index fa6e13b..664671b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapIntKey.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapLongKey.java
index 2201fb3..c4a3cfb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapLongKey.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapObjectKey.java
index ebb700c..6b97ec1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapObjectKey.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey1.java
index c2a89c8..402f77c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey1.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey2.java
index 9c8a1d7..0275b76 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapStringKey2.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapUUIDKey.java
index ce4b47c..cdf92fb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryHeapUUIDKey.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeap.java
index 065f65d..a583715 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapIntKey.java
index 645396e..2b9a2e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapIntKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapLongKey.java
index e947584..8a869a9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapLongKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapObjectKey.java
index 89afddc..65b688f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapObjectKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey1.java
index e95414b..55dba52 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey1.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey2.java
index a78a4d6..d3e811b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapStringKey2.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapUUIDKey.java
index 45f77b1..8054b40 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinRegionEntryOffHeapUUIDKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU


[43/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentLauncher.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentLauncher.java
index dfa9ac3..c017671 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentLauncher.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentLauncher.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.File;
 import java.io.FileInputStream;
@@ -39,20 +39,20 @@ import java.util.TreeMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.jmx.Agent;
-import com.gemstone.gemfire.admin.jmx.AgentConfig;
-import com.gemstone.gemfire.admin.jmx.AgentFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.PureJavaMode;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.internal.util.JavaCommandBuilder;
+import org.apache.geode.GemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.jmx.Agent;
+import org.apache.geode.admin.jmx.AgentConfig;
+import org.apache.geode.admin.jmx.AgentFactory;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.PureJavaMode;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.internal.util.JavaCommandBuilder;
 
 /**
  * A command line utility inspired by the <code>CacheServerLauncher</code> that is responsible for administering

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
index e203f5b..e08f3a5 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/CacheServerJmxImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -34,25 +34,25 @@ import javax.naming.OperationNotSupportedException;
 import org.apache.commons.modeler.ManagedBean;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.CacheServerConfig;
-import com.gemstone.gemfire.admin.CacheVmConfig;
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.admin.StatisticResource;
-import com.gemstone.gemfire.admin.SystemMemberCache;
-import com.gemstone.gemfire.admin.SystemMemberCacheEvent;
-import com.gemstone.gemfire.admin.SystemMemberRegionEvent;
-import com.gemstone.gemfire.admin.internal.CacheServerImpl;
-import com.gemstone.gemfire.admin.internal.ConfigurationParameterImpl;
-import com.gemstone.gemfire.internal.admin.ClientMembershipMessage;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.CacheServerConfig;
+import org.apache.geode.admin.CacheVmConfig;
+import org.apache.geode.admin.ConfigurationParameter;
+import org.apache.geode.admin.StatisticResource;
+import org.apache.geode.admin.SystemMemberCache;
+import org.apache.geode.admin.SystemMemberCacheEvent;
+import org.apache.geode.admin.SystemMemberRegionEvent;
+import org.apache.geode.admin.internal.CacheServerImpl;
+import org.apache.geode.admin.internal.ConfigurationParameterImpl;
+import org.apache.geode.internal.admin.ClientMembershipMessage;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * MBean representation of a {@link
- * com.gemstone.gemfire.admin.CacheVm}. 
+ * org.apache.geode.admin.CacheVm}. 
  *
  * @since GemFire 4.0
  */
@@ -303,7 +303,7 @@ public class CacheServerJmxImpl extends CacheServerImpl
   // -------------------------------------------------------------------------
 
   public void refreshConfig()
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     // 1st call to refreshConfig would trigger 
     // the auto-refresh if an interval is set
     if (this.refreshInterval>0) {
@@ -430,7 +430,7 @@ public class CacheServerJmxImpl extends CacheServerImpl
    */
   @Override
   protected StatisticResource createStatisticResource(StatResource stat)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     StatisticResourceJmxImpl managedStatisticResource = null;
     
     synchronized (this.managedStatisticsResourcesMap) {
@@ -462,7 +462,7 @@ public class CacheServerJmxImpl extends CacheServerImpl
    */
   @Override
   protected SystemMemberCache createSystemMemberCache(GemFireVM vm)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     if (managedSystemMemberCache == null) {
       managedSystemMemberCache = new SystemMemberCacheJmxImpl(vm);
     }
@@ -481,7 +481,7 @@ public class CacheServerJmxImpl extends CacheServerImpl
    *         with the new attributes added
    */
   public ManagedBean addDynamicAttributes(ManagedBean managed) 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     return Helper.addDynamicAttributes(this, managed);
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigAttributeInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigAttributeInfo.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigAttributeInfo.java
index 7dba8d9..9f7f940 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigAttributeInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigAttributeInfo.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-//import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.internal.Assert;
+//import org.apache.geode.admin.ConfigurationParameter;
+import org.apache.geode.internal.Assert;
 
 import javax.management.Descriptor;
 import javax.management.modelmbean.DescriptorSupport;
@@ -25,7 +25,7 @@ import javax.management.modelmbean.ModelMBeanAttributeInfo;
 
 /** 
  * Subclass of AttributeInfo with {@link 
- * com.gemstone.gemfire.admin.ConfigurationParameter} added for use as the 
+ * org.apache.geode.admin.ConfigurationParameter} added for use as the 
  * {@link javax.management.modelmbean.ModelMBeanAttributeInfo} descriptor's 
  * <i>targetObject</i> value.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigurationParameterJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigurationParameterJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigurationParameterJmxImpl.java
index 20796c7..a318eb5 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigurationParameterJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ConfigurationParameterJmxImpl.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.IOException;
 import java.io.Serializable;
 
 import org.apache.logging.log4j.Level;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.UnmodifiableConfigurationException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.UnmodifiableConfigurationException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides MBean support for managing accessing a ConfigurationParameter.
@@ -42,7 +42,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  *
  */
 public class ConfigurationParameterJmxImpl
-extends com.gemstone.gemfire.admin.internal.ConfigurationParameterImpl
+extends org.apache.geode.admin.internal.ConfigurationParameterImpl
 implements Serializable {
 
   private static final long serialVersionUID = -7822171853906772375L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributedSystemHealthConfigJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributedSystemHealthConfigJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributedSystemHealthConfigJmxImpl.java
index 5babbcd..18c3fd5 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributedSystemHealthConfigJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributedSystemHealthConfigJmxImpl.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.admin.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.admin.*;
+import org.apache.geode.admin.internal.*;
+//import org.apache.geode.internal.admin.*;
 import javax.management.*;
 import javax.management.modelmbean.*;
 //import org.apache.commons.modeler.ManagedBean;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributionLocatorJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributionLocatorJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributionLocatorJmxImpl.java
index f264f21..ad60682 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributionLocatorJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DistributionLocatorJmxImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-//import com.gemstone.gemfire.admin.AdminException;
-//import com.gemstone.gemfire.admin.DistributionLocator;
-import com.gemstone.gemfire.admin.DistributionLocatorConfig;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.Assert;
+//import org.apache.geode.admin.AdminException;
+//import org.apache.geode.admin.DistributionLocator;
+import org.apache.geode.admin.DistributionLocatorConfig;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.Assert;
 
 //import org.apache.commons.modeler.ManagedBean;
 //import org.apache.commons.modeler.AttributeInfo;
@@ -47,8 +47,8 @@ import javax.management.modelmbean.ModelMBean;
  *
  */
 public class DistributionLocatorJmxImpl 
-extends com.gemstone.gemfire.admin.internal.DistributionLocatorImpl
-implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource,
+extends org.apache.geode.admin.internal.DistributionLocatorImpl
+implements org.apache.geode.admin.jmx.internal.ManagedResource,
            DistributionLocatorConfig {
 
   /** The JMX object name of this managed resource */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DynamicManagedBean.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DynamicManagedBean.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DynamicManagedBean.java
index 67bb0ec..1b62fb0 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DynamicManagedBean.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/DynamicManagedBean.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthConfigJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthConfigJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthConfigJmxImpl.java
index dce9e5d..f1bfa55 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthConfigJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthConfigJmxImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import javax.management.ObjectName;
 import javax.management.modelmbean.ModelMBean;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.internal.GemFireHealthConfigImpl;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.internal.GemFireHealthConfigImpl;
 
 /**
  * The JMX "managed resource" that represents the configuration for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthJmxImpl.java
index 1cf931a..1f8d322 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GemFireHealthJmxImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import javax.management.MalformedObjectNameException;
 import javax.management.ObjectName;
@@ -22,15 +22,15 @@ import javax.management.modelmbean.ModelMBean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.DistributedSystemHealthConfig;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.admin.internal.GemFireHealthImpl;
-import com.gemstone.gemfire.internal.admin.GfManagerAgent;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.DistributedSystemHealthConfig;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.admin.internal.GemFireHealthImpl;
+import org.apache.geode.internal.admin.GfManagerAgent;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 //import org.apache.commons.modeler.ManagedBean;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GenerateMBeanHTML.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GenerateMBeanHTML.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GenerateMBeanHTML.java
index f887a23..2c4f63e 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GenerateMBeanHTML.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/GenerateMBeanHTML.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import javax.xml.parsers.SAXParser;
 import javax.xml.parsers.SAXParserFactory;
@@ -37,7 +37,7 @@ public class GenerateMBeanHTML extends DefaultHandler {
 
   /** The location of the DTD for the MBean descriptions */
   private static final String DTD_LOCATION =
-    "/com/gemstone/gemfire/admin/jmx/internal/doc-files/mbeans-descriptors.dtd";
+    "/org/apache/geode/admin/jmx/internal/doc-files/mbeans-descriptors.dtd";
 
 //  /** The system id of MBean description's DTD */
 //  private static final String SYSTEM_ID = 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
index b16d2bd..d805b8a 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.net.URL;
 import java.util.Date;
@@ -42,14 +42,14 @@ import org.apache.commons.modeler.Registry;
 import org.apache.logging.log4j.Level;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.LogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Common support for MBeans and {@link ManagedResource}s.  Static loading of
@@ -165,7 +165,7 @@ public class MBeanUtil {
         }
         registry.setMBeanServer(mbeanServer);
   
-        String mbeansResource = getOSPath("/com/gemstone/gemfire/admin/jmx/mbeans-descriptors.xml");
+        String mbeansResource = getOSPath("/org/apache/geode/admin/jmx/mbeans-descriptors.xml");
         //System.out.println(LocalizedStrings.MBeanUtil_LOADING_RESOURCE_0.toLocalizedString(mbeansResource));
         
         URL url = ClassPathLoader.getLatest().getResource(MBeanUtil.class, mbeansResource);
@@ -294,7 +294,7 @@ public class MBeanUtil {
     
     // customize the defn...
     managed.setClassName(
-        "com.gemstone.gemfire.admin.jmx.internal.MX4JModelMBean");
+        "org.apache.geode.admin.jmx.internal.MX4JModelMBean");
 
     return managed;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
index 81f956f..81f543d 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JModelMBean.java
@@ -6,7 +6,7 @@
  * See the terms of the MX4J License in the documentation provided with this software.
  */
 
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.lang.reflect.InvocationTargetException;
 import java.lang.reflect.Method;
@@ -58,7 +58,7 @@ import mx4j.persist.MBeanPersister;
 import mx4j.persist.PersisterMBean;
 import mx4j.util.Utils;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * @author <a href="mailto:biorn_steedom@users.sourceforge.net">Simone Bordet</a>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JServerSocketFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JServerSocketFactory.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JServerSocketFactory.java
index 649038e..7781a25 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JServerSocketFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MX4JServerSocketFactory.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.admin.internal.InetAddressUtil;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.admin.internal.InetAddressUtil;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MailManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MailManager.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MailManager.java
index 53a50d6..1786406 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MailManager.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MailManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.File;
 import java.io.FileInputStream;
@@ -30,10 +30,10 @@ import javax.mail.internet.MimeMessage;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Provides the ways to send emails to all the registered email id It also

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResource.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResource.java
index f2ecba5..2496013 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResource.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResource.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import javax.management.ObjectName;
 import javax.management.modelmbean.ModelMBean;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
index 65a908e..cf9b792 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/ManagedResourceType.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import org.apache.commons.lang.StringUtils;
 
@@ -31,47 +31,47 @@ public class ManagedResourceType implements java.io.Serializable {
   
   /** Agent managed resource type */
   public static final ManagedResourceType AGENT = 
-      new ManagedResourceType("Agent", com.gemstone.gemfire.admin.jmx.Agent.class);
+      new ManagedResourceType("Agent", org.apache.geode.admin.jmx.Agent.class);
 
   /** DistributedSystem managed resource type */
   public static final ManagedResourceType DISTRIBUTED_SYSTEM = 
-      new ManagedResourceType("AdminDistributedSystem", com.gemstone.gemfire.admin.AdminDistributedSystem.class);
+      new ManagedResourceType("AdminDistributedSystem", org.apache.geode.admin.AdminDistributedSystem.class);
 
   /** SystemMember managed resource type */
   public static final ManagedResourceType SYSTEM_MEMBER = 
-      new ManagedResourceType("SystemMember", com.gemstone.gemfire.admin.SystemMember.class);
+      new ManagedResourceType("SystemMember", org.apache.geode.admin.SystemMember.class);
 
   /** SystemMemberCache managed resource type */
   public static final ManagedResourceType SYSTEM_MEMBER_CACHE = 
-      new ManagedResourceType("SystemMemberCache", com.gemstone.gemfire.admin.SystemMemberCache.class);
+      new ManagedResourceType("SystemMemberCache", org.apache.geode.admin.SystemMemberCache.class);
 
   /** SystemMemberCache managed resource type */
   public static final ManagedResourceType SYSTEM_MEMBER_REGION = 
-      new ManagedResourceType("SystemMemberRegion", com.gemstone.gemfire.admin.SystemMemberRegion.class);
+      new ManagedResourceType("SystemMemberRegion", org.apache.geode.admin.SystemMemberRegion.class);
 
   /** SystemMemberCacheServer managed resource type */
   public static final ManagedResourceType SYSTEM_MEMBER_CACHE_SERVER = 
-      new ManagedResourceType("SystemMemberCacheServer", com.gemstone.gemfire.admin.SystemMemberCacheServer.class);
+      new ManagedResourceType("SystemMemberCacheServer", org.apache.geode.admin.SystemMemberCacheServer.class);
 
   /** CacheVm managed resource type */
   public static final ManagedResourceType CACHE_VM = 
-      new ManagedResourceType("CacheVm", com.gemstone.gemfire.admin.CacheVm.class);
+      new ManagedResourceType("CacheVm", org.apache.geode.admin.CacheVm.class);
 
   /** StatisticResource managed resource type */
   public static final ManagedResourceType STATISTIC_RESOURCE = 
-      new ManagedResourceType("StatisticResource", com.gemstone.gemfire.admin.StatisticResource.class);
+      new ManagedResourceType("StatisticResource", org.apache.geode.admin.StatisticResource.class);
 
   public static final ManagedResourceType GEMFIRE_HEALTH = 
-      new ManagedResourceType("GemFireHealth", com.gemstone.gemfire.admin.GemFireHealth.class);
+      new ManagedResourceType("GemFireHealth", org.apache.geode.admin.GemFireHealth.class);
 
   public static final ManagedResourceType DISTRIBUTED_SYSTEM_HEALTH_CONFIG = 
-      new ManagedResourceType("DistributedSystemHealthConfig", com.gemstone.gemfire.admin.DistributedSystemHealthConfig.class);
+      new ManagedResourceType("DistributedSystemHealthConfig", org.apache.geode.admin.DistributedSystemHealthConfig.class);
 
   public static final ManagedResourceType GEMFIRE_HEALTH_CONFIG = 
-      new ManagedResourceType("GemFireHealthConfig", com.gemstone.gemfire.admin.GemFireHealthConfig.class);
+      new ManagedResourceType("GemFireHealthConfig", org.apache.geode.admin.GemFireHealthConfig.class);
 
   public static final ManagedResourceType DISTRIBUTION_LOCATOR = 
-      new ManagedResourceType("DistributionLocator", com.gemstone.gemfire.admin.DistributionLocator.class);
+      new ManagedResourceType("DistributionLocator", org.apache.geode.admin.DistributionLocator.class);
 
   ////////////////////  Instance Fields  ////////////////////
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MemberInfoWithStatsMBean.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MemberInfoWithStatsMBean.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MemberInfoWithStatsMBean.java
index d14e5e6..ac75f38 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MemberInfoWithStatsMBean.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MemberInfoWithStatsMBean.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.admin.jmx.Agent;
-import com.gemstone.gemfire.cache.InterestPolicy;
-import com.gemstone.gemfire.cache.SubscriptionAttributes;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.admin.remote.ClientHealthStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.admin.*;
+import org.apache.geode.admin.jmx.Agent;
+import org.apache.geode.cache.InterestPolicy;
+import org.apache.geode.cache.SubscriptionAttributes;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.admin.remote.ClientHealthStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import mx4j.AbstractDynamicMBean;
 import org.apache.logging.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryService.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryService.java
index f9d6f87..6bf240f 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryService.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryService.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.IOException;
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryServiceMBean.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryServiceMBean.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryServiceMBean.java
index d226bf1..f2ac079 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryServiceMBean.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RMIRegistryServiceMBean.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.rmi.NoSuchObjectException;
 import java.rmi.NotBoundException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
index d5e4c72..93513e5 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/RefreshNotificationType.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import org.apache.commons.lang.StringUtils;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertNotification.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertNotification.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertNotification.java
index 8a35ba9..59d7948 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertNotification.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertNotification.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.Serializable;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Notification to be sent to clients (e.g GFMon2.0 ). It incorporates

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertsAggregator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertsAggregator.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertsAggregator.java
index 94900f2..b80b18b 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertsAggregator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatAlertsAggregator.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * This interface represents an Aggregator entity and resides in JMXAgent.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticAttributeInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticAttributeInfo.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticAttributeInfo.java
index ddd2cfb..92c6091 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticAttributeInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticAttributeInfo.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.admin.Statistic;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.admin.Statistic;
+import org.apache.geode.internal.Assert;
 
 import javax.management.Descriptor;
 import javax.management.modelmbean.DescriptorSupport;
 import javax.management.modelmbean.ModelMBeanAttributeInfo;
 
 /** 
- * Subclass of AttributeInfo with {@link com.gemstone.gemfire.admin.Statistic} 
+ * Subclass of AttributeInfo with {@link org.apache.geode.admin.Statistic} 
  * added for use as the {@link 
  * javax.management.modelmbean.ModelMBeanAttributeInfo} descriptor's 
  * <i>targetObject</i> value.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
index 6e79ad8..3e04500 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/StatisticResourceJmxImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import javax.management.Notification;
 import javax.management.ObjectName;
@@ -24,14 +24,14 @@ import javax.naming.OperationNotSupportedException;
 import org.apache.commons.modeler.ManagedBean;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.Statistic;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.LogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.Statistic;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Provides MBean support for the monitoring of a statistic resource.
@@ -40,9 +40,9 @@ import com.gemstone.gemfire.internal.logging.LogService;
  *
  */
 public class StatisticResourceJmxImpl 
-extends com.gemstone.gemfire.admin.internal.StatisticResourceImpl
+extends org.apache.geode.admin.internal.StatisticResourceImpl
 implements javax.management.NotificationListener, 
-           com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
+           org.apache.geode.admin.jmx.internal.ManagedResource {
 
   private static final Logger logger = LogService.getLogger();
   
@@ -67,19 +67,19 @@ implements javax.management.NotificationListener,
    *
    * @param statResource  the admin StatResource to manage/monitor
    * @param member        the SystemMember owning this resource
-   * @exception com.gemstone.gemfire.admin.AdminException 
+   * @exception org.apache.geode.admin.AdminException 
    *            if unable to create this StatisticResource for administration
    */
   public StatisticResourceJmxImpl(StatResource statResource,
                                   SystemMemberJmx member)
-                           throws com.gemstone.gemfire.admin.AdminException {
+                           throws org.apache.geode.admin.AdminException {
     super(statResource, member);
     initializeMBean();
   }
 
   /** Create and register the MBean to manage this resource */
   private void initializeMBean() 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     this.mbeanName = new StringBuffer("GemFire.Statistic:")
                       .append("source=").append(MBeanUtil.makeCompliantMBeanNameProperty(this.member.getId()))
                       .append(",type=").append(MBeanUtil.makeCompliantMBeanNameProperty(getType()))
@@ -199,9 +199,9 @@ implements javax.management.NotificationListener,
       try {
         refresh();
 
-      } catch (com.gemstone.gemfire.admin.AdminException e) {
+      } catch (org.apache.geode.admin.AdminException e) {
         logger.warn(e.getMessage(), e);
-      } catch (com.gemstone.gemfire.admin.OperationCancelledException e) {
+      } catch (org.apache.geode.admin.OperationCancelledException e) {
         // underlying resource is no longer reachable by remote admin
         logger.warn(e.getMessage(), e);
         _setRefreshInterval(0);
@@ -240,7 +240,7 @@ implements javax.management.NotificationListener,
    *         with the new attributes added
    */
   ManagedBean addDynamicAttributes(ManagedBean managed) 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     if (managed == null) {
       throw new IllegalArgumentException(LocalizedStrings.StatisticResourceJmxImpl_MANAGEDBEAN_IS_NULL.toLocalizedString());
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberBridgeServerJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberBridgeServerJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberBridgeServerJmxImpl.java
index ad94396..0040cb0 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberBridgeServerJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberBridgeServerJmxImpl.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.internal.SystemMemberBridgeServerImpl;
-import com.gemstone.gemfire.admin.internal.SystemMemberCacheImpl;
-import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.internal.SystemMemberBridgeServerImpl;
+import org.apache.geode.admin.internal.SystemMemberCacheImpl;
+import org.apache.geode.internal.admin.AdminBridgeServer;
+import org.apache.geode.internal.admin.GemFireVM;
 
 import javax.management.ObjectName;
 import javax.management.modelmbean.ModelMBean;
 
 /**
  * MBean representation of a {@link
- * com.gemstone.gemfire.admin.SystemMemberBridgeServer}. 
+ * org.apache.geode.admin.SystemMemberBridgeServer}. 
  *
  * @since GemFire 4.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberCacheJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberCacheJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberCacheJmxImpl.java
index 2e32f8f..b8cc255 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberCacheJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberCacheJmxImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.util.Collection;
 import java.util.HashMap;
@@ -30,25 +30,25 @@ import javax.management.modelmbean.ModelMBean;
 import org.apache.commons.modeler.ManagedBean;
 import org.apache.logging.log4j.Level;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.SystemMemberCacheServer;
-import com.gemstone.gemfire.admin.SystemMemberRegion;
-import com.gemstone.gemfire.admin.internal.SystemMemberBridgeServerImpl;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.SystemMemberCacheServer;
+import org.apache.geode.admin.SystemMemberRegion;
+import org.apache.geode.admin.internal.SystemMemberBridgeServerImpl;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.admin.AdminBridgeServer;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 /**
- * MBean representation of {@link com.gemstone.gemfire.admin.SystemMemberCache}.
+ * MBean representation of {@link org.apache.geode.admin.SystemMemberCache}.
  *
  * @since GemFire     3.5
  */
 public class SystemMemberCacheJmxImpl 
-extends com.gemstone.gemfire.admin.internal.SystemMemberCacheImpl
-implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
+extends org.apache.geode.admin.internal.SystemMemberCacheImpl
+implements org.apache.geode.admin.jmx.internal.ManagedResource {
 
   /** The object name of this managed resource */
   private ObjectName objectName;
@@ -68,14 +68,14 @@ implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
    *        The vm owning the cache this object will manage
    */
   public SystemMemberCacheJmxImpl(GemFireVM vm)
-  throws com.gemstone.gemfire.admin.AdminException { 
+  throws org.apache.geode.admin.AdminException { 
     super(vm);
     initializeMBean();
   }
 
   /** Create and register the MBean to manage this resource */
   private void initializeMBean() 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     this.mbeanName = new StringBuffer("GemFire.Cache:")
         .append("name=")
         .append(MBeanUtil.makeCompliantMBeanNameProperty(getName()))
@@ -109,7 +109,7 @@ implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
    */
   @Override  
   protected SystemMemberRegion createSystemMemberRegion(Region r)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     SystemMemberRegionJmxImpl managedSystemMemberRegion = null;
     boolean needsRefresh = false;
     synchronized (this.managedRegionResourcesMap) {
@@ -177,7 +177,7 @@ implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
    *         with the new attributes added
    */
   ManagedBean addDynamicAttributes(ManagedBean managed)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     if (managed == null) {
       throw new IllegalArgumentException(LocalizedStrings.SystemMemberCacheJmxImpl_MANAGEDBEAN_IS_NULL.toLocalizedString());
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
index c57bf85..dd52a4e 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmx.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.admin.ClientMembershipMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.admin.jmx.internal;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.*;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.admin.ClientMembershipMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.commons.modeler.ManagedBean;
 import org.apache.logging.log4j.Logger;
 
@@ -356,7 +356,7 @@ public interface SystemMemberJmx
         try {
           member.refreshConfig();
 
-        } catch (com.gemstone.gemfire.admin.AdminException e) {
+        } catch (org.apache.geode.admin.AdminException e) {
           logger.warn(e.getMessage(), e);
         } catch (OperationCancelledException e) {
           // underlying resource is no longer reachable by remote admin

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
index 103dbe1..2f5fca9 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberJmxImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -34,21 +34,21 @@ import javax.naming.OperationNotSupportedException;
 import org.apache.commons.modeler.ManagedBean;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.admin.StatisticResource;
-import com.gemstone.gemfire.admin.SystemMemberCache;
-import com.gemstone.gemfire.admin.SystemMemberCacheEvent;
-import com.gemstone.gemfire.admin.SystemMemberRegionEvent;
-import com.gemstone.gemfire.admin.internal.ConfigurationParameterImpl;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.admin.ApplicationVM;
-import com.gemstone.gemfire.internal.admin.ClientMembershipMessage;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.ConfigurationParameter;
+import org.apache.geode.admin.StatisticResource;
+import org.apache.geode.admin.SystemMemberCache;
+import org.apache.geode.admin.SystemMemberCacheEvent;
+import org.apache.geode.admin.SystemMemberRegionEvent;
+import org.apache.geode.admin.internal.ConfigurationParameterImpl;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.admin.ApplicationVM;
+import org.apache.geode.internal.admin.ClientMembershipMessage;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Provides MBean support for managing a SystemMember application.
@@ -61,9 +61,9 @@ import com.gemstone.gemfire.internal.logging.LogService;
  *
  */
 public class SystemMemberJmxImpl 
-extends com.gemstone.gemfire.admin.internal.SystemMemberImpl
+extends org.apache.geode.admin.internal.SystemMemberImpl
 implements SystemMemberJmx, javax.management.NotificationListener,
-           com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
+           org.apache.geode.admin.jmx.internal.ManagedResource {
 
   private static final Logger logger = LogService.getLogger();
   
@@ -95,7 +95,7 @@ implements SystemMemberJmx, javax.management.NotificationListener,
    */
   public SystemMemberJmxImpl(AdminDistributedSystemJmxImpl system,
                              ApplicationVM application)
-                      throws com.gemstone.gemfire.admin.AdminException { 
+                      throws org.apache.geode.admin.AdminException { 
     super(system, application);
     initializeMBean();
   }
@@ -123,7 +123,7 @@ implements SystemMemberJmx, javax.management.NotificationListener,
 
   /** Create and register the MBean to manage this resource */
   private void initializeMBean() 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     //initialize Managed Resources for stats & cache first.
 //    initializeManagedResources();
 
@@ -194,7 +194,7 @@ implements SystemMemberJmx, javax.management.NotificationListener,
   //   MBean Operations
   // -------------------------------------------------------------------------
 
-  public void refreshConfig() throws com.gemstone.gemfire.admin.AdminException {
+  public void refreshConfig() throws org.apache.geode.admin.AdminException {
     // 1st call to refreshConfig would trigger
     // the auto-refresh if an interval is set
     if (this.refreshInterval > 0) {
@@ -324,7 +324,7 @@ implements SystemMemberJmx, javax.management.NotificationListener,
    */
   @Override
   protected StatisticResource createStatisticResource(StatResource stat)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     StatisticResourceJmxImpl managedStatisticResource = null;
     
     synchronized (this.managedStatisticsResourcesMap) {
@@ -356,7 +356,7 @@ implements SystemMemberJmx, javax.management.NotificationListener,
    */
   @Override
   protected SystemMemberCache createSystemMemberCache(GemFireVM vm)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     if (managedSystemMemberCache == null) {
       managedSystemMemberCache = new SystemMemberCacheJmxImpl(vm);
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberRegionJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberRegionJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberRegionJmxImpl.java
index d7b4d5b..9ee3153 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberRegionJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/SystemMemberRegionJmxImpl.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
-import com.gemstone.gemfire.admin.internal.SystemMemberCacheImpl;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
+import org.apache.geode.admin.internal.SystemMemberCacheImpl;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.admin.GemFireVM;
 
 import javax.management.ObjectName;
 import javax.management.modelmbean.ModelMBean;
 
 /**
  * MBean representation of {@link 
- * com.gemstone.gemfire.admin.SystemMemberRegion}.
+ * org.apache.geode.admin.SystemMemberRegion}.
  *
  * @since GemFire     3.5
  */
 public class SystemMemberRegionJmxImpl 
-extends com.gemstone.gemfire.admin.internal.SystemMemberRegionImpl
-implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
+extends org.apache.geode.admin.internal.SystemMemberRegionImpl
+implements org.apache.geode.admin.jmx.internal.ManagedResource {
 
   /** The object name of this managed resource */
   private ObjectName objectName;
@@ -48,14 +48,14 @@ implements com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
    */
   public SystemMemberRegionJmxImpl(SystemMemberCacheImpl cache, 
                                    Region region)
-                            throws com.gemstone.gemfire.admin.AdminException {
+                            throws org.apache.geode.admin.AdminException {
     super(cache, region);
     initializeMBean(cache);
   }
 
   /** Create and register the MBean to manage this resource */
   private void initializeMBean(SystemMemberCacheImpl cache)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     
     GemFireVM vm = cache.getVM();
     this.mbeanName = new StringBuffer("GemFire.Cache:")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/package.html b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/package.html
index 1700ab7..bc2b2f2 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/package.html
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/package.html
@@ -18,7 +18,7 @@ limitations under the License.
 <BODY>
 
 <P>Contains the implementation of the external JMX APIs from
-<a href="{@docRoot}/com/gemstone/gemfire/admin/jmx/package-summary.html#package_description">com.gemstone.gemfire.admin.jmx</a>.</P>
+<a href="{@docRoot}/org/apache/geode/admin/jmx/package-summary.html#package_description">org.apache.geode.admin.jmx</a>.</P>
 
 <H2>JMX Support in GemFire</H2>
 
@@ -33,7 +33,7 @@ Our goal was to provide JMX administrative support in GemFire.  The design was i
 
 From a functional stand point, the JMX support was supposed to provide most of the same administrative and operational monitoring that the console already provides.  In some cases we limited the functionality due to security concerns and in others because it was hard to express the features as JMX beans.  The JMX Agent also provides some functionality (such as Health monitoring) that is not currently in the console.
 <p>
-The Agent communicates with the distributed system using the same distribution manager {@link com.gemstone.gemfire.distributed.internal.DistributionManager} as the console uses and thus has the same requirements that determine what distributed system it can manage.  Although the Console currently supports managing multiple distributed systems, we decided that a given Agent should only be able to manage a single system.  We have not tested the use of more than one Agent for the same system, however nothing currently prohibits this.
+The Agent communicates with the distributed system using the same distribution manager {@link org.apache.geode.distributed.internal.DistributionManager} as the console uses and thus has the same requirements that determine what distributed system it can manage.  Although the Console currently supports managing multiple distributed systems, we decided that a given Agent should only be able to manage a single system.  We have not tested the use of more than one Agent for the same system, however nothing currently prohibits this.
 <p>
 We decided to develop a simple public Admin API which in essence wraps the internal.admin API that the Console currently uses extensively.  The Admin API also contains implementations of new functionality not in internal.admin.  Our JMX support is an extension to this Admin API.  In an overly simplified view, the GemFire JMX MBeans are ModelMBeans that manage instances of the Admin API objects housed in the Agent's MBeanServer.
 <p>
@@ -43,39 +43,39 @@ The two server connectors we selected are the HttpAdaptor and the RMI Connector.
 <p>
 Two open-source JMX implementations made it to our final review for consideration: <a href="http://www.xmojo.org">XMOJO</a> and <a href="http://www.mx4j.org">MX4J</a>.  The decision to go with MX4J was based mainly on our perceptions of MX4J being more active and widespread in use.  Additionally, XMOJO is associated with <a href="http://www.adventnet.com/">AdventNet</a> which produces commercial products.  This made MX4J seem more true to open-source and safer from corporate tampering.
 <p>
-ModelMBeans are very dynamic and capable of managing aggregate resources.  Use of a ModelMBean entails specifying meta-data to an instance of javax.management.modelmbean.RequiredModelMBean.  This meta-data identifies the manageble resource(s) which can consist of a single object, or many objects, including those in one VM or in any number of distributed VMs.  We decided to subclass classes in the Admin API in order to massage them a little and make them easier to use as a managed resource by the ModelMBean.  For example, com.gemstone.gemfire.admin.GemFireManager represents a type of member in a GemFire system which manages shared memory.  When an MBean is registered for managing the GemFireManager, the JMX Agent instantiates a "JMX friendlier" subclass: com.gemstone.gemfire.admin.jmx.internal.GemFireMangerJmxImpl.  Comparison of this class with the non-JMX super class com.gemstone.gemfire.admin.internal.GemFireManagerImpl will illustrate what "JMX friendly" means better than trying 
 to explain it here...
+ModelMBeans are very dynamic and capable of managing aggregate resources.  Use of a ModelMBean entails specifying meta-data to an instance of javax.management.modelmbean.RequiredModelMBean.  This meta-data identifies the manageble resource(s) which can consist of a single object, or many objects, including those in one VM or in any number of distributed VMs.  We decided to subclass classes in the Admin API in order to massage them a little and make them easier to use as a managed resource by the ModelMBean.  For example, org.apache.geode.admin.GemFireManager represents a type of member in a GemFire system which manages shared memory.  When an MBean is registered for managing the GemFireManager, the JMX Agent instantiates a "JMX friendlier" subclass: org.apache.geode.admin.jmx.internal.GemFireMangerJmxImpl.  Comparison of this class with the non-JMX super class org.apache.geode.admin.internal.GemFireManagerImpl will illustrate what "JMX friendly" means better than trying to explain i
 t here...
 <p>
 One standard approach to defining a ModelMBean is to programmatically
 build the necessary meta-data.  The folks on the Tomcat approach
 developed a better solution... an XML definition file which Jakarta
 Commons-Modeler parses to create the meta-data objects required to
 definie the ModelMBean.  We currently have our XML descriptor file at
-com.gemstone.gemfire.admin.jmx.mbeans-descriptors.xml.
+org.apache.geode.admin.jmx.mbeans-descriptors.xml.
 Commons-Modeler can be found at <A href="http://jakarta.apache.org/commons/modeler">http://jakarta.apache.org/commons/modeler/</A>
 <p>
 Here's a quick run-down of the Admin and JMX pkgs in GemFire...
 <p>
-<b>com.gemstone.gemfire.admin</b>
+<b>org.apache.geode.admin</b>
 <ul>
 <li/>interfaces describing GemFire entities and resources for managing or monitoring
 </ul>
 <p>
-<b>com.gemstone.gemfire.admin.internal</b>
+<b>org.apache.geode.admin.internal</b>
 <ul>
 <li/>implementations of the admin pkg which could be used to managing GemFire
 <li/>recommendation is to create one set on non-JMX unit tests for these and then wrap that unit test within another test that is specific to its use in JMX
 </ul>
 <p>
-<b>com.gemstone.gemfire.admin.jmx</b>
+<b>org.apache.geode.admin.jmx</b>
 <ul>
 <li/>Commons-Modeler descriptor file mbeans-descriptors.xml
 <li/>AgentMBean - non-required interface that simply represents a public documentation of what the Agent does
 <li/>VersionMBean and Version - unused (but functional) examples of a standard MBean (other MBeans as defined in mbeans-descriptors.xml also provide version info)
 </ul>
 <p>
-<b>com.gemstone.gemfire.admin.jmx.internal</b>
+<b>org.apache.geode.admin.jmx.internal</b>
 <ul>
-<li/>subclasses of com.gemstone.gemfire.admin.internal classes that use JMX services, implement ManagedResource, register ModelMBeans to manage themselves, and other JMX related details
+<li/>subclasses of org.apache.geode.admin.internal classes that use JMX services, implement ManagedResource, register ModelMBeans to manage themselves, and other JMX related details
 <li/>ManagedResource - simple interface we use to create a more uniform approach in using JMX
 <li/>Agent - application with main, registers HttpAdaptor, acts as a factory to DistributedSystemJmxImpl (which is the entry point to using JMX with a GemFire system)
 <li/>AgentConfig - configuration for Agent that reads/writes to a properties file
@@ -93,7 +93,7 @@ Here's a quick run-down of the Admin and JMX pkgs in GemFire...
 <p>
 3) Our MBeans currently have some return types of Admin interfaces and GemFire MBean types.  This is not recommended.  The correct approach is to return javax.management.ObjectName or an array of ObjectName so that remotability is not broken.  We have a bug filed to correct this in GemFire.
 <p>
-4) Commons-Modeler provides a simple, incomplete implementation of ModelMBean called org.apache.commons.modeler.BaseModelMBean. We decided to use the standard RequiredModelMBean which all JMX implementations are required to supply.  The JMX spec details several "managed resource types" that a ModelMBean can support.  ObjectReference is the type that both MX4J's RequiredModelMBean and Modeler's BaseModelMBean support.  However, MX4J is more strict in it's interpretation of the spec which spells it out as "ObjectReference".  Modeler's BaseModelMBean performs no enforcement and simply assumes it is managing type ObjectReference.  Modeler has a bug in org.apache.commons.modeler.ManagedBean because it specifies "objectReference" which is the incorrect case in comparison to the specification.  I intend to work with the Jakarta-Commons folks to change this to comply with the spec.  The Modeler will use BaseModelMBean by default even though it is actually depending on a JMX implementation s
 uch as MX4J or XMOJO.  com.gemstone.gemfire.admin.jmx.internal.MBeanUtil tells Modeler to use RequiredModelMBean instead and also uses com.gemstone.gemfire.admin.jmx.internal.SpecManagedBean as a workaround to the whole "objectReference" issue.  You could feasibly use org.apache.commons.modeler.BaseModelMBean or RequiredModelMBean.
+4) Commons-Modeler provides a simple, incomplete implementation of ModelMBean called org.apache.commons.modeler.BaseModelMBean. We decided to use the standard RequiredModelMBean which all JMX implementations are required to supply.  The JMX spec details several "managed resource types" that a ModelMBean can support.  ObjectReference is the type that both MX4J's RequiredModelMBean and Modeler's BaseModelMBean support.  However, MX4J is more strict in it's interpretation of the spec which spells it out as "ObjectReference".  Modeler's BaseModelMBean performs no enforcement and simply assumes it is managing type ObjectReference.  Modeler has a bug in org.apache.commons.modeler.ManagedBean because it specifies "objectReference" which is the incorrect case in comparison to the specification.  I intend to work with the Jakarta-Commons folks to change this to comply with the spec.  The Modeler will use BaseModelMBean by default even though it is actually depending on a JMX implementation s
 uch as MX4J or XMOJO.  org.apache.geode.admin.jmx.internal.MBeanUtil tells Modeler to use RequiredModelMBean instead and also uses org.apache.geode.admin.jmx.internal.SpecManagedBean as a workaround to the whole "objectReference" issue.  You could feasibly use org.apache.commons.modeler.BaseModelMBean or RequiredModelMBean.
 <p>
 
 <h3>Capabilities currently supported in GemFire via JMX:</h3>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/package.html b/geode-core/src/main/java/org/apache/geode/admin/package.html
index 86d7651..29ce994 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/package.html
+++ b/geode-core/src/main/java/org/apache/geode/admin/package.html
@@ -26,11 +26,11 @@ system, and processes that host GemFire Caches.</P>
 The Admin API provides interfaces for administrative control, 
 monitoring, and custom management of a GemFire system.
 <P>
-The {@link com.gemstone.gemfire.admin.AdminDistributedSystemFactory}
+The {@link org.apache.geode.admin.AdminDistributedSystemFactory}
 is the starting point.  It creates an instance of
 <code>AdminDistributedSystem</code> that administers the distributed
 system to which a VM is {@linkplain
-com.gemstone.gemfire.distributed.DistributedSystem connected}.
+org.apache.geode.distributed.DistributedSystem connected}.
 <P>
 <pre><code>
 DistributedSystem connection = DistributedSystem.connect(new Properties());
@@ -39,38 +39,38 @@ AdminDistributedSystem system =
 system.connect(new File("admin.log"), "info");
 </code></pre>
 <P>
-This {@link com.gemstone.gemfire.admin.AdminDistributedSystem}
+This {@link org.apache.geode.admin.AdminDistributedSystem}
 interface exposes methods for such tasks as connecting to the system,
 merging system logs, getting administrative interfaces to 
 applications that host GemFire Caches.
 
 <H3>Monitoring the Health of GemFire</H3>
 
-<P>The {@link com.gemstone.gemfire.admin.GemFireHealth} interface
+<P>The {@link org.apache.geode.admin.GemFireHealth} interface
 allows the overall health of GemFire to be monitored.
 <code>GemFireHealth</code> monitors the behavior the members of a
 distributed system namely 
-application VMs that may host {@link com.gemstone.gemfire.cache.Cache
+application VMs that may host {@link org.apache.geode.cache.Cache
 cache} instances.  There are three levels of health: {@linkplain
-com.gemstone.gemfire.admin.GemFireHealth#GOOD_HEALTH good health} that
+org.apache.geode.admin.GemFireHealth#GOOD_HEALTH good health} that
 indicates that all GemFire components are behaving reasonably,
-{@linkplain com.gemstone.gemfire.admin.GemFireHealth#OKAY_HEALTH okay
+{@linkplain org.apache.geode.admin.GemFireHealth#OKAY_HEALTH okay
 health} that indicates that one or more GemFire components is slightly
 unhealthy and may need some attention, and {@linkplain
-com.gemstone.gemfire.admin.GemFireHealth#POOR_HEALTH poor health} that
+org.apache.geode.admin.GemFireHealth#POOR_HEALTH poor health} that
 indicates that a GemFire component is unhealthy and needs immediate
 attention.</P>
 
 <P>Because each GemFire application has its own definition of what it
 means to be "healthy", the metrics that are used to determine health
 are configurable.  {@link
-com.gemstone.gemfire.admin.GemFireHealthConfig} provides methods for
+org.apache.geode.admin.GemFireHealthConfig} provides methods for
 configuring how the health of {@linkplain
-com.gemstone.gemfire.admin.DistributedSystemHealthConfig the
+org.apache.geode.admin.DistributedSystemHealthConfig the
 distributed system},
-{@linkplain com.gemstone.gemfire.admin.CacheHealthConfig members that
+{@linkplain org.apache.geode.admin.CacheHealthConfig members that
 host Cache instances}, and {@linkplain
-com.gemstone.gemfire.admin.MemberHealthConfig individual members} of
+org.apache.geode.admin.MemberHealthConfig individual members} of
 the distributed system.  <code>GemFireHealthConfig</code> also allows
 you to configure how often GemFire's health is evaluated.</P>
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
index c773c96..3418c21 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.File;
 import java.io.Serializable;
@@ -25,21 +25,21 @@ import java.util.List;
 import java.util.Set;
 import java.util.concurrent.CopyOnWriteArraySet;
 
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.cache.AbstractRegion;
-import com.gemstone.gemfire.internal.cache.DiskStoreFactoryImpl;
-import com.gemstone.gemfire.internal.cache.DiskWriteAttributesImpl;
-import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.cache.UserSpecifiedRegionAttributes;
-import com.gemstone.gemfire.internal.cache.xmlcache.RegionAttributesCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.cache.AbstractRegion;
+import org.apache.geode.internal.cache.DiskStoreFactoryImpl;
+import org.apache.geode.internal.cache.DiskWriteAttributesImpl;
+import org.apache.geode.internal.cache.EvictionAttributesImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PartitionAttributesImpl;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.cache.UserSpecifiedRegionAttributes;
+import org.apache.geode.internal.cache.xmlcache.RegionAttributesCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /** Creates instances of {@link RegionAttributes}. An <code>AttributesFactory</code>
  * instance maintains state for creating <code>RegionAttributes</code> instances.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
index 6b31759..d3aaf9c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/Cache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Cache.java b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
index a17fdd2..773654b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Cache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.List;
 import java.util.Set;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueueFactory;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.snapshot.CacheSnapshotService;
-import com.gemstone.gemfire.cache.util.GatewayConflictResolver;
-import com.gemstone.gemfire.cache.wan.GatewayReceiver;
-import com.gemstone.gemfire.cache.wan.GatewayReceiverFactory;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueueFactory;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.snapshot.CacheSnapshotService;
+import org.apache.geode.cache.util.GatewayConflictResolver;
+import org.apache.geode.cache.wan.GatewayReceiver;
+import org.apache.geode.cache.wan.GatewayReceiverFactory;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.cache.wan.GatewaySenderFactory;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.i18n.LogWriterI18n;
 
 
 /** 
@@ -84,7 +84,7 @@ public interface Cache extends GemFireCache {
    * @return the region object
    * @throws RegionExistsException if a region is already in
    * this cache
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheClosedException if the cache is closed
    * @throws IllegalStateException If the supplied RegionAttributes violate the
@@ -103,7 +103,7 @@ public interface Cache extends GemFireCache {
    * @param aRegionAttributes the attributes of the root region
    * @return the region object
    * @throws RegionExistsException if a region is already in this cache
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheClosedException if the cache is closed
    * @throws IllegalStateException If the supplied RegionAttributes violate the
@@ -224,7 +224,7 @@ public interface Cache extends GemFireCache {
   
   /**
    * Gets the number of seconds a cache
-   * {@link com.gemstone.gemfire.cache.Region#get(Object) get} operation
+   * {@link org.apache.geode.cache.Region#get(Object) get} operation
    * can spend searching for a value before it times out.
    * The search includes any time spent loading the object.
    * When the search times out it causes the get to fail by throwing
@@ -245,9 +245,9 @@ public interface Cache extends GemFireCache {
    * Creates a new cache server, with the default configuration,
    * that will allow clients to access this cache.
    * <p>For the default configuration see the constants in
-   * {@link com.gemstone.gemfire.cache.server.CacheServer}.
+   * {@link org.apache.geode.cache.server.CacheServer}.
    * 
-   * @see com.gemstone.gemfire.cache.server.CacheServer
+   * @see org.apache.geode.cache.server.CacheServer
    *
    * @since GemFire 5.7
    */
@@ -286,7 +286,7 @@ public interface Cache extends GemFireCache {
    * Sets whether or not this <code>Cache</code> resides in a
    * long-running "cache server" VM.  A cache server may be an
    * application VM or may be a stand-along VM launched using {@linkplain
-   * com.gemstone.gemfire.admin.AdminDistributedSystem#addCacheServer
+   * org.apache.geode.admin.AdminDistributedSystem#addCacheServer
    * administration API} or the <code>cacheserver</code> command line
    * utility.
    *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java b/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
index eae82ea..9b6964d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * User-defined objects that can be plugged into caching to receive callback

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
index f72dbe7..9c2be5d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.CancelException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 /**
  * Indicates that the caching system has 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java b/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
index 8ee1a7f..44e4745 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.EnumListenerEvent;
 
 /**
  * A region- or entry-related event affecting the cache.



[47/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsJUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsJUnitTest.java
index 84b8668..6ce0014 100755
--- a/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsJUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/management/internal/cli/commands/LauncherLifecycleCommandsJUnitTest.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.management.internal.cli.commands;
-
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.ServerLauncher;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.DistributionLocator;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+package org.apache.geode.management.internal.cli.commands;
+
+import org.apache.geode.GemFireException;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.ServerLauncher;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.DistributionLocator;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.management.internal.cli.i18n.CliStrings;
+import org.apache.geode.test.junit.categories.UnitTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Test;
@@ -34,14 +34,14 @@ import org.junit.experimental.categories.Category;
 import java.io.File;
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 /**
  * The LauncherLifecycleCommandsJUnitTest class is a test suite of test cases testing the contract and functionality of
  * the lifecycle launcher GemFire shell (Gfsh) commands.
  *
- * @see com.gemstone.gemfire.management.internal.cli.commands.LauncherLifecycleCommands
+ * @see org.apache.geode.management.internal.cli.commands.LauncherLifecycleCommands
  * @see org.junit.Assert
  * @see org.junit.Test
  * @since GemFire 7.0

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
index 3408717..0a53489 100644
--- a/geode-assembly/src/test/java/org/apache/geode/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/management/internal/configuration/SharedConfigurationEndToEndDUnitTest.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-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.InternalLocator;
-import com.gemstone.gemfire.internal.ClassBuilder;
-import com.gemstone.gemfire.internal.JarDeployer;
-import com.gemstone.gemfire.internal.admin.remote.ShutdownAllRequest;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.management.cli.Result.Status;
-import com.gemstone.gemfire.management.internal.cli.HeadlessGfsh;
-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 com.gemstone.gemfire.test.dunit.SerializableCallable;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.WaitCriterion;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+package org.apache.geode.management.internal.configuration;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.ClassBuilder;
+import org.apache.geode.internal.JarDeployer;
+import org.apache.geode.internal.admin.remote.ShutdownAllRequest;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.management.cli.Result.Status;
+import org.apache.geode.management.internal.cli.HeadlessGfsh;
+import org.apache.geode.management.internal.cli.commands.CliCommandTestBase;
+import org.apache.geode.management.internal.cli.i18n.CliStrings;
+import org.apache.geode.management.internal.cli.result.CommandResult;
+import org.apache.geode.management.internal.cli.util.CommandStringBuilder;
+import org.apache.geode.test.dunit.SerializableCallable;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.dunit.WaitCriterion;
+import org.apache.geode.test.junit.categories.DistributedTest;
 import org.apache.commons.io.FileUtils;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
@@ -48,19 +48,19 @@ import java.util.HashSet;
 import java.util.Properties;
 import java.util.Set;
 
-import static com.gemstone.gemfire.cache.RegionShortcut.PARTITION;
-import static com.gemstone.gemfire.cache.RegionShortcut.REPLICATE;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-import static com.gemstone.gemfire.internal.AvailablePortHelper.getRandomAvailableTCPPorts;
-import static com.gemstone.gemfire.internal.FileUtil.delete;
-import static com.gemstone.gemfire.internal.FileUtil.deleteMatching;
-import static com.gemstone.gemfire.internal.lang.StringUtils.isBlank;
-import static com.gemstone.gemfire.management.internal.cli.CliUtil.getAllNormalMembers;
-import static com.gemstone.gemfire.test.dunit.Assert.*;
-import static com.gemstone.gemfire.test.dunit.Host.getHost;
-import static com.gemstone.gemfire.test.dunit.IgnoredException.addIgnoredException;
-import static com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter;
-import static com.gemstone.gemfire.test.dunit.Wait.waitForCriterion;
+import static org.apache.geode.cache.RegionShortcut.PARTITION;
+import static org.apache.geode.cache.RegionShortcut.REPLICATE;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+import static org.apache.geode.internal.AvailablePortHelper.getRandomAvailableTCPPorts;
+import static org.apache.geode.internal.FileUtil.delete;
+import static org.apache.geode.internal.FileUtil.deleteMatching;
+import static org.apache.geode.internal.lang.StringUtils.isBlank;
+import static org.apache.geode.management.internal.cli.CliUtil.getAllNormalMembers;
+import static org.apache.geode.test.dunit.Assert.*;
+import static org.apache.geode.test.dunit.Host.getHost;
+import static org.apache.geode.test.dunit.IgnoredException.addIgnoredException;
+import static org.apache.geode.test.dunit.LogWriterUtils.getLogWriter;
+import static org.apache.geode.test.dunit.Wait.waitForCriterion;
 
 @Category(DistributedTest.class)
 public class SharedConfigurationEndToEndDUnitTest extends CliCommandTestBase {
@@ -205,8 +205,8 @@ public class SharedConfigurationEndToEndDUnitTest extends CliCommandTestBase {
       byte[] jarBytes = classBuilder.createJarFromClassContent("com/qcdunit/QueueCommandsDUnitTestListener",
           "package com.qcdunit;" +
               "import java.util.List; import java.util.Properties;" +
-              "import com.gemstone.gemfire.internal.cache.xmlcache.Declarable2; import com.gemstone.gemfire.cache.asyncqueue.AsyncEvent;" +
-              "import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;" +
+              "import org.apache.geode.internal.cache.xmlcache.Declarable2; import org.apache.geode.cache.asyncqueue.AsyncEvent;" +
+              "import org.apache.geode.cache.asyncqueue.AsyncEventListener;" +
               "public class QueueCommandsDUnitTestListener implements Declarable2, AsyncEventListener {" +
               "Properties props;" +
               "public boolean processEvents(List<AsyncEvent> events) { return true; }" +

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestFunctionTemplate.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestFunctionTemplate.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestFunctionTemplate.java
index 8cd0638..b21f94c 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestFunctionTemplate.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestFunctionTemplate.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web;
+package org.apache.geode.rest.internal.web;
 
-import com.gemstone.gemfire.cache.execute.FunctionAdapter;
+import org.apache.geode.cache.execute.FunctionAdapter;
 
 public abstract class RestFunctionTemplate extends FunctionAdapter {
   public int invocationCount = 0;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestInterfaceJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestInterfaceJUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestInterfaceJUnitTest.java
index 8246671..0d93518 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestInterfaceJUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestInterfaceJUnitTest.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web;
+package org.apache.geode.rest.internal.web;
 
 import com.fasterxml.jackson.core.JsonParser.Feature;
 import com.fasterxml.jackson.databind.DeserializationFeature;
 import com.fasterxml.jackson.databind.ObjectMapper;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.management.internal.AgentUtil;
-import com.gemstone.gemfire.pdx.*;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.management.internal.AgentUtil;
+import org.apache.geode.pdx.*;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Test;
@@ -49,7 +49,7 @@ import java.io.InputStreamReader;
 import java.text.SimpleDateFormat;
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 /**
@@ -63,10 +63,10 @@ import static org.junit.Assert.*;
  * @see org.springframework.test.context.ContextConfiguration
  * @see org.springframework.test.context.junit4.SpringJUnit4ClassRunner
  * @see org.springframework.web.client.RestTemplate
- * @see com.gemstone.gemfire.cache.Cache
- * @see com.gemstone.gemfire.cache.Region
- * @see com.gemstone.gemfire.pdx.PdxInstance
- * @see com.gemstone.gemfire.pdx.ReflectionBasedAutoSerializer
+ * @see org.apache.geode.cache.Cache
+ * @see org.apache.geode.cache.Region
+ * @see org.apache.geode.pdx.PdxInstance
+ * @see org.apache.geode.pdx.ReflectionBasedAutoSerializer
  * @since Geode 1.0.0
  */
 //@RunWith(SpringJUnit4ClassRunner.class)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestSecurityDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestSecurityDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestSecurityDUnitTest.java
index 847ca76..df146a6 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestSecurityDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/RestSecurityDUnitTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web;
+package org.apache.geode.rest.internal.web;
 
 import static org.junit.Assert.*;
 
@@ -34,10 +34,10 @@ import org.json.JSONException;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.security.AbstractSecureServerDUnitTest;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.categories.SecurityTest;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.security.AbstractSecureServerDUnitTest;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.categories.SecurityTest;
 
 @Category({ DistributedTest.class, SecurityTest.class})
 public class RestSecurityDUnitTest extends AbstractSecureServerDUnitTest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
index 7344780..b2bb040 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/AddFreeItemToOrders.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -22,20 +22,20 @@ import java.util.Collection;
 import java.util.List;
 import java.util.Vector;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.pdx.PdxInstance;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.pdx.PdxInstance;
 
 /**
  * Gemfire function to add free items in the existing order

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Customer.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Customer.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Customer.java
index c065fbb..801c5a7 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Customer.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Customer.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.io.Serializable;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.ObjectUtils;
 
 /**
  * The Customer class models a customer entity.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/DateTimeUtils.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/DateTimeUtils.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/DateTimeUtils.java
index 3a92df3..1467821 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/DateTimeUtils.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/DateTimeUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.text.SimpleDateFormat;
 import java.util.Calendar;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Gender.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Gender.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Gender.java
index 9cd1cdb..774d83c 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Gender.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Gender.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 /**
  * The Gender enum is a enumeration of genders (sexes).

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetAllEntries.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetAllEntries.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetAllEntries.java
index daa609e..c047f12 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetAllEntries.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetAllEntries.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.HashMap;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
 
 /**
  * The GetAllEntries is function that will return a map as a result of its execution.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
index beb8d3a..e224777 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetDeliveredOrders.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.ArrayList;
 import java.util.Collection;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetRegions.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetRegions.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetRegions.java
index 6f287c7..9e261a7 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetRegions.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetRegions.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.ArrayList;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
 
 /**
 * The GetRegions class is an gemfire function that gives data about available regions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetValueForKey.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetValueForKey.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetValueForKey.java
index 25e87b6..eb461fb 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetValueForKey.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/GetValueForKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
 
 public class GetValueForKey implements Function {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Item.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Item.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Item.java
index 5f99bbe..e8d4f01 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Item.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Item.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.io.Serializable;
 
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.pdx.PdxReader;
-import com.gemstone.gemfire.pdx.PdxSerializable;
-import com.gemstone.gemfire.pdx.PdxWriter;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.pdx.PdxReader;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxWriter;
 
 /**
  * The Item class models item entity in the real world.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Order.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Order.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Order.java
index 062aaf9..bcf5c3b 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Order.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Order.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.Date;
 import java.util.List;
 
-import com.gemstone.gemfire.pdx.PdxReader;
-import com.gemstone.gemfire.pdx.PdxSerializable;
-import com.gemstone.gemfire.pdx.PdxWriter;
+import org.apache.geode.pdx.PdxReader;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxWriter;
 
 /**
 * The Order class is an abstraction modeling a order.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Person.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Person.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Person.java
index 9687f1e..b995ec2 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Person.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/Person.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.Date;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.pdx.PdxReader;
-import com.gemstone.gemfire.pdx.PdxSerializable;
-import com.gemstone.gemfire.pdx.PdxWriter;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.pdx.PdxReader;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxWriter;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/PutKeyFunction.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/PutKeyFunction.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/PutKeyFunction.java
index e75d9fc..ab0f7d0 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/PutKeyFunction.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/PutKeyFunction.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIOnRegionFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIOnRegionFunctionExecutionDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIOnRegionFunctionExecutionDUnitTest.java
index 62ddb35..b45b683 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIOnRegionFunctionExecutionDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIOnRegionFunctionExecutionDUnitTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import static org.junit.Assert.*;
 
@@ -34,26 +34,26 @@ import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.PartitionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionTestHelper;
-import com.gemstone.gemfire.rest.internal.web.RestFunctionTemplate;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.PartitionAttributesImpl;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionTestHelper;
+import org.apache.geode.rest.internal.web.RestFunctionTemplate;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
 
 /**
  * Dunit Test to validate OnRegion function execution with REST APIs
@@ -87,7 +87,7 @@ public class RestAPIOnRegionFunctionExecutionDUnitTest extends RestAPITestBase {
     factory.setScope(Scope.DISTRIBUTED_ACK);
     factory.setDataPolicy(policy);
     Region region = CacheFactory.getAnyInstance().createRegion(REPLICATE_REGION_NAME, factory.create());
-    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("Region Created :" + region);
+    org.apache.geode.test.dunit.LogWriterUtils.getLogWriter().info("Region Created :" + region);
     assertNotNull(region);
   }
 
@@ -100,7 +100,7 @@ public class RestAPIOnRegionFunctionExecutionDUnitTest extends RestAPITestBase {
     raf.setPartitionAttributes(pa);
 
     Region region = CacheFactory.getAnyInstance().createRegion(PR_REGION_NAME, raf.create());
-    com.gemstone.gemfire.test.dunit.LogWriterUtils.getLogWriter().info("Region Created :" + region);
+    org.apache.geode.test.dunit.LogWriterUtils.getLogWriter().info("Region Created :" + region);
     assertNotNull(region);
     return Boolean.TRUE;
   }
@@ -223,7 +223,7 @@ public class RestAPIOnRegionFunctionExecutionDUnitTest extends RestAPITestBase {
 
     vm3.invoke("populatePRRegion", () -> populatePRRegion());
 
-    String jsonBody = "[" + "{\"@type\": \"double\",\"@value\": 210}" + ",{\"@type\":\"com.gemstone.gemfire.rest.internal.web.controllers.Item\"," + "\"itemNo\":\"599\",\"description\":\"Part X Free on Bumper Offer\"," + "\"quantity\":\"2\"," + "\"unitprice\":\"5\"," + "\"totalprice\":\"10.00\"}" + "]";
+    String jsonBody = "[" + "{\"@type\": \"double\",\"@value\": 210}" + ",{\"@type\":\"org.apache.geode.rest.internal.web.controllers.Item\"," + "\"itemNo\":\"599\",\"description\":\"Part X Free on Bumper Offer\"," + "\"quantity\":\"2\"," + "\"unitprice\":\"5\"," + "\"totalprice\":\"10.00\"}" + "]";
 
     CloseableHttpResponse response = executeFunctionThroughRestCall("SampleFunction", PR_REGION_NAME, null, jsonBody, null, null);
     assertEquals(200, response.getStatusLine().getStatusCode());
@@ -232,7 +232,7 @@ public class RestAPIOnRegionFunctionExecutionDUnitTest extends RestAPITestBase {
     // Assert that only 1 node has executed the function.
     assertCorrectInvocationCount(4, vm0, vm1, vm2, vm3);
 
-    jsonBody = "[" + "{\"@type\": \"double\",\"@value\": 220}" + ",{\"@type\":\"com.gemstone.gemfire.rest.internal.web.controllers.Item\"," + "\"itemNo\":\"609\",\"description\":\"Part X Free on Bumper Offer\"," + "\"quantity\":\"3\"," + "\"unitprice\":\"9\"," + "\"totalprice\":\"12.00\"}" + "]";
+    jsonBody = "[" + "{\"@type\": \"double\",\"@value\": 220}" + ",{\"@type\":\"org.apache.geode.rest.internal.web.controllers.Item\"," + "\"itemNo\":\"609\",\"description\":\"Part X Free on Bumper Offer\"," + "\"quantity\":\"3\"," + "\"unitprice\":\"9\"," + "\"totalprice\":\"12.00\"}" + "]";
 
     resetInvocationCounts(vm0, vm1, vm2, vm3);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
index de48cf9..a7eb66d 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
@@ -15,10 +15,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-import static com.gemstone.gemfire.test.dunit.Assert.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+import static org.apache.geode.test.dunit.Assert.*;
 
 import java.io.BufferedReader;
 import java.io.IOException;
@@ -40,20 +40,20 @@ import org.apache.http.impl.client.HttpClients;
 import org.json.JSONArray;
 import org.junit.experimental.categories.Category;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.management.internal.AgentUtil;
-import com.gemstone.gemfire.rest.internal.web.RestFunctionTemplate;
-import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.Invoke;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.management.internal.AgentUtil;
+import org.apache.geode.rest.internal.web.RestFunctionTemplate;
+import org.apache.geode.test.dunit.Host;
+import org.apache.geode.test.dunit.Invoke;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.dunit.internal.JUnit4DistributedTestCase;
+import org.apache.geode.test.junit.categories.DistributedTest;
 
 @Category(DistributedTest.class)
 class RestAPITestBase extends JUnit4DistributedTestCase {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsAndInterOpsDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsAndInterOpsDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsAndInterOpsDUnitTest.java
index 09410d3..0299615 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsAndInterOpsDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsAndInterOpsDUnitTest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 import java.io.BufferedReader;
@@ -48,32 +48,32 @@ import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.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.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.internal.LocatorTestBase;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.management.ManagementTestBase;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.NetworkUtils;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.internal.LocatorTestBase;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.AvailablePort;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.management.ManagementTestBase;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.test.dunit.Host;
+import org.apache.geode.test.dunit.NetworkUtils;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
 
 /**
  * Dunit Test containing inter - operations between REST Client and Gemfire cache client
@@ -119,14 +119,14 @@ public class RestAPIsAndInterOpsDUnitTest extends LocatorTestBase {
   final static String PERSON_AS_JSON_CAS = "{"
       + "\"@old\" :"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 101," + " \"firstName\": \"Mithali\","
       + " \"middleName\": \"Dorai\"," + " \"lastName\": \"Raj\","
       + " \"birthDate\": \"12/04/1982\"," + "\"gender\": \"FEMALE\""
       + "},"
       + "\"@new\" :"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 1101," + " \"firstName\": \"Virat\","
       + " \"middleName\": \"Premkumar\"," + " \"lastName\": \"Kohli\","
       + " \"birthDate\": \"08/11/1988\"," + "\"gender\": \"MALE\""
@@ -134,50 +134,50 @@ public class RestAPIsAndInterOpsDUnitTest extends LocatorTestBase {
       + "}";
 
   final static String PERSON_AS_JSON_REPLACE = "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 501," + " \"firstName\": \"Barack\","
       + " \"middleName\": \"Hussein\"," + " \"lastName\": \"Obama\","
       + " \"birthDate\": \"04/08/1961\"," + "\"gender\": \"MALE\""
       + "}";
 
   private static final String PERSON_LIST_AS_JSON = "[" + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 3," + " \"firstName\": \"Nishka3\","
       + " \"middleName\": \"Nilkanth3\"," + " \"lastName\": \"Patel3\","
       + " \"birthDate\": \"07/31/2009\"," + "\"gender\": \"FEMALE\"" + "},"
-      + "{" + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "{" + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 4," + " \"firstName\": \"Tanay4\","
       + " \"middleName\": \"kiran4\"," + " \"lastName\": \"Patel4\","
       + " \"birthDate\": \"23/08/2012\"," + "\"gender\": \"MALE\"" + "}," + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 5," + " \"firstName\": \"Nishka5\","
       + " \"middleName\": \"Nilkanth5\"," + " \"lastName\": \"Patel5\","
       + " \"birthDate\": \"31/09/2009\"," + "\"gender\": \"FEMALE\"" + "},"
-      + "{" + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "{" + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 6," + " \"firstName\": \"Tanay6\","
       + " \"middleName\": \"Kiran6\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"23/08/2012\"," + "\"gender\": \"MALE\"" + "}," + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 7," + " \"firstName\": \"Nishka7\","
       + " \"middleName\": \"Nilkanth7\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"31/09/2009\"," + "\"gender\": \"FEMALE\"" + "},"
-      + "{" + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "{" + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 8," + " \"firstName\": \"Tanay8\","
       + " \"middleName\": \"kiran8\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"23/08/2012\"," + "\"gender\": \"MALE\"" + "}," + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 9," + " \"firstName\": \"Nishka9\","
       + " \"middleName\": \"Nilkanth9\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"31/09/2009\"," + "\"gender\": \"FEMALE\"" + "},"
-      + "{" + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "{" + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 10," + " \"firstName\": \"Tanay10\","
       + " \"middleName\": \"kiran10\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"23/08/2012\"," + "\"gender\": \"MALE\"" + "}," + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 11," + " \"firstName\": \"Nishka11\","
       + " \"middleName\": \"Nilkanth11\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"31/09/2009\"," + "\"gender\": \"FEMALE\"" + "},"
-      + "{" + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Person\","
+      + "{" + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Person\","
       + "\"id\": 12," + " \"firstName\": \"Tanay12\","
       + " \"middleName\": \"kiran12\"," + " \"lastName\": \"Patel\","
       + " \"birthDate\": \"23/08/2012\"," + "\"gender\": \"MALE\"" + "}" + "]";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnGroupsFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnGroupsFunctionExecutionDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnGroupsFunctionExecutionDUnitTest.java
index a3a2a10..e8e81cc 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnGroupsFunctionExecutionDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnGroupsFunctionExecutionDUnitTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import static org.junit.Assert.*;
 
@@ -29,13 +29,13 @@ import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.rest.internal.web.RestFunctionTemplate;
-import com.gemstone.gemfire.test.dunit.LogWriterUtils;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.rest.internal.web.RestFunctionTemplate;
+import org.apache.geode.test.dunit.LogWriterUtils;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
 
 @Category(DistributedTest.class)
 @RunWith(Parameterized.class)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnMembersFunctionExecutionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnMembersFunctionExecutionDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnMembersFunctionExecutionDUnitTest.java
index ad431f9..64fbba6 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnMembersFunctionExecutionDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsOnMembersFunctionExecutionDUnitTest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.util.Arrays;
 import java.util.Collection;
@@ -28,16 +28,16 @@ import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.rest.internal.web.RestFunctionTemplate;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.categories.FlakyTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.rest.internal.web.RestFunctionTemplate;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.categories.FlakyTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
 
 @Category(DistributedTest.class)
 @RunWith(Parameterized.class)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsQueryAndFEJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsQueryAndFEJUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsQueryAndFEJUnitTest.java
index 8321caf..ed7c09c 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsQueryAndFEJUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsQueryAndFEJUnitTest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 import java.net.InetAddress;
@@ -45,30 +45,30 @@ import org.springframework.util.StringUtils;
 import org.springframework.web.client.HttpClientErrorException;
 import org.springframework.web.client.HttpServerErrorException;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.CacheLoader;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.LoaderHelper;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.ServerLauncher;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.management.internal.AgentUtil;
-import com.gemstone.gemfire.management.internal.ManagementConstants;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.LoaderHelper;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.ServerLauncher;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.management.internal.AgentUtil;
+import org.apache.geode.management.internal.ManagementConstants;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
 public class RestAPIsQueryAndFEJUnitTest {
@@ -92,7 +92,7 @@ public class RestAPIsQueryAndFEJUnitTest {
   private Map<Integer, QueryResultData> queryResultByIndex;
  
   private final String ORDER1_AS_JSON = "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 111," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -105,7 +105,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       + "}" + "]" + "}";
   
   private final String MALFORMED_JSON = "{"
-      + "\"@type\" \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\" \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 111," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -118,7 +118,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       + "}" + "]" + "}";
   
   private final String ORDER2_AS_JSON = "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 112," + "\"customerId\": 102,"
       + "\"description\": \"Purchase order for company - B\"," + "\"orderDate\": \"02/10/2014\"," + "\"deliveryDate\": \"02/20/2014\","
       + "\"contact\": \"John Blum\","
@@ -131,7 +131,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       + "}" + "]" + "}";
   
   private final String ORDER2_UPDATED_AS_JSON = "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 1112," + "\"customerId\": 102,"
       + "\"description\": \"Purchase order for company - B\","  + "\"orderDate\": \"02/10/2014\"," + "\"deliveryDate\": \"02/20/2014\","
       + "\"contact\": \"John Blum\","
@@ -145,25 +145,25 @@ public class RestAPIsQueryAndFEJUnitTest {
   
   final String CUSTOMER_LIST1_AS_JSON = "[" 
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 1,"
       + " \"firstName\": \"Vishal\","
       + " \"lastName\": \"Roa\"" 
       + "},"
       +"{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 2,"
       + " \"firstName\": \"Nilkanth\","
       + " \"lastName\": \"Patel\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 3,"
       + " \"firstName\": \"Avinash Dongre\","
       + " \"lastName\": \"Roa\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 4,"
       + " \"firstName\": \"Avinash Dongre\","
       + " \"lastName\": \"Roa\"" 
@@ -172,181 +172,181 @@ public class RestAPIsQueryAndFEJUnitTest {
       
   final String CUSTOMER_LIST_AS_JSON = "[" 
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 101,"
       + " \"firstName\": \"Vishal\","
       + " \"lastName\": \"Roa\"" 
       + "},"
       +"{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 102,"
       + " \"firstName\": \"Nilkanth\","
       + " \"lastName\": \"Patel\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 103,"
       + " \"firstName\": \"Avinash Dongre\","
       + " \"lastName\": \"Roa\"" 
       + "},"
       +"{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 104,"
       + " \"firstName\": \"John\","
       + " \"lastName\": \"Blum\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 105,"
       + " \"firstName\": \"Shankar\","
       + " \"lastName\": \"Hundekar\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 106,"
       + " \"firstName\": \"Amey\","
       + " \"lastName\": \"Barve\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 107,"
       + " \"firstName\": \"Vishal\","
       + " \"lastName\": \"Roa\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 108,"
       + " \"firstName\": \"Supriya\","
       + " \"lastName\": \"Pillai\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 109,"
       + " \"firstName\": \"Tushar\","
       + " \"lastName\": \"khairnar\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 110,"
       + " \"firstName\": \"Rishitesh\","
       + " \"lastName\": \"Mishra\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 111,"
       + " \"firstName\": \"Ajay\","
       + " \"lastName\": \"Pandey\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 112,"
       + " \"firstName\": \"Suyog\","
       + " \"lastName\": \"Bokare\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 113,"
       + " \"firstName\": \"Rajesh\","
       + " \"lastName\": \"kumar\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 114,"
       + " \"firstName\": \"swati\","
       + " \"lastName\": \"sawant\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 115,"
       + " \"firstName\": \"sonal\","
       + " \"lastName\": \"Agrawal\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 116,"
       + " \"firstName\": \"Amogh\","
       + " \"lastName\": \"Shetkar\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 117,"
       + " \"firstName\": \"Viren\","
       + " \"lastName\": \"Balaut\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 118,"
       + " \"firstName\": \"Namrata\","
       + " \"lastName\": \"Tanvi\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 119,"
       + " \"firstName\": \"Rahul\","
       + " \"lastName\": \"Diyekar\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 120,"
       + " \"firstName\": \"Varun\","
       + " \"lastName\": \"Agrawal\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 121,"
       + " \"firstName\": \"Hemant\","
       + " \"lastName\": \"Bhanavat\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 122,"
       + " \"firstName\": \"Sunil\","
       + " \"lastName\": \"jigyasu\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 123,"
       + " \"firstName\": \"Sumedh\","
       + " \"lastName\": \"wale\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 124,"
       + " \"firstName\": \"saobhik\","
       + " \"lastName\": \"chaudhari\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 125,"
       + " \"firstName\": \"Ketki\","
       + " \"lastName\": \"Naidu\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 126,"
       + " \"firstName\": \"YOgesh\","
       + " \"lastName\": \"Mahajan\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 127,"
       + " \"firstName\": \"Surinder\","
       + " \"lastName\": \"Bindra\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 128,"
       + " \"firstName\": \"sandip\","
       + " \"lastName\": \"kasbe\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 129,"
       + " \"firstName\": \"shivam\","
       + " \"lastName\": \"Panada\"" 
       + "},"
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Customer\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Customer\","
       +"\"customerId\": 130,"
       + " \"firstName\": \"Preeti\","
       + " \"lastName\": \"Kumari\"" 
@@ -506,7 +506,7 @@ public class RestAPIsQueryAndFEJUnitTest {
   private final String ORDER_AS_CASJSON = "{"
       + "\"@old\" :" 
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 111," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -520,7 +520,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       + "},"
       + "\"@new\" :" 
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 11101," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -555,7 +555,7 @@ public class RestAPIsQueryAndFEJUnitTest {
   private final String MALFORMED_CAS_JSON = "{"
       + "\"@old\" :" 
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 111," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -569,7 +569,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       + "},"
        
       + "{"
-      + "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Order\","
+      + "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Order\","
       + "\"purchaseOrderNo\": 11101," + "\"customerId\": 101,"
       + "\"description\": \"Purchase order for company - A\"," + "\"orderDate\": \"01/10/2014\"," + "\"deliveryDate\": \"01/20/2014\","
       + "\"contact\": \"Nilkanthkumar N Patel\","
@@ -672,7 +672,7 @@ public class RestAPIsQueryAndFEJUnitTest {
     +        "\"@value\": 210"
     +    "},"
     +    "{"
-    +        "\"@type\": \"com.gemstone.gemfire.rest.internal.web.controllers.Item\","
+    +        "\"@type\": \"org.apache.geode.rest.internal.web.controllers.Item\","
     +        "\"itemNo\": \"599\","
     +        "\"description\": \"Part X Free on Bumper Offer\","
     +        "\"quantity\": \"2\","
@@ -1477,11 +1477,11 @@ public class RestAPIsQueryAndFEJUnitTest {
       c.getLogger().info("<ExpectedException action=add>" + expectedEx + "</ExpectedException>");
       return expectedEx;
     } else if (index == 7) {
-      expectedEx = "com.gemstone.gemfire.cache.TimeoutException";
+      expectedEx = "org.apache.geode.cache.TimeoutException";
       c.getLogger().info("<ExpectedException action=add>" + expectedEx + "</ExpectedException>");
       return expectedEx;
     } else if (index == 11 || index == 15) {
-      expectedEx = "com.gemstone.gemfire.cache.CacheWriterException";
+      expectedEx = "org.apache.geode.cache.CacheWriterException";
       c.getLogger().info("<ExpectedException action=add>" + expectedEx + "</ExpectedException>");
       return expectedEx;
     } else if (index == 19) {
@@ -1489,7 +1489,7 @@ public class RestAPIsQueryAndFEJUnitTest {
       c.getLogger().info("<ExpectedException action=add>" + expectedEx + "</ExpectedException>");
       return expectedEx;
     } else if (index == 38 || index == 41 ) {
-      expectedEx = "com.gemstone.gemfire.cache.RegionDestroyedException";
+      expectedEx = "org.apache.geode.cache.RegionDestroyedException";
       c.getLogger().info("<ExpectedException action=add>" + expectedEx + "</ExpectedException>");
       return expectedEx;
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsWithSSLDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsWithSSLDUnitTest.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsWithSSLDUnitTest.java
index daa781d..9a406fd 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsWithSSLDUnitTest.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPIsWithSSLDUnitTest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 import java.io.BufferedReader;
@@ -50,32 +50,32 @@ import org.junit.experimental.categories.Category;
 import org.junit.runner.RunWith;
 import org.junit.runners.Parameterized;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.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.client.internal.LocatorTestBase;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.management.ManagementException;
-import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.dunit.IgnoredException;
-import com.gemstone.gemfire.test.dunit.NetworkUtils;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.runners.CategoryWithParameterizedRunnerFactory;
-import com.gemstone.gemfire.util.test.TestUtil;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.internal.LocatorTestBase;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.AvailablePort;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.management.ManagementException;
+import org.apache.geode.test.dunit.Host;
+import org.apache.geode.test.dunit.IgnoredException;
+import org.apache.geode.test.dunit.NetworkUtils;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.runners.CategoryWithParameterizedRunnerFactory;
+import org.apache.geode.util.test.TestUtil;
 
 /**
  * 
@@ -303,7 +303,7 @@ public class RestAPIsWithSSLDUnitTest extends LocatorTestBase {
 
     IgnoredException.addIgnoredException("java.net.BindException");
     IgnoredException.addIgnoredException("java.rmi.server.ExportException");
-    IgnoredException.addIgnoredException("com.gemstone.gemfire.management.ManagementException");
+    IgnoredException.addIgnoredException("org.apache.geode.management.ManagementException");
 
     Properties props = new Properties();
     props.setProperty(MCAST_PORT, "0");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestTestUtils.java
----------------------------------------------------------------------
diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestTestUtils.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestTestUtils.java
index edad9f8..233a6e0 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestTestUtils.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestTestUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.rest.internal.web.controllers;
+package org.apache.geode.rest.internal.web.controllers;
 
 import java.net.URI;
 import java.text.SimpleDateFormat;
@@ -89,8 +89,8 @@ public class RestTestUtils  {
   protected static HttpMessageConverter<Object> createMarshallingHttpMessageConverter() {
     final Jaxb2Marshaller jaxbMarshaller = new Jaxb2Marshaller();
 
-    jaxbMarshaller.setContextPaths("com.gemstone.gemfire.web.rest.domain",
-        "com.gemstone.gemfire.web.controllers.support");
+    jaxbMarshaller.setContextPaths("org.apache.geode.web.rest.domain",
+        "org.apache.geode.web.controllers.support");
     jaxbMarshaller.setMarshallerProperties(Collections.singletonMap(
         "jaxb.formatted.output", Boolean.TRUE));
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/main/java/org/apache/geode/annotations/Experimental.java
----------------------------------------------------------------------
diff --git a/geode-common/src/main/java/org/apache/geode/annotations/Experimental.java b/geode-common/src/main/java/org/apache/geode/annotations/Experimental.java
index 0ce94a1..d628ea5 100755
--- a/geode-common/src/main/java/org/apache/geode/annotations/Experimental.java
+++ b/geode-common/src/main/java/org/apache/geode/annotations/Experimental.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.annotations;
+package org.apache.geode.annotations;
 
 import java.lang.annotation.Documented;
 import java.lang.annotation.ElementType;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/test/java/org/apache/geode/annotations/ExperimentalJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-common/src/test/java/org/apache/geode/annotations/ExperimentalJUnitTest.java b/geode-common/src/test/java/org/apache/geode/annotations/ExperimentalJUnitTest.java
index 2df1cd6..487106a 100755
--- a/geode-common/src/test/java/org/apache/geode/annotations/ExperimentalJUnitTest.java
+++ b/geode-common/src/test/java/org/apache/geode/annotations/ExperimentalJUnitTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.annotations;
+package org.apache.geode.annotations;
 
 import static org.assertj.core.api.Assertions.*;
 
@@ -23,9 +23,9 @@ import java.lang.reflect.AnnotatedElement;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-import com.gemstone.gemfire.annotations.experimentalpackage.ClassInExperimentalPackage;
-import com.gemstone.gemfire.experimental.nonexperimentalpackage.ClassInNonExperimentalPackage;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.annotations.experimentalpackage.ClassInExperimentalPackage;
+import org.apache.geode.experimental.nonexperimentalpackage.ClassInNonExperimentalPackage;
+import org.apache.geode.test.junit.categories.UnitTest;
 
 /**
  * Unit tests for the <tt>Experimental</tt> annotation. Verifies that the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/ClassInExperimentalPackage.java
----------------------------------------------------------------------
diff --git a/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/ClassInExperimentalPackage.java b/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/ClassInExperimentalPackage.java
index cd080ce..3b6e7d2 100755
--- a/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/ClassInExperimentalPackage.java
+++ b/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/ClassInExperimentalPackage.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.annotations.experimentalpackage;
+package org.apache.geode.annotations.experimentalpackage;
 
 /**
  * Used by <tt>ExperimentalJUnitTest</tt>. This is a class in an
  * <tt>Experimental</tt> package.
  * 
- * @see com.gemstone.gemfire.annotations.ExperimentalJUnitTest
+ * @see org.apache.geode.annotations.ExperimentalJUnitTest
  */
 public class ClassInExperimentalPackage {
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/package-info.java
----------------------------------------------------------------------
diff --git a/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/package-info.java b/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/package-info.java
index 3db93ff..288e9aa 100755
--- a/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/package-info.java
+++ b/geode-common/src/test/java/org/apache/geode/annotations/experimentalpackage/package-info.java
@@ -18,9 +18,9 @@
  * Used by <tt>ExperimentalJUnitTest</tt>. This is an <tt>Experimental</tt> 
  * package.
  * 
- * @see com.gemstone.gemfire.annotations.ExperimentalJUnitTest
+ * @see org.apache.geode.annotations.ExperimentalJUnitTest
  */
 @Experimental("This is an experimental package")
-package com.gemstone.gemfire.annotations.experimentalpackage;
+package org.apache.geode.annotations.experimentalpackage;
 
-import com.gemstone.gemfire.annotations.Experimental;
+import org.apache.geode.annotations.Experimental;



[07/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ValidatingDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ValidatingDiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ValidatingDiskRegion.java
index edf3316..e0499d2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ValidatingDiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ValidatingDiskRegion.java
@@ -14,32 +14,32 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.DistributedRegion.DiskPosition;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.Entry;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.cache.persistence.DiskExceptionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-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.i18n.LocalizedStrings;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.DistributedRegion.DiskPosition;
+import org.apache.geode.internal.cache.InitialImageOperation.Entry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.persistence.DiskExceptionHandler;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A disk region that is created when doing offline validation.
@@ -205,7 +205,7 @@ public class ValidatingDiskRegion extends DiskRegion implements DiskRecoveryStor
       throw new IllegalStateException("should never be called");
     }
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.cache.DiskEntry#getVersionStamp()
+     * @see org.apache.geode.internal.cache.DiskEntry#getVersionStamp()
      */
     @Override
     public VersionStamp getVersionStamp() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ValueByteWrapper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ValueByteWrapper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ValueByteWrapper.java
index 36242ba..5629174 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ValueByteWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ValueByteWrapper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * A wrapper class for the operation which has been recovered to be recovered by

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTagHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTagHolder.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTagHolder.java
index 48258df..da0c2dc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTagHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTagHolder.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * This class is just used to hold the version tag for an operation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTimestamp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTimestamp.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTimestamp.java
index 83a8993..85aba25 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTimestamp.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionTimestamp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntry.java
index 529a3ef..97f0e0a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeap.java
index e2b9b82..d98be8a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapIntKey.java
index 369046f..a243dab 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapIntKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapLongKey.java
index 4f0a21a..feca718 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapLongKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapObjectKey.java
index 9adc75c..6a2ebd5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapObjectKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey1.java
index 57a49da..7561df7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey1.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey2.java
index c278422..f8dcd49 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapStringKey2.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapUUIDKey.java
index 8c98440..bdc70ee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryHeapUUIDKey.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeap.java
index 6bf84f6..80eca23 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapIntKey.java
index ae2acca..ad5139f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapIntKey.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapLongKey.java
index 859980d..c49367c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapLongKey.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapObjectKey.java
index 7c2e6f8..7e39d10 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapObjectKey.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey1.java
index fe69989..9042efa 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey1.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey2.java
index 6e8651c..a39a8e2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapStringKey2.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapUUIDKey.java
index cffd1ef..e3ce530 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskLRURegionEntryOffHeapUUIDKey.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntry.java
index afabc53..b0021d3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeap.java
index 5cdd063..fb8a37d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapIntKey.java
index 5d087b1..5ebb53f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapIntKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapLongKey.java
index d723de6..b0765b9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapLongKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapObjectKey.java
index 61403ed..72b0d69 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapObjectKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey1.java
index ebfb3de..92b87cc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey1.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey2.java
index a984ed6..dcc9718 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapStringKey2.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapUUIDKey.java
index 1f63b43..7bfc31b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryHeapUUIDKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeap.java
index f26a631..66f3e04 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapIntKey.java
index 8d12972..f4a024a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapIntKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapLongKey.java
index b4f14b0..d011a9a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapLongKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapObjectKey.java
index cb0aa66..143e5c9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapObjectKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey1.java
index 9fc7b6a..89691a4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey1.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey2.java
index 0252a39..15c69fc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapStringKey2.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapUUIDKey.java
index 3e015a5..624a8e8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsDiskRegionEntryOffHeapUUIDKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntry.java
index f482f6e..f6f4538 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeap.java
index 301d8d0..ea4dc06 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapIntKey.java
index dfc3b2b..904a3fb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapIntKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapLongKey.java
index a4190b8..c2ce6e3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapLongKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU


[56/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/controllers/PulseControllerJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/controllers/PulseControllerJUnitTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/controllers/PulseControllerJUnitTest.java
new file mode 100644
index 0000000..cc11985
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/controllers/PulseControllerJUnitTest.java
@@ -0,0 +1,816 @@
+/*
+ * 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 org.apache.geode.tools.pulse.controllers;
+
+import static org.hamcrest.Matchers.contains;
+import static org.hamcrest.Matchers.*;
+import static org.junit.Assert.*;
+import static org.mockito.Matchers.anyInt;
+import static org.mockito.Matchers.anyString;
+import static org.mockito.Mockito.doReturn;
+import static org.powermock.api.mockito.PowerMockito.spy;
+import static org.powermock.api.mockito.PowerMockito.when;
+import static org.springframework.test.web.servlet.request.MockMvcRequestBuilders.*;
+import static org.springframework.test.web.servlet.result.MockMvcResultMatchers.*;
+
+import java.io.File;
+import java.security.Principal;
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.UUID;
+import javax.servlet.ServletContextListener;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import org.apache.geode.tools.pulse.internal.PulseAppListener;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import org.apache.geode.test.junit.categories.UnitTest;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConfig;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+
+import org.apache.commons.collections.buffer.CircularFifoBuffer;
+import org.junit.Before;
+import org.junit.Rule;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.junit.rules.TemporaryFolder;
+import org.junit.runner.RunWith;
+import org.mockito.Mockito;
+import org.powermock.core.classloader.annotations.PowerMockIgnore;
+import org.powermock.core.classloader.annotations.PrepareForTest;
+import org.powermock.modules.junit4.PowerMockRunner;
+import org.powermock.modules.junit4.PowerMockRunnerDelegate;
+import org.springframework.beans.factory.annotation.Autowired;
+import org.springframework.http.MediaType;
+import org.springframework.test.context.ContextConfiguration;
+import org.springframework.test.context.junit4.SpringJUnit4ClassRunner;
+import org.springframework.test.context.web.WebAppConfiguration;
+import org.springframework.test.web.servlet.MockMvc;
+import org.springframework.test.web.servlet.setup.MockMvcBuilders;
+import org.springframework.web.context.WebApplicationContext;
+
+import org.apache.geode.test.junit.categories.IntegrationTest;
+
+@Category(IntegrationTest.class)
+@PrepareForTest(Repository.class)
+@RunWith(PowerMockRunner.class)
+@PowerMockRunnerDelegate(SpringJUnit4ClassRunner.class)
+@WebAppConfiguration
+@ContextConfiguration("classpath*:mvc-dispatcher-servlet.xml")
+@PowerMockIgnore("*.IntegrationTest")
+public class PulseControllerJUnitTest {
+
+  private static final String PRINCIPAL_USER = "test-user";
+
+  private static final String MEMBER_ID = "member1";
+  private static final String MEMBER_NAME = "localhost-server";
+  private static final String CLUSTER_NAME = "mock-cluster";
+  private static final String REGION_NAME = "mock-region";
+  private static final String REGION_PATH = "/" + REGION_NAME;
+  private static final String REGION_TYPE = "PARTITION";
+  private static final String AEQ_LISTENER = "async-event-listener";
+  private static final String CLIENT_NAME = "client-1";
+  private static final String PHYSICAL_HOST_NAME = "physical-host-1";
+  private static final String GEMFIRE_VERSION = "1.0.0";
+
+  private static final Principal principal;
+
+  static {
+    principal = () -> PRINCIPAL_USER;
+  }
+
+  @Rule
+  public TemporaryFolder tempFolder = new TemporaryFolder();
+
+  @Autowired
+  private WebApplicationContext wac;
+
+  private MockMvc mockMvc;
+
+  private Cluster cluster;
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  @Before
+  public void setup() throws Exception {
+    this.mockMvc = MockMvcBuilders.webAppContextSetup(this.wac).build();
+
+
+    cluster = Mockito.spy(Cluster.class);
+
+    Cluster.Region region = new Cluster.Region();
+    region.setName(REGION_NAME);
+    region.setFullPath(REGION_PATH);
+    region.setRegionType(REGION_TYPE);
+    region.setMemberCount(1);
+    region.setMemberName(new ArrayList<String>() {{
+      add(MEMBER_NAME);
+    }});
+    region.setPutsRate(12.31D);
+    region.setGetsRate(27.99D);
+    Cluster.RegionOnMember regionOnMember = new Cluster.RegionOnMember();
+    regionOnMember.setRegionFullPath(REGION_PATH);
+    regionOnMember.setMemberName(MEMBER_NAME);
+    region.setRegionOnMembers(new ArrayList<Cluster.RegionOnMember>() {{
+      add(regionOnMember);
+    }});
+    cluster.addClusterRegion(REGION_PATH, region);
+
+    Cluster.Member member = new Cluster.Member();
+    member.setId(MEMBER_ID);
+    member.setName(MEMBER_NAME);
+    member.setUptime(1L);
+    member.setHost(PHYSICAL_HOST_NAME);
+    member.setGemfireVersion(GEMFIRE_VERSION);
+    member.setCpuUsage(55.77123D);
+
+    member.setMemberRegions(new HashMap<String, Cluster.Region>() {{
+      put(REGION_NAME, region);
+    }});
+
+    Cluster.AsyncEventQueue aeq = new Cluster.AsyncEventQueue();
+    aeq.setAsyncEventListener(AEQ_LISTENER);
+    member.setAsyncEventQueueList(new ArrayList() {{
+      add(aeq);
+    }});
+
+    Cluster.Client client = new Cluster.Client();
+    client.setId("100");
+    client.setName(CLIENT_NAME);
+    client.setUptime(1L);
+    member.setMemberClientsHMap(new HashMap<String, Cluster.Client>() {{
+      put(CLIENT_NAME, client);
+    }});
+
+    cluster.setMembersHMap(new HashMap() {{
+      put(MEMBER_NAME, member);
+    }});
+    cluster.setPhysicalToMember(new HashMap() {{
+      put(PHYSICAL_HOST_NAME, new ArrayList() {{
+        add(member);
+      }});
+    }});
+    cluster.setServerName(CLUSTER_NAME);
+    cluster.setMemoryUsageTrend(new CircularFifoBuffer() {{
+      add(1);
+      add(2);
+      add(3);
+    }});
+    cluster.setWritePerSecTrend(new CircularFifoBuffer() {{
+      add(1.29);
+      add(2.3);
+      add(3.0);
+    }});
+    cluster.setThroughoutReadsTrend(new CircularFifoBuffer() {{
+      add(1);
+      add(2);
+      add(3);
+    }});
+    cluster.setThroughoutWritesTrend(new CircularFifoBuffer() {{
+      add(4);
+      add(5);
+      add(6);
+    }});
+
+    Repository repo = Mockito.spy(Repository.class);
+
+    // Set up a partial mock for some static methods
+    spy(Repository.class);
+    when(Repository.class, "get").thenReturn(repo);
+    doReturn(cluster).when(repo).getCluster();
+
+    PulseConfig config = new PulseConfig();
+    File tempQueryLog = tempFolder.newFile("query_history.log");
+    config.setQueryHistoryFileName(tempQueryLog.toString());
+    doReturn(config).when(repo).getPulseConfig();
+
+    PulseController.pulseVersion.setPulseVersion("not empty");
+    PulseController.pulseVersion.setPulseBuildId("not empty");
+    PulseController.pulseVersion.setPulseBuildDate("not empty");
+    PulseController.pulseVersion.setPulseSourceDate("not empty");
+    PulseController.pulseVersion.setPulseSourceRevision("not empty");
+    PulseController.pulseVersion.setPulseSourceRepository("not empty");
+  }
+
+  @Test
+  public void pulseUpdateForClusterDetails() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterDetails\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterDetails.userName").value(PRINCIPAL_USER))
+        .andExpect(jsonPath("$.ClusterDetails.totalHeap").value(0D))
+        .andExpect(jsonPath("$.ClusterDetails.clusterName").value(CLUSTER_NAME))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterDiskThroughput() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterDiskThroughput\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterDiskThroughput.currentThroughputWrites").value(0D))
+        .andExpect(jsonPath("$.ClusterDiskThroughput.throughputReads", contains(1, 2, 3)))
+        .andExpect(jsonPath("$.ClusterDiskThroughput.currentThroughputReads").value(0D))
+        .andExpect(jsonPath("$.ClusterDiskThroughput.throughputWrites", contains(4, 5, 6)))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterGCPauses() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterJVMPauses\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterJVMPauses.currentGCPauses").value(0))
+        .andExpect(jsonPath("$.ClusterJVMPauses.gCPausesTrend").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterKeyStatistics() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterKeyStatistics\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterKeyStatistics.readPerSecTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterKeyStatistics.queriesPerSecTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterKeyStatistics.writePerSecTrend", contains(1.29, 2.3, 3.0)))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterMember() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterMembers\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterMembers.members[0].serverGroups[0]").value("Default"))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].cpuUsage").value(55.77D))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].clients").value(1))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].heapUsage").value(0))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].currentHeapUsage").value(0))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].isManager").value(false))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].threads").value(0))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].memberId").value(MEMBER_ID))
+        .andExpect(jsonPath("$.ClusterMembers.members[0].redundancyZones[0]").value("Default"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterMembersRGraph() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterMembersRGraph\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterMembersRGraph.memberCount").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.data").isEmpty())
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.name").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.id").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].id").value(PHYSICAL_HOST_NAME))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].name").value(PHYSICAL_HOST_NAME))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.loadAvg").value(0D))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.sockets").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.threads").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.cpuUsage").value(0D))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.memoryUsage").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.hostStatus").value("Normal"))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.$type").value("hostNormalNode"))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].id").value(MEMBER_ID))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gemfireVersion").value(GEMFIRE_VERSION))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.memoryUsage").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.cpuUsage").value(55.77D))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.regions").value(1))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.host").value(PHYSICAL_HOST_NAME))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.port").value("-"))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.clients").value(1))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gcPauses").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.numThreads").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.nodeType").value("memberNormalNode"))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.$type").value("memberNormalNode"))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gatewaySender").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gatewayReceiver").value(0))
+        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].children").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterMemoryUsage() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterMemoryUsage\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterMemoryUsage.currentMemoryUsage").value(0))
+        .andExpect(jsonPath("$.ClusterMemoryUsage.memoryUsageTrend", containsInAnyOrder(1, 2, 3)))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterRegion() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterRegion\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterRegion.clusterName").value(CLUSTER_NAME))
+        .andExpect(jsonPath("$.ClusterRegion.userName").value(PRINCIPAL_USER))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].regionPath").value(REGION_PATH))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].diskReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryUsage").value("0.0000"))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].getsRate").value(27.99D))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].wanEnabled").value(false))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memberCount").value(1))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memberNames[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memberNames[0].id").value(MEMBER_ID))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].emptyNodes").value(0))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].type").value(REGION_TYPE))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].isEnableOffHeapMemory").value("OFF"))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].putsRate").value(12.31D))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].totalMemory").value(0))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].entryCount").value(0))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].compressionCodec").value("NA"))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].name").value(REGION_NAME))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].systemRegionEntryCount").value(0))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].persistence").value("OFF"))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegion.region[0].diskWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegion.region[0].dataUsage").value(0))
+        .andExpect(jsonPath("$.ClusterRegion.region[0].entrySize").value("0.0000"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterRegions() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterRegions\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].regionPath").value(REGION_PATH))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].diskReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryUsage").value("0.0000"))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].getsRate").value(27.99D))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].wanEnabled").value(false))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberCount").value(1))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberNames[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberNames[0].id").value(MEMBER_ID))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].emptyNodes").value(0))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].type").value(REGION_TYPE))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].isEnableOffHeapMemory").value("OFF"))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].putsRate").value(12.31D))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].totalMemory").value(0))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].entryCount").value(0))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].compressionCodec").value("NA"))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].name").value(REGION_NAME))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].systemRegionEntryCount").value(0))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].persistence").value("OFF"))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].diskWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].dataUsage").value(0))
+        .andExpect(jsonPath("$.ClusterRegions.regions[0].entrySize").value("0.0000"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterSelectedRegion() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterSelectedRegion\":{\"regionFullPath\":\"" + REGION_PATH + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.lruEvictionRate").value(0D))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.getsRate").value(27.99D))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.emptyNodes").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.type").value(REGION_TYPE))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.isEnableOffHeapMemory").value("OFF"))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.path").value(REGION_PATH))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].cpuUsage").value(55.77D))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].clients").value(1))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].heapUsage").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].currentHeapUsage").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].isManager").value(false))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].threads").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].memberId").value(MEMBER_ID))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].uptime").value("0 Hours 0 Mins 1 Secs"))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.diskWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.dataUsage").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.regionPath").value(REGION_PATH))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.diskReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryUsage").value("0.0000"))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.wanEnabled").value(false))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memberCount").value(1))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.putsRate").value(12.31D))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.totalMemory").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.entryCount").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.compressionCodec").value("NA"))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.name").value(REGION_NAME))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.systemRegionEntryCount").value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.persistence").value("OFF"))
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.entrySize").value("0.0000"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterSelectedRegionsMember() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterSelectedRegionsMember\":{\"regionFullPath\":\"" + REGION_PATH + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.diskReadsTrend", MEMBER_NAME).isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.regionFullPath", MEMBER_NAME).value(REGION_PATH))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.entryCount", MEMBER_NAME).value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.accessor", MEMBER_NAME).value("True"))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memberName", MEMBER_NAME).value(MEMBER_NAME))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memoryReadsTrend", MEMBER_NAME).isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.diskWritesTrend", MEMBER_NAME).isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memoryWritesTrend", MEMBER_NAME).isEmpty())
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.entrySize", MEMBER_NAME).value(0))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.clusterName").value(CLUSTER_NAME))
+        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.userName").value(PRINCIPAL_USER))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForClusterWANInfo() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"ClusterWANInfo\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.ClusterWANInfo.connectedClusters").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberAsynchEventQueues() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberAsynchEventQueues\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.isAsyncEventQueuesPresent").value(true))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchTimeInterval").value(0))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchConflationEnabled").value(false))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].queueSize").value(0))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].senderType").value(false))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].asyncEventListener").value(AEQ_LISTENER))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchSize").value(0))
+        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].primary").value(false))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberClients() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberClients\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberClients.name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].puts").value(0))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].cpuUsage").value("0.0000"))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].clientId").value("100"))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].queueSize").value(0))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].clientCQCount").value(0))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].name").value(CLIENT_NAME))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].isConnected").value("No"))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].threads").value(0))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].isSubscriptionEnabled").value("No"))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].gets").value(0))
+        .andExpect(jsonPath("$.MemberClients.memberClients[0].uptime").value("0 Hours 0 Mins 1 Secs"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberDetails() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberDetails\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberDetails.name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.MemberDetails.offHeapUsedSize").value(0))
+        .andExpect(jsonPath("$.MemberDetails.diskStorageUsed").value(0D))
+        .andExpect(jsonPath("$.MemberDetails.regionsCount").value(1))
+        .andExpect(jsonPath("$.MemberDetails.clusterName").value(CLUSTER_NAME))
+        .andExpect(jsonPath("$.MemberDetails.name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.MemberDetails.threads").value(0))
+        .andExpect(jsonPath("$.MemberDetails.clusterId").isNotEmpty())
+        .andExpect(jsonPath("$.MemberDetails.numClients").value(1))
+        .andExpect(jsonPath("$.MemberDetails.userName").value(PRINCIPAL_USER))
+        .andExpect(jsonPath("$.MemberDetails.offHeapFreeSize").value(0))
+        .andExpect(jsonPath("$.MemberDetails.memberId").value(MEMBER_ID))
+        .andExpect(jsonPath("$.MemberDetails.status").value("Normal"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberDiskThroughput() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberDiskThroughput\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberDiskThroughput.throughputWritesTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberDiskThroughput.throughputReadsTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberDiskThroughput.throughputWrites").value(0D))
+        .andExpect(jsonPath("$.MemberDiskThroughput.throughputReads").value(0D))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberGatewayHub() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberGatewayHub\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberGatewayHub.isGatewayReceiver").value(false))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchTimeInterval").value(0))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchConflationEnabled").value(false))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].queueSize").value(0))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].senderType").value(false))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].asyncEventListener").value(AEQ_LISTENER))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchSize").value(0))
+        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].primary").value(false))
+        .andExpect(jsonPath("$.MemberGatewayHub.isGatewaySender").value(false))
+        .andExpect(jsonPath("$.MemberGatewayHub.regionsInvolved").isEmpty())
+        .andExpect(jsonPath("$.MemberGatewayHub.gatewaySenders").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberGCPauses() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberGCPauses\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberGCPauses.gcPausesCount").value(0))
+        .andExpect(jsonPath("$.MemberGCPauses.gcPausesTrend").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberHeapUsage() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberHeapUsage\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberHeapUsage.heapUsageTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberHeapUsage.currentHeapUsage").value(0))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberKeyStatistics() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberKeyStatistics\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberKeyStatistics.readPerSecTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberKeyStatistics.cpuUsageTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberKeyStatistics.memoryUsageTrend").isEmpty())
+        .andExpect(jsonPath("$.MemberKeyStatistics.writePerSecTrend").isEmpty())
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMemberRegions() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MemberRegions\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MemberRegions.name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].fullPath").value(REGION_PATH))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].entryCount").value(0))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].name").value(REGION_NAME))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].diskStoreName").value(""))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].gatewayEnabled").value(false))
+        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].entrySize").value("0.0000"))
+        .andExpect(jsonPath("$.MemberRegions.memberId").value(MEMBER_ID))
+        .andExpect(jsonPath("$.MemberRegions.status").value("Normal"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForMembersList() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"MembersList\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.MembersList.clusterMembers[0].name").value(MEMBER_NAME))
+        .andExpect(jsonPath("$.MembersList.clusterMembers[0].memberId").value(MEMBER_ID))
+        .andExpect(jsonPath("$.MembersList.clusterName").value(CLUSTER_NAME))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForPulseVersion() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"PulseVersion\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.PulseVersion.sourceDate").value("not empty"))
+        .andExpect(jsonPath("$.PulseVersion.sourceRepository").value("not empty"))
+        .andExpect(jsonPath("$.PulseVersion.pulseVersion").value("not empty"))
+        .andExpect(jsonPath("$.PulseVersion.sourceRevision").value("not empty"))
+        .andExpect(jsonPath("$.PulseVersion.buildId").value("not empty"))
+        .andExpect(jsonPath("$.PulseVersion.buildDate").value("not empty"))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForQueryStatistics() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"QueryStatistics\":\"{}\"}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.QueryStatistics.queriesList").isEmpty())
+        .andExpect(jsonPath("$.QueryStatistics.connectedFlag").value(false))
+        .andExpect(jsonPath("$.QueryStatistics.connectedErrorMsg").value(""))
+    ;
+  }
+
+  @Test
+  public void pulseUpdateForSystemAlerts() throws Exception {
+    this.mockMvc.perform(post("/pulseUpdate")
+        .param("pulseData", "{\"SystemAlerts\":{\"pageNumber\":\"1\"}}")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.SystemAlerts.pageNumber").value(1))
+        .andExpect(jsonPath("$.SystemAlerts.connectedFlag").value(false))
+        .andExpect(jsonPath("$.SystemAlerts.connectedErrorMsg").value(""))
+        .andExpect(jsonPath("$.SystemAlerts.systemAlerts").isEmpty())
+    ;
+  }
+
+  @Test
+  public void authenticateUserNotLoggedIn() throws Exception {
+    this.mockMvc.perform(get("/authenticateUser")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.isUserLoggedIn").value(false));
+  }
+
+  @Test
+  public void authenticateUserLoggedIn() throws Exception {
+    this.mockMvc.perform(get("/authenticateUser")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.isUserLoggedIn").value(true));
+  }
+
+  @Test
+  public void pulseVersion() throws Exception {
+    this.mockMvc.perform(get("/pulseVersion")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.pulseVersion").isNotEmpty())
+        .andExpect(jsonPath("$.buildId").isNotEmpty())
+        .andExpect(jsonPath("$.buildDate").isNotEmpty())
+        .andExpect(jsonPath("$.sourceDate").isNotEmpty())
+        .andExpect(jsonPath("$.sourceRevision").isNotEmpty())
+        .andExpect(jsonPath("$.sourceRepository").isNotEmpty())
+    ;
+  }
+
+  @Test
+  public void clearAlerts() throws Exception {
+    this.mockMvc.perform(get("/clearAlerts")
+        .param("alertType", "1")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.pageNumber").value(1))
+        .andExpect(jsonPath("$.systemAlerts").isEmpty())
+        .andExpect(jsonPath("$.connectedFlag").value(false))
+        .andExpect(jsonPath("$.status").value("deleted"))
+    ;
+  }
+
+  @Test
+  public void acknowledgeAlert() throws Exception {
+    this.mockMvc.perform(get("/acknowledgeAlert")
+        .param("alertId", "1")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.status").value("deleted"));
+  }
+
+  @Test
+  public void dataBrowserRegions() throws Exception {
+    this.mockMvc.perform(get("/dataBrowserRegions")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.clusterName").value(CLUSTER_NAME))
+        .andExpect(jsonPath("$.connectedFlag").value(false))
+        .andExpect(jsonPath("$.clusterRegions[0].fullPath").value(REGION_PATH))
+        .andExpect(jsonPath("$.clusterRegions[0].regionType").value(REGION_TYPE))
+    ;
+  }
+
+  @Test
+  public void dataBrowserQuery() throws Exception {
+    doReturn(mapper.createObjectNode().put("foo", "bar")).when(cluster).executeQuery(anyString(), anyString(), anyInt());
+
+    this.mockMvc.perform(get("/dataBrowserQuery")
+        .param("query", "SELECT * FROM " + REGION_PATH)
+        .param("members", MEMBER_NAME)
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.foo").value("bar"))
+    ;
+  }
+
+  @Test
+  public void dataBrowserQueryHistory() throws Exception {
+    dataBrowserQuery();
+
+    this.mockMvc.perform(get("/dataBrowserQueryHistory")
+        .param("action", "view")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.queryHistory[0].queryText").value("\"SELECT * FROM " + REGION_PATH + "\""))
+    ;
+  }
+
+  @Test
+  public void pulseProductSupport() throws Exception {
+    this.mockMvc.perform(get("/pulseProductSupport")
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.product").value("gemfire"))
+    ;
+  }
+
+  @Test
+  public void getQueryStatisticsGridModel() throws Exception {
+    this.mockMvc.perform(get("/getQueryStatisticsGridModel")
+        .principal(principal)
+        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
+        .andExpect(status().isOk())
+        .andExpect(jsonPath("$.columnNames", containsInAnyOrder("Query",
+            "NumExecution",
+            "TotalExecutionTime(ns)",
+            "NumExecutionsInProgress",
+            "NumTimesCompiled",
+            "NumTimesGlobalIndexLookup",
+            "NumRowsModified",
+            "ParseTime(ms)",
+            "BindTime(ms)",
+            "OptimizeTime(ms)",
+            "RoutingInfoTime(ms)",
+            "GenerateTime(ms)",
+            "TotalCompilationTime(ms)",
+            "ExecutionTime(ns)",
+            "ProjectionTime(ns)",
+            "RowsModificationTime(ns)",
+            "QNNumRowsSeen",
+            "QNMsgSendTime(ns)",
+            "QNMsgSerTime(ns)",
+            "QNRespDeSerTime(ns)")))
+    ;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemFireDistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemFireDistributedSystem.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemFireDistributedSystem.java
new file mode 100644
index 0000000..90c66c0
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemFireDistributedSystem.java
@@ -0,0 +1,324 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.testbed;
+
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+
+
+/**
+ * 
+ * TODO
+ * 0. SystemAlerts
+ * 1. Operations like member-up/down/crash, region create/destroy [7.5 scope]
+ * 2. Read events like member-up/down/crash, region create/destroy [7.5 scope]
+ * 3. PropFile Writing
+ * 4. Link to other remote systems, topology - multi-cluster [7.5] 
+ * 
+ *
+ */
+public class GemFireDistributedSystem {
+  
+  private static final String SERVERS = "servers";
+  private static final String LOCATORS_NAME = LOCATORS;
+  private static final String PEERS = "peers";
+  private static final String HOSTS = "hosts";
+  private static final String REGIONS = "regions";
+  private static final String CLIENTS = "clients";
+  private static final String SEP = ".";
+  private static final String FUNCTIONS = null;
+  private static final String CQS = null;
+  
+  
+  List<Server> servers = new ArrayList<Server>();
+  List<Client> clients = new ArrayList<Client>();
+  List<Locator> locators = new ArrayList<Locator>();
+  List<Peer> peers = new ArrayList<Peer>();
+  List<Host> hosts = new ArrayList<Host>();
+  List<Region> regions = new ArrayList<Region>();
+  List<Function> functions = new ArrayList<Function>();
+  List<CQ> cqs = new ArrayList<CQ>();
+  String dsName = null;
+  
+  public GemFireDistributedSystem(String name,Properties pr){
+    PropFileHelper propertiesFile = new PropFileHelper(pr);
+    this.dsName = name;
+    readGemfireDS(propertiesFile);
+  }
+  
+  public GemFireDistributedSystem(String name,String fileName) throws IOException{
+    PropFileHelper propertiesFile = new PropFileHelper(fileName);
+    this.dsName = name;
+    readGemfireDS(propertiesFile);
+  }
+  
+  private void readGemfireDS(PropFileHelper propertiesFile) {
+    String serverStrings[] = propertiesFile.readValues(dsName + SEP + SERVERS);
+    System.out.println("Servers = " + serverStrings.length);
+    for(String serverName : serverStrings){
+      Server server = new Server();
+      server.init(propertiesFile,dsName,serverName);
+      servers.add(server);
+    }  
+    
+    String clientStrings[] = propertiesFile.readValues(dsName + SEP + CLIENTS);
+    System.out.println("Clients = " + clientStrings.length);
+    for(String clientName : clientStrings){
+      Client client = new Client();
+      client.init(propertiesFile,dsName,clientName);
+      clients.add(client);
+    }  
+    
+    String locatorStrings[] = propertiesFile.readValues(dsName + SEP + LOCATORS);
+    System.out.println("Locators = " + locatorStrings.length);
+    for(String locatorName : locatorStrings){
+      Locator locator = new Locator();
+      locator.init(propertiesFile,dsName,locatorName);
+      locators.add(locator);
+    }
+    
+    String peerStrings[] = propertiesFile.readValues(dsName + SEP + PEERS);
+    System.out.println("Peers = " + peerStrings.length);
+    for(String peerName : peerStrings){
+      Peer peer = new Peer();
+      peer.init(propertiesFile,dsName,peerName);
+      peers.add(peer);
+    }
+    
+    String hostsStrings[] = propertiesFile.readValues(dsName + SEP + HOSTS);
+    for(String hostName : hostsStrings){
+      Host host = new Host();
+      host.init(propertiesFile,dsName,hostName);
+      hosts.add(host);
+    }
+    
+    String regionsStrings[] = propertiesFile.readValues(dsName + SEP + REGIONS);
+    for(String regionName : regionsStrings){
+      Region region = new Region();
+      region.init(propertiesFile,dsName,regionName);
+      regions.add(region);
+    }
+    
+    String functionStrings[] = propertiesFile.readValues(dsName + SEP + FUNCTIONS);
+    for(String functionName : functionStrings){
+      Function function = new Function();
+      function.init(propertiesFile,dsName,functionName);
+      functions.add(function);
+    }    
+    
+    String cqStrings[] = propertiesFile.readValues(dsName + SEP + CQS);
+    for(String cqName : cqStrings){
+      CQ cq = new CQ();
+      cq.init(propertiesFile,dsName,cqName);
+      cqs.add(cq);
+    }
+    
+  }
+  
+  public List<Region> getRegions(String memberName) {    
+    List<Region> list = new ArrayList<Region>();
+    for(Region r : regions){
+      if(r.getMembers().contains(memberName))
+          list.add(r);
+    }
+    return list;
+   }
+  
+  public Region getRegion(String regionName) {
+    Region r = null;
+    for (Region rn : getRegions()) {
+      if (rn.getName().equals(regionName)) {
+        r = rn;
+        break;
+      }
+    }
+    return r;
+  }
+
+  public List<Region> getRegions() {
+   return regions;
+  }
+  
+  public List<Function> getFunction() {
+    return functions;
+  }
+  
+  public List<CQ> getCQs() {
+    return cqs;
+  }
+  
+  public List<Server> getServers(){
+    return servers;    
+  }
+  
+  public List<Client> getClients(){
+    return clients;
+  }
+  
+  public List<Peer> getPeers(){
+    return peers;    
+  }
+  
+  public List<Locator> getLocators(){
+    return locators;    
+  }
+  
+  public List<Host> getPhysicalHosts(){
+    return hosts;    
+  }
+  
+  public static class Base{
+    protected Map<String,String> properties=null;
+    protected String name;
+    
+    public void init(PropFileHelper propertiesFile, String dsName, String name) {
+      this.name = name;      
+      String leadingkey = dsName + SEP + name;
+      Map<String,String> map = propertiesFile.readObject(leadingkey);
+      map.put("name",name);
+      this.properties = map;
+    }
+    
+    public String getName(){
+      return properties.get("name");
+    }
+    
+    public String key(String string) {
+      return properties.get(string);
+    }
+    
+    public int keyInt(String string) {
+      String str = properties.get(string);
+      try{
+        int index = Integer.parseInt(str);
+        return index;
+      }catch(Exception e){
+        return -1;
+      }
+    }
+    
+    public List<String> values(String string) {
+      String values= properties.get(string);
+      String array[] = values.split(",");
+      List<String> list = new ArrayList<String>();
+      for(String s:array)
+        list.add(s);
+      return list;
+    }
+    
+  }
+  
+  public static class Host extends Base{
+    
+  }
+  
+  public static class Server extends Base{
+    public String toString(){
+      return properties.get("name") + "[on host=" + properties.get("host");
+    }
+    
+    public String getHost(){
+      return properties.get("host");
+    }
+  }
+  
+  public static class Client extends Base{
+    public String toString(){
+      return properties.get("name") ;//+ "[on host=" + properties.get("host");
+    }
+    
+    public String getHost(){
+      return properties.get("host");
+    }
+  }
+  
+  public static class Locator extends Base{
+    public String getHost(){
+      return properties.get("host");
+    }
+  }
+  
+  public static class Peer extends Base{
+
+    public String getHost(){
+      return properties.get("host");
+    }
+  }
+  
+  public static class Region extends Base{
+    public String toString(){
+      return properties.get("name") + "[type=" + properties.get("type");
+    }
+    
+    public String getType(){
+      return key("type");
+    }
+    
+    public int getEntryCount(){
+      return keyInt("entryCount");
+    }
+    
+    public List<String> getWanSenders(){
+      return values("wanSenders");
+    }
+    
+    public List<String> getMembers(){
+      return values("members");
+    }
+    
+  }
+  
+  public static class WanSender extends Base{
+    
+  }
+
+  public static class Function extends Base{
+    public String getMemberId(){
+      return key("memberId");
+    }    
+  }
+  
+  public static class CQ extends Base{
+    public String getQuery(){
+      return key("query");
+    }    
+    
+    public String getClient(){
+      return key("client");
+    }
+  }
+  
+  public static class SystemAlert extends Base{
+    //TODO
+  }
+  
+  public static void main(String[] args) throws IOException {
+    
+    GemFireDistributedSystem ds = new GemFireDistributedSystem("t1", "config/testbed.properties");
+    System.out.println("Servers = " + ds.getServers());    
+    System.out.println("Regions = " + ds.getRegions());
+    System.out.println("Clients = " + ds.getClients());
+  } 
+  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemfireTopology.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemfireTopology.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemfireTopology.java
new file mode 100644
index 0000000..b5028a9
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/GemfireTopology.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 org.apache.geode.tools.pulse.testbed;
+
+public class GemfireTopology {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropFileHelper.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropFileHelper.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropFileHelper.java
new file mode 100644
index 0000000..4f00ab1
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropFileHelper.java
@@ -0,0 +1,115 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.testbed;
+
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.FileNotFoundException;
+import java.io.IOException;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
+public class PropFileHelper {
+  
+  private String filePath=null;
+  private Properties pr=null;
+  
+  public PropFileHelper(String filePath) throws FileNotFoundException, IOException{
+    this.filePath = filePath;
+    pr = new Properties();
+    pr.load(new FileInputStream(new File(this.filePath)));
+  }
+  
+  public PropFileHelper(Properties pr2) {
+    this.pr =pr2;
+  }
+
+  public String[] readValues(String property){
+    return readValues(property,",");
+  }
+  
+  public String[] readValues(String property, String separator){
+    String value = readKey(property);
+    if(value!=null){
+      String[] array = value.split(separator);
+      return array;
+    }else{
+      return new String[0];
+    }
+  }
+  
+  public String readKey(String key){
+    String value = pr.getProperty(key);
+    if(value!=null)
+      return value.trim();
+    else return value;
+  }
+  
+  public Map<String,String> readObject(String leadingkey){
+    Map<String,String> map = new HashMap<String,String>();
+    String leadingKeyString = leadingkey+"."; 
+    for(Object keyObject : pr.keySet()){
+      String key = (String)keyObject;
+      String value = readKey(key);
+      if(key.startsWith(leadingKeyString)){
+        String innerProp = key.substring(leadingKeyString.length());
+        /* inner object stuff
+        if(checkForMultipleValues){
+          if(innerProp.contains(separator)){
+            String array[] = readValues(key);
+          }
+        }else*/
+        {
+          //System.out.println("Adding prop with key " + innerProp + " k=" + leadingkey);
+          map.put(innerProp, value);
+        }      
+      }
+    }    
+    return map;
+  }
+  
+  public static void main(String[] args) {
+    
+    Properties pr = new Properties();
+    pr.put("topologies", "t1,t2");
+    pr.put("t1.id", "1");
+    pr.put("t2.id", "2");
+    
+    pr.put("t1.prop1", "prop11");
+    pr.put("t1.prop2", "prop12");
+    pr.put("t1.prop3", "prop13");
+    pr.put("t2.prop1", "1");
+    pr.put("t2.prop2", "2");
+    pr.put("t2.prop3", "3");
+    
+    PropFileHelper helper = new PropFileHelper(pr);
+    String topologies[] = helper.readValues("topologies");
+    for(String topology : topologies){
+      Map<String,String> topologyMap = helper.readObject(topology);
+      System.out.println(topologyMap);
+    }
+    
+  }
+
+  public Properties getProperties() {
+    return pr;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropMockDataUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropMockDataUpdater.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropMockDataUpdater.java
new file mode 100644
index 0000000..e1659fb
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/PropMockDataUpdater.java
@@ -0,0 +1,513 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.testbed;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Cluster.Alert;
+import org.apache.geode.tools.pulse.internal.data.Cluster.Client;
+import org.apache.geode.tools.pulse.internal.data.Cluster.GatewayReceiver;
+import org.apache.geode.tools.pulse.internal.data.Cluster.GatewaySender;
+import org.apache.geode.tools.pulse.internal.data.Cluster.Member;
+import org.apache.geode.tools.pulse.internal.data.Cluster.Region;
+import org.apache.geode.tools.pulse.internal.data.IClusterUpdater;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Locator;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Peer;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Server;
+
+import java.io.FileNotFoundException;
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Map.Entry;
+import java.util.Random;
+import java.util.ResourceBundle;
+
+public class PropMockDataUpdater implements IClusterUpdater {
+  private static final int MAX_HOSTS = 40;
+  private static final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+  private final ResourceBundle resourceBundle = Repository.get().getResourceBundle();
+  private static final int POLL_INTERVAL = 5000;
+  public static final int MAX_SAMPLE_SIZE = 180;
+  public static final int ALERTS_MAX_SIZE = 1000;
+  public static final int PAGE_ALERTS_MAX_SIZE = 100;
+
+  private Cluster cluster= null;
+  private TestBed testbed;
+  private final String testbedFile = System.getProperty("pulse.propMockDataUpdaterFile");;
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public PropMockDataUpdater(Cluster cluster) {
+    this.cluster = cluster;
+    try {
+      loadPropertiesFile();
+    } catch (FileNotFoundException e) {
+      throw new RuntimeException(e);
+    } catch (IOException e) {
+      throw new RuntimeException(e);
+    }
+  }
+
+  private void loadPropertiesFile() throws FileNotFoundException, IOException{
+    this.testbed = new TestBed(testbedFile,true);
+  }
+
+  /**
+   * function used for updating Cluster data
+   * for Mock
+   */
+  @Override
+  public boolean updateData() {
+    cluster.setConnectedFlag(true);
+    Random r = new Random(System.currentTimeMillis());
+    long totalHeapSize = Math.abs(r.nextInt(3200 - 2048) + 2048);
+    cluster.setTotalHeapSize(totalHeapSize);
+    long usedHeapSize  = Math.abs(r.nextInt(2048));
+    cluster.setUsedHeapSize(usedHeapSize);
+    double writePerSec = Math.abs(r.nextInt(100));
+    cluster.setWritePerSec(writePerSec);
+
+    //propfile
+    cluster.setSubscriptionCount(testbed.getRootDs().getClients().size());
+    cluster.setRegisteredCQCount((long) testbed.getRootDs().getCQs().size());
+    cluster.setRunningFunctionCount(testbed.getRootDs().getFunction().size());
+
+
+    cluster.setClusterId( Math.abs(r.nextInt(100)));
+    cluster.getWritePerSecTrend().add(writePerSec);
+    cluster.setDiskWritesRate(writePerSec);
+
+    long garbageCollectionCount = Math.abs(r.nextInt(100));
+    cluster.setGarbageCollectionCount(garbageCollectionCount);
+    cluster.getGarbageCollectionTrend().add(garbageCollectionCount);
+
+    long readPerSec = Math.abs(r.nextInt(100));
+    cluster.setReadPerSec(readPerSec);
+    cluster.getReadPerSecTrend().add(readPerSec);
+
+    long diskReadsRate = readPerSec;cluster.setDiskReadsRate(diskReadsRate);
+    cluster.setDiskReadsRate(readPerSec);
+    long queriesPerSec = Math.abs(r.nextInt(100));
+    cluster.setQueriesPerSec(queriesPerSec);
+    cluster.getQueriesPerSecTrend().add(queriesPerSec);
+
+    long loadPerSec = Math.abs(r.nextInt(100));
+    cluster.setLoadPerSec(loadPerSec);
+    cluster.setTotalHeapSize(totalHeapSize);
+    long totalBytesOnDisk = totalHeapSize;
+    cluster.setTotalBytesOnDisk(totalBytesOnDisk);
+
+    cluster.getTotalBytesOnDiskTrend().add(totalBytesOnDisk);
+
+    cluster.getMemoryUsageTrend().add(usedHeapSize);
+    cluster.getThroughoutWritesTrend().add(writePerSec);
+
+    cluster.setMemberCount(0);
+
+    Map<String,Cluster.Member>  membersHMap = cluster.getMembersHMap();
+    List<Cluster.Region> regionsList = (List<Cluster.Region>)cluster.getClusterRegions().values();
+    Map<String, Boolean> wanInformation = cluster.getWanInformation();
+
+    // Create 3 members first time around
+    int locatorCount=0;
+    if (membersHMap.size() == 0) {
+      for(Locator locator : testbed.getRootDs().getLocators()){
+        String id = "(Launcher_Locator-1099-13-40-24-5368)-"+locatorCount++;
+        String name = locator.getName();
+        membersHMap.put(id+name, initializeMember(id,name, true, true, true, false, locator.getHost()));
+      }
+      cluster.setLocatorCount(testbed.getRootDs().getLocators().size());
+
+      int serverCount=0;
+      for(Server server : testbed.getRootDs().getServers()){
+        String id = "(Launcher_Server-1099-13-40-24-5368)-"+serverCount++;
+        String name = server.getName();
+        membersHMap.put(id+name, initializeMember(id,name, false, true, false, true, server.getHost()));
+      }
+      cluster.setServerCount(testbed.getRootDs().getServers().size());
+
+      int peerCount=0;
+      for(Peer peer : testbed.getRootDs().getPeers()){
+        String id = "(Launcher_Peer-1099-13-40-24-5368)-"+peerCount++;
+        String name = peer.getName();
+        membersHMap.put( id+name, initializeMember(id,name, false, true, false, false, peer.getHost()));
+      }
+
+      for(Entry<String, Member> memberSet : membersHMap.entrySet())
+      {
+        HashMap<String,Cluster.Region> memberRegions = new HashMap<String,Cluster.Region>();
+        HashMap<String,Cluster.Client> memberClientsHM = new HashMap<String,Cluster.Client>();
+
+        Random randomGenerator = new Random();
+
+        //Read from property file
+        int randomInt = (randomGenerator.nextInt(5)) + 1;
+        List<org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Region> thisMemberRegions = testbed.getRootDs().getRegions(memberSet.getValue().getName());
+
+        int regionExists = 0;
+        int index=0;
+        for (org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Region thisMemberRegion : thisMemberRegions) {
+          Region region = initMemberRegion(index++,thisMemberRegion.getName(),memberSet.getValue().getName(),
+              thisMemberRegion.getEntryCount(),thisMemberRegion.getType(), thisMemberRegion.getMembers().size()); //read from property file
+          if (regionsList.size() > 0) {
+            for (Region clusterRegion : regionsList) {
+              if ((region.getName()).equals(clusterRegion.getName())) {
+                clusterRegion.getMemberName().add(memberSet.getValue().getName());
+                //clusterRegion.memberCount = clusterRegion.memberCount + 1;
+                //int mcount = clusterRegion.getMemberCount() + 1;
+                //clusterRegion.setMemberCount(mcount);
+                regionExists = 1;
+                break;
+              }
+            }
+            if (regionExists == 0){
+              regionsList.add(region);
+            }
+          } else{
+            regionsList.add(region);
+          }
+          memberRegions.put(region.getFullPath(),region);
+          //totalRegionCount = regionsList.size();
+          cluster.setTotalRegionCount(regionsList.size());
+        }
+        membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
+
+        if (memberSet.getValue().isCache()) {
+          Client client = initMemberClient(0, memberSet.getValue().getHost()); //read from prop File
+          memberClientsHM.put(client.getId(), client);
+          randomInt = randomGenerator.nextInt(10);
+          for (int y = 1; y < randomInt; y++) {
+            Client newClient = initMemberClient(y, memberSet.getValue()
+                .getHost());
+            memberClientsHM.put(newClient.getId(), newClient);
+          }
+          membersHMap.get(memberSet.getKey()).updateMemberClientsHMap(memberClientsHM);
+          /*clientConnectionCount = clientConnectionCount
+              + membersHMap.get(memberSet.getKey()).getMemberClientsHMap().size();*/
+          long clientConnectionCount = cluster.getClientConnectionCount() + membersHMap.get(memberSet.getKey()).getMemberClientsHMap().size();
+          cluster.setClientConnectionCount(clientConnectionCount);
+        }
+
+      }
+    }
+    wanInformation.clear(); //read from property file
+    int wanInfoSize = Math.abs(r.nextInt(10));
+    wanInfoSize++;
+    for (int i = 0; i < wanInfoSize; i++) {
+      String name = "Mock Cluster" + i;
+      Boolean value = false;
+      if (i % 2 == 0){
+        value = true;
+      }
+      wanInformation.put(name, value);
+    }
+    //memberCount = membersHMap.size();
+    cluster.setMemberCount(membersHMap.size());
+
+    totalHeapSize = 0;
+    for(Entry<String, Member> memberSet : membersHMap.entrySet())
+    {
+      refresh(membersHMap.get(memberSet.getKey()));
+      Member member = membersHMap.get(memberSet.getKey());
+      totalHeapSize += member.getCurrentHeapSize();
+    }
+
+    for (Region region : regionsList) {
+      region.setGetsRate((Math.abs(r.nextInt(100))) + 1);
+      region.setPutsRate((Math.abs(r.nextInt(100))) +1);
+      region.getGetsPerSecTrend().add(region.getGetsRate());
+      region.getPutsPerSecTrend().add(region.getPutsRate());
+    }
+
+    return true;
+  }
+
+
+  private Region initMemberRegion(int count, String regionName, String memName, int entryCount, String type, int memberCount) {
+    Region memberRegion = new Region();
+    memberRegion.setName(regionName);
+    memberRegion.setFullPath("/"+regionName);
+    Random randomGenerator = new Random();
+    memberRegion.setSystemRegionEntryCount(entryCount);
+    // memberRegion.setEntrySize("N/A");
+    memberRegion.setEntrySize(Math.abs(randomGenerator.nextInt(10)));
+    memberRegion.setDiskStoreName("ABC");
+    memberRegion.setScope("DISTRIBUTED_NO_ACK");
+    memberRegion.setDiskSynchronous(true);
+    memberRegion.setRegionType(type);
+    if(type.contains("PERSISTENT"))
+      memberRegion.setPersistentEnabled(true);
+    else
+      memberRegion.setPersistentEnabled(false);
+    if (count % 2 == 0){
+      memberRegion.setWanEnabled(true);
+    }
+    else{
+      memberRegion.setWanEnabled(false);
+    }
+    memberRegion.setWanEnabled(true);
+    /*memberRegion.setSystemRegionEntryCount(Long.valueOf(String.valueOf(Math
+        .abs(randomGenerator.nextInt(100)))));*/
+    memberRegion.getMemberName().add(memName);
+    memberRegion.setMemberCount(memberCount);
+    return memberRegion;
+  }
+
+
+  private Client initMemberClient(int count, String host) {
+
+    Client memberClient = new Client();
+    Random r = new Random(System.currentTimeMillis());
+    memberClient.setName("Name_" + count);
+    long processCpuTime = (long) (r.nextDouble() * 100);
+    memberClient.setProcessCpuTime(processCpuTime);
+    memberClient.setCpuUsage(0);
+    memberClient.setGets(Math.abs(r.nextInt(100)));
+    memberClient.setHost(host);
+    memberClient.setId(String.valueOf(1000 + count));
+    memberClient.setPuts(Math.abs(r.nextInt(100)));
+    memberClient.setCpus(Math.abs(r.nextInt(20)));
+    memberClient.setQueueSize(Math.abs(r.nextInt(100)));
+    if ((count % 2) == 0){
+      memberClient.setStatus("up");
+    }
+    else{
+      memberClient.setStatus("down");
+    }
+    memberClient.setThreads(Math.abs(r.nextInt(100)));
+    memberClient
+        .setUptime(Math.abs(System.currentTimeMillis() - r.nextLong()));
+
+    return memberClient;
+  }
+
+  private Member initializeMember(String id, String name, boolean manager,
+      boolean isCache, boolean isLocator, boolean isServer, String host) {
+    Member m = new Member();
+
+    m.setId(id);
+    m.setName(name);
+
+    //m.setHost(getHostName(System.currentTimeMillis()));
+    m.setHost(host);
+
+    m.setMaxHeapSize(247);
+
+    Random r = new Random(System.currentTimeMillis());
+
+    m.setCache(isCache);
+    m.setLocator(isLocator);
+    m.setServer(isServer);
+    m.setManager(manager);
+
+    m.setLoadAverage((double) Math.abs(r.nextInt(100)));
+    m.setNumThreads(Math.abs(r.nextInt(100)));
+    m.setGarbageCollectionCount((long) Math.abs(r.nextInt(100)));
+    m.getGarbageCollectionSamples().add(m.getGarbageCollectionCount());
+
+    m.setTotalFileDescriptorOpen((long) Math.abs(r.nextInt(100)));
+    m.setTotalDiskUsage(Math.abs(r.nextInt(100)));
+
+
+    m.setThroughputWrites(Math.abs(r.nextInt(10)));
+    m.getThroughputWritesTrend().add(m.getThroughputWrites());
+
+    GatewayReceiver gatewayReceiver = m.getGatewayReceiver();
+    String port  = cluster.getPort();
+    if(port==null || "".equals(port))
+      port = "1099";
+    gatewayReceiver.setListeningPort(Integer.parseInt(port));
+    gatewayReceiver.setLinkThroughput(Math.abs(r.nextInt(10)));
+    gatewayReceiver.setAvgBatchProcessingTime((long) Math.abs(r.nextInt(10)));
+    gatewayReceiver.setId(String.valueOf(Math.abs(r.nextInt(10))));
+    gatewayReceiver.setQueueSize(Math.abs(r.nextInt(10)));
+    gatewayReceiver.setStatus(true);
+    gatewayReceiver.setBatchSize(Math.abs(r.nextInt(10)));
+
+    int gatewaySenderCount = Math.abs(r.nextInt(10));
+
+    List<GatewaySender> list = m.getGatewaySenderList();
+
+    for (int i = 0; i < gatewaySenderCount; i++) {
+      list.add(createGatewaySenderCount(r));
+    }
+
+    Map<String, List<Member>> physicalToMember = cluster.getPhysicalToMember();
+
+    List<Cluster.Member> memberArrList = physicalToMember.get(m.getHost());
+    if (memberArrList != null){
+      memberArrList.add(m);
+    }
+    else {
+      ArrayList<Cluster.Member> memberList = new ArrayList<Cluster.Member>();
+      memberList.add(m);
+      physicalToMember.put(m.getHost(), memberList);
+    }
+    int memberCount = cluster.getMemberCount();memberCount++;cluster.setMemberCount(memberCount);
+    return m;
+  }
+
+  private GatewaySender createGatewaySenderCount(Random r) {
+
+    GatewaySender gatewaySender = new GatewaySender();
+
+    gatewaySender.setBatchSize(Math.abs(r.nextInt(10)));
+    gatewaySender.setId(String.valueOf(Math.abs(r.nextInt(10))));
+    gatewaySender.setLinkThroughput(Math.abs(r.nextInt(10)));
+    gatewaySender.setPersistenceEnabled(true);
+    gatewaySender.setPrimary(true);
+    gatewaySender.setQueueSize(Math.abs(r.nextInt(10)));
+    gatewaySender.setSenderType(false);
+    gatewaySender.setStatus(true);
+
+    return gatewaySender;
+  }
+
+  /*
+  private String getHostName(long rndSeed) {
+    Random rnd = new Random(rndSeed);
+    String hName = null;
+
+    int index = Math.abs(rnd.nextInt(MAX_HOSTS));
+
+    ArrayList<String> hostNames = cluster.getHostNames();
+
+    if (hostNames.size() <= index) {
+      hName = "host" + hostNames.size();
+      hostNames.add(hName);
+    } else {
+      hName = hostNames.get(index);
+    }
+
+    Map<String, ArrayList<Member>> physicalToMember = cluster.getPhysicalToMember();
+
+    ArrayList<Member> memberArrList = physicalToMember.get(hName);
+    if (memberArrList != null) {
+      if (memberArrList.size() > 4){
+        hName = getHostName(rndSeed + rnd.nextLong());
+      }
+    }
+    return hName;
+  }*/
+
+  private void refresh(Member m) {
+    if(LOGGER.infoEnabled()){
+      LOGGER.info(resourceBundle.getString("LOG_MSG_REFRESHING_MEMBER_DATA")+" : " + m.getName());
+    }
+
+    Random r = new Random(System.currentTimeMillis());
+
+    m.setUptime(System.currentTimeMillis());
+    m.setQueueBacklog("" + Math.abs(r.nextInt(500)));
+    m.setCurrentHeapSize(Math.abs(r.nextInt(Math.abs((int) m.getMaxHeapSize()))));
+    m.setTotalDiskUsage(Math.abs(r.nextInt(100)));
+
+    double cpuUsage = r.nextDouble() * 100;
+    m.getCpuUsageSamples().add(cpuUsage);
+    m.setCpuUsage(cpuUsage);
+
+    m.getHeapUsageSamples().add(m.getCurrentHeapSize());
+    m.setLoadAverage((double) Math.abs(r.nextInt(100)));
+    m.setNumThreads(Math.abs(r.nextInt(100)));
+    m.setGarbageCollectionCount((long) Math.abs(r.nextInt(100)));
+    m.getGarbageCollectionSamples().add(m.getGarbageCollectionCount());
+
+    m.setTotalFileDescriptorOpen((long) Math.abs(r.nextInt(100)));
+
+    m.setThroughputWrites(Math.abs(r.nextInt(10)));
+    m.getThroughputWritesTrend().add(m.getThroughputWrites());
+
+    m.setGetsRate(Math.abs(r.nextInt(5000)));
+    m.getGetsPerSecond().add(m.getGetsRate());
+
+    m.setPutsRate(Math.abs(r.nextInt(5000)));
+    m.getPutsPerSecond().add(m.getPutsRate());
+
+    Alert[] alerts = cluster.getAlertsList();
+    List<Alert> alertsList = Arrays.asList(alerts);
+
+    if (r.nextBoolean()) {
+      // Generate alerts
+      if (r.nextBoolean()) {
+        if (r.nextInt(10) > 5) {
+          alertsList.add(createAlert(Alert.SEVERE, m.getName(), alertsList.size()));
+          if(alertsList.size() > ALERTS_MAX_SIZE){
+            alertsList.remove(0);
+          }
+        }
+      }
+
+      if (r.nextBoolean()) {
+        if (r.nextInt(10) > 5) {
+          alertsList.add(createAlert(Alert.ERROR, m.getName(), alertsList.size()));
+          if(alertsList.size() > ALERTS_MAX_SIZE){
+            alertsList.remove(0);
+          }
+        }
+      }
+
+      if (r.nextBoolean()) {
+        if (r.nextInt(10) > 5) {
+          alertsList.add(createAlert(Alert.WARNING, m.getName(), alertsList.size()));
+          if(alertsList.size() > ALERTS_MAX_SIZE){
+            alertsList.remove(0);
+          }
+        }
+      }
+    }
+  }
+
+  private Alert createAlert(int sev, String memberName, int index) {
+
+    Alert alert = new Alert();
+    alert.setSeverity(sev);
+    alert.setId(index);
+    alert.setMemberName(memberName);
+    alert.setTimestamp(new Date());
+
+    switch (sev) {
+    case Alert.SEVERE:
+      alert.setDescription(PulseConstants.ALERT_DESC_SEVERE);
+      break;
+    case Alert.ERROR:
+      alert.setDescription(PulseConstants.ALERT_DESC_ERROR);
+      break;
+    case Alert.WARNING:
+      alert.setDescription(PulseConstants.ALERT_DESC_WARNING);
+      break;
+    }
+    return alert;
+  }
+
+  @Override
+  public ObjectNode executeQuery(String queryText, String members, int limit) {
+    // TODO for Sushant/Sachin - Add implementation for MockUpdater for Automation
+    return null;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/TestBed.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/TestBed.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/TestBed.java
new file mode 100644
index 0000000..fa61e29
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/TestBed.java
@@ -0,0 +1,84 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.testbed;
+
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.FileNotFoundException;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.Properties;
+
+public class TestBed {
+  
+  private String fileName=null;
+  PropFileHelper propertiesFile =null;
+  GemFireDistributedSystem ds = null;
+
+  public TestBed(){
+    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+    InputStream inputStream = classLoader.getResourceAsStream("testbed.properties");
+    Properties properties = new Properties();
+    try {
+      properties.load(inputStream);
+    } catch (IOException e) {
+      e.printStackTrace();
+      throw new RuntimeException(e);
+    }
+    propertiesFile = new PropFileHelper(properties);
+    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
+  }
+
+  public TestBed(String fileName) throws FileNotFoundException, IOException{
+    this.fileName = fileName;
+    propertiesFile = new PropFileHelper(fileName);
+    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
+  }
+  
+  
+  public TestBed(String fileName,boolean flag) throws FileNotFoundException, IOException{    
+//    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+//    InputStream inputStream = classLoader.getResourceAsStream("testbed.properties");
+//    System.out.println("Inputstream : " + inputStream);
+    Properties properties = new Properties();
+    try {
+      properties.load(new FileInputStream(new File(fileName)));
+    } catch (IOException e) {
+      e.printStackTrace();
+      throw new RuntimeException(e);
+    }    
+    this.fileName = fileName;
+    propertiesFile = new PropFileHelper(properties);
+    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
+  }
+  
+  
+  public String getBrowserForDriver(){
+    return propertiesFile.readKey("browser");
+  }
+  
+  public String getBrowserVersionForDriver(String browser){
+    return propertiesFile.readKey("browserVersion");
+  }
+  
+  public GemFireDistributedSystem getRootDs(){
+    return ds;
+  }  
+
+}
\ No newline at end of file


[58/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseBaseTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseBaseTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseBaseTest.java
deleted file mode 100644
index a854a48..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseBaseTest.java
+++ /dev/null
@@ -1,693 +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 com.vmware.geode.tools.pulse.tests;
-
-import static com.vmware.geode.tools.pulse.tests.PulseAbstractTest.*;
-import static org.junit.Assert.*;
-
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.TreeMap;
-import java.util.concurrent.TimeUnit;
-
-import org.openqa.selenium.By;
-import org.openqa.selenium.WebElement;
-import org.openqa.selenium.interactions.Actions;
-import org.openqa.selenium.support.ui.ExpectedConditions;
-import org.openqa.selenium.support.ui.WebDriverWait;
-
-public class PulseBaseTest {
-
-  public static int maxWaitTime = 20;
-
-  WebElement element = null;
-
-	public WebElement findElementUsingId(String id) {
-		return driver.findElement(By.id(id));
-	}
-	public WebElement findElementUsingXpath(String xpath) {
-		return driver.findElement(By.xpath(xpath));
-	}
-
-	public void clickElementUsingId(String id) {
-		findElementUsingId(id).click();
-	}
-
-	public void clickElementUsingXpath(String xpath) {
-		findElementUsingXpath(xpath).click();
-	}
-
-	public void enterTextUsingId(String id, String textToEnter) {
-		findElementUsingId(id).sendKeys(textToEnter);
-
-	}
-
-	public void enterTextUsingXpath(String xpath, String textToEnter) {
-		findElementUsingXpath(xpath).sendKeys(textToEnter);
-	}
-
-	public String getValueFromPropertiesFile(String key) {
-		return JMXProperties.getInstance().getProperty(key);
-	}
-
-	public void sendKeysUsingId(String Id, String textToEnter){
-		findElementById(Id).sendKeys(textToEnter);
-	}
-
-	public void waitForElement(WebElement element) {
-		driver.manage().timeouts().implicitlyWait(0, TimeUnit.SECONDS);
-		WebDriverWait wait = new WebDriverWait(driver, 20);
-		wait.until(ExpectedConditions.visibilityOf(element));
-	}
-
-	public WebElement findElementById(String id) {
-		return driver.findElement(By.id(id));
-	}
-
-	public WebElement findElementByXpath(String xpath) {
-		return driver.findElement(By.xpath(xpath));
-	}
-
-	public String getTextUsingXpath(String xpath) {
-		return findElementByXpath(xpath).getText();
-	}
-
-	public String getTextUsingId(String id) {
-		return findElementById(id).getText();
-	}
-
-	public String getPersistanceEnabled(Region r) {
-		String persitance = null;
-
-		if (r.getPersistentEnabled()) {
-			persitance = "ON";
-		} else if (!r.getPersistentEnabled()) {
-			persitance = "OFF";
-		}
-		return persitance;
-	}
-
-	public String getPersistanceEnabled(String trueOrFalse) {
-		String persitance = null;
-
-		if (trueOrFalse.contains("true")) {
-			persitance = "ON";
-		} else if (trueOrFalse.contains("false")) {
-			persitance = "OFF";
-		}
-		return persitance;
-	}
-
-	public String HeapUsage(String valueInKB) {
-
-		return null;
-	}
-
-	// WIP - need to work on this --
-	public HashMap<String, HashMap<String, Region>> getRegionDetailsFromUI(String regionName) {
-
-		String[] regionNames = JMXProperties.getInstance().getProperty("regions").split(" ");
-		HashMap<String, HashMap<String, Region>> regionUiMap = new HashMap<String, HashMap<String, Region>>();
-
-		for (String region : regionNames) {
-			HashMap<String, Region> regionMap = regionUiMap.get(region);
-		}
-
-		return regionUiMap;
-	}
-
-	public void validateServerGroupGridData() {
-		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='memberListSG']/tbody/tr"));
-		int rowsCount = serverGridRows.size();
-		String[][] gridDataFromUI = new String[rowsCount][7];
-
-		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
-			for (int i = 0; i <= 6; i++) {
-				gridDataFromUI[x][i] = driver.findElement(
-						By.xpath("//table[@id='memberListSG']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
-			}
-		}
-
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
-
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			String[] sgs = thisMember.getGroups();
-
-			for (String sgName : sgs) {
-				HashMap<String, Member> sgMembers = sgMap.get(sgName);
-				if (sgMembers == null) {
-					sgMembers = new HashMap<String, Member>();
-					sgMap.put(sgName, sgMembers);
-				}
-				sgMembers.put(thisMember.getMember(), thisMember);
-			}
-		}
-
-		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
-			String sgName = gridDataFromUI[i][0];
-			String memName = gridDataFromUI[i][1];
-			Member m = sgMap.get(sgName).get(memName);
-
-			assertEquals(sgName, gridDataFromUI[i][0]);
-			assertEquals(memName, gridDataFromUI[i][1]);
-			assertEquals(m.getMember(), gridDataFromUI[i][2]);
-			assertEquals(m.getHost(), gridDataFromUI[i][3]);
-			String cupUsage = String.valueOf(m.getCpuUsage());
-			assertEquals(cupUsage, gridDataFromUI[i][5]);
-		}
-
-	}
-
-	public void validateRedundancyZonesGridData() {
-		List<WebElement> rzGridRows = driver.findElements(By.xpath("//table[@id='memberListRZ']/tbody/tr"));
-		int rowsCount = rzGridRows.size();
-		String[][] gridDataFromUI = new String[rowsCount][7];
-
-		for (int j = 2, x = 0; j <= rzGridRows.size(); j++, x++) {
-			for (int i = 0; i <= 6; i++) {
-				gridDataFromUI[x][i] = driver.findElement(
-						By.xpath("//table[@id='memberListRZ']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
-			}
-		}
-
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
-
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			//String[] rz = thisMember.getRedundancyZone();
-			String sgName = thisMember.getRedundancyZone();
-
-			//for (String sgName : rz) {
-				HashMap<String, Member> rzMembers = rzMap.get(sgName);
-
-				if (rzMembers == null) {
-					rzMembers = new HashMap<String, Member>();
-					rzMap.put(sgName, rzMembers);
-				}
-
-				rzMembers.put(thisMember.getMember(), thisMember);
-			//}
-		}
-
-		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
-			String sgName = gridDataFromUI[i][0];
-			String memName = gridDataFromUI[i][1];
-			Member m = rzMap.get(sgName).get(memName);
-
-			assertEquals(sgName, gridDataFromUI[i][0]);
-			assertEquals(memName, gridDataFromUI[i][1]);
-			assertEquals(m.getMember(), gridDataFromUI[i][2]);
-			assertEquals(m.getHost(), gridDataFromUI[i][3]);
-			String cupUsage = String.valueOf(m.getCpuUsage());
-			assertEquals(cupUsage, gridDataFromUI[i][5]);
-		}
-
-	}
-
-	public void validateTopologyGridData() {
-		List<WebElement> rzGridRows = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
-		int rowsCount = rzGridRows.size();
-		String[][] gridDataFromUI = new String[rowsCount][8];
-
-		for (int j = 2, x = 0; j <= rzGridRows.size(); j++, x++) {
-			for (int i = 0; i <= 7; i++) {
-				gridDataFromUI[x][i] = driver.findElement(
-						By.xpath("//table[@id='memberList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
-			}
-		}
-
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, Member> tpMap = new HashMap<String, Member>();
-
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			tpMap.put(thisMember.getMember(), thisMember);
-
-		}
-
-		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
-
-			String memName = gridDataFromUI[i][0];
-			Member m = tpMap.get(memName);
-
-			assertEquals(m.getMember(), gridDataFromUI[i][0]);
-			assertEquals(m.getMember(), gridDataFromUI[i][1]);
-			assertEquals(m.getHost(), gridDataFromUI[i][2]);
-			String cupUsage = String.valueOf(m.getCpuUsage());
-			assertEquals(cupUsage, gridDataFromUI[i][5]);
-		}
-	}
-
-	public void validateDataPrespectiveGridData() {
-		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='regionsList']/tbody/tr"));
-		int rowsCount = serverGridRows.size();
-		String[][] gridDataFromUI = new String[rowsCount][7];
-
-		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
-			for (int i = 0; i <= 6; i++) {
-				if (i < 5) {
-					gridDataFromUI[x][i] = driver.findElement(
-							By.xpath("//table[@id='regionsList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
-				} else if (i == 5) {
-					gridDataFromUI[x][i] = driver.findElement(
-							By.xpath("//table[@id='regionsList']/tbody/tr[" + j + "]/td[" + (i + 4) + "]")).getText();
-				}
-			}
-		}
-
-		String[] regionNames = JMXProperties.getInstance().getProperty("regions").split(" ");
-		HashMap<String, Region> dataMap = new HashMap<String, Region>();
-
-		for (String region : regionNames) {
-			Region thisRegion = new Region(region);
-			dataMap.put(thisRegion.getName(), thisRegion);
-
-		}
-
-		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
-			String memName = gridDataFromUI[i][0];
-			Region r = dataMap.get(memName);
-
-			assertEquals(r.getName(), gridDataFromUI[i][0]);
-			assertEquals(r.getRegionType(), gridDataFromUI[i][1]);
-
-			assertEquals(String.valueOf(r.getSystemRegionEntryCount()), gridDataFromUI[i][2]);
-			assertEquals(r.getFullPath(), gridDataFromUI[i][4]);
-			assertEquals(getPersistanceEnabled(r), gridDataFromUI[i][5]);
-		}
-	}
-
-	public void validateRegionDetailsGridData() {
-		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
-		int rowsCount = serverGridRows.size();
-		String[][] gridDataFromUI = new String[rowsCount][7];
-
-		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
-			for (int i = 0; i < 2; i++) {
-				gridDataFromUI[x][i] = driver.findElement(
-						By.xpath("//table[@id='memberList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
-			}
-		}
-
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, Member> tpMap = new HashMap<String, Member>();
-
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			tpMap.put(thisMember.getMember(), thisMember);
-		}
-
-		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
-
-			String memName = gridDataFromUI[i][0];
-			Member m = tpMap.get(memName);
-			assertEquals(m.getMember(), gridDataFromUI[i][0]);
-		}
-
-	}
-
-	public void navigateToToplogyView(){
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.radioButtonXpath);
-	}
-
-	public void navigateToServerGroupGView(){
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
-	}
-
-	public void navigateToRedundancyZoneView(){
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
-	}
-
-	//  ------ 	Topology / Server Group / Redundancy Group - Tree View
-
-	public void navigateToTopologyTreeView(){
-		navigateToToplogyView();
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-	}
-
-	public void navigateToServerGroupTreeView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
-	}
-
-	public void navigateToRedundancyZonesTreeView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
-	}
-
-	//  ------ 	Topology / Server Group / Redundancy Group - Grid View
-
-	public void navigateToTopologyGridView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.radioButtonXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-	}
-
-	public void navigateToServerGroupGridView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
-		clickElementUsingId(PulseTestLocators.ServerGroups.gridButtonId);
-	}
-
-	public void navigateToRedundancyZonesGridView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
-		clickElementUsingId(PulseTestLocators.RedundancyZone.gridButtonId);
-	}
-
-	// ----- Data perspective / region details
-
-	public void navigateToDataPrespectiveGridView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.downarrowButtonXpath);
-		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.dataViewButtonXpath);
-		clickElementUsingId(PulseTestLocators.DataPerspectiveView.gridButtonId);
-	}
-
-	public void navigateToRegionDetailsView() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.downarrowButtonXpath);
-		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.dataViewButtonXpath);
-		// clickElementUsingXpath(PulseTestLocators.RegionDetailsView.regionNameXpath);
-		// // WIP - region navigation defect needs to fixed
-		clickElementUsingXpath(PulseTestLocators.RegionDetailsView.treeMapCanvasXpath);
-	}
-
-	public void navigateToRegionDetailsGridView() {
-		navigateToRegionDetailsView();
-		clickElementUsingXpath(PulseTestLocators.RegionDetailsView.gridButtonXpath);
-	}
-
-	public String getPropertyValue(String propertyKey) {
-		String propertyValue = JMXProperties.getInstance().getProperty(propertyKey);
-		return propertyValue;
-	}
-
-	public void verifyElementPresentById(String id) {
-		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
-		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.id(id)));
-	}
-
-	public void verifyElementPresentByLinkText(String lnkText) {
-		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
-		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.linkText(lnkText)));
-	}
-
-	public void verifyElementPresentByXpath(String xpath) {
-		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
-		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.xpath(xpath)));
-	}
-
-	public void verifyTextPresrntById(String id, String text) {
-		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
-		wait.until(ExpectedConditions.textToBePresentInElementLocated(By.id(id), text));
-	}
-
-	public void verifyTextPresrntByXpath(String xpath, String text) {
-		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
-		wait.until(ExpectedConditions.textToBePresentInElementLocated(By.xpath(xpath), text));
-	}
-
-	public void verifyElementAttributeById(String id, String attribute, String value) {
-		String actualValue = findElementById(id).getAttribute(attribute);
-		assertTrue(actualValue.equals(value) || actualValue.contains(value));
-	}
-
-
-	public void mouseReleaseById(String id){
-		verifyElementPresentById(id);
-		Actions action = new Actions(driver);
-		WebElement we = driver.findElement(By.id(id));
-		action.moveToElement(we).release().perform();
-	}
-	public void mouseClickAndHoldOverElementById(String id) {
-		verifyElementPresentById(id);
-		Actions action = new Actions(driver);
-		WebElement we = driver.findElement(By.id(id));
-		action.moveToElement(we).clickAndHold().perform();
-	}
-
-	public void mouseOverElementByXpath(String xpath) {
-		Actions action = new Actions(driver);
-		WebElement we = driver.findElement(By.xpath(xpath));
-		action.moveToElement(we).build().perform();
-	}
-
-
-	public float stringToFloat(String stringValue){
-		float floatNum = Float.parseFloat(stringValue);
-		return floatNum;
-	}
-
-	public String floatToString(float floatValue){
-		String stringValue = Float.toString(floatValue);
-		return stringValue;
-	}
-
-
-	public String[] splitString(String stringToSplit, String splitDelimiter){
-		String [] stringArray = stringToSplit.split(splitDelimiter);
-		return stringArray;
-	}
-
-	public void assertMemberSortingByCpuUsage(){
-		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
-		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
-		for (String member : membersNames) {
-			Member thisMember = new Member(member);
-			memberMap.put(thisMember.getCpuUsage(), thisMember.getMember());
-		}
-		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberCPUUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM2;
-			}else{
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM3;
-			}
-			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
-	    }
-	}
-
-	public void assertMemberSortingByHeapUsage(){
-		Map<Long, String> memberMap = new TreeMap<Long,String>(Collections.reverseOrder());
-		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
-		for (String member : membersNames) {
-			Member thisMember = new Member(member);
-			memberMap.put(thisMember.getCurrentHeapSize(), thisMember.getMember());
-		}
-		for(Map.Entry<Long, String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberHeapUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM2;
-			}else{
-				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM3;
-			}
-			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberHeapUsage));
-	    }
-	}
-
-	public void assertMemberSortingBySGCpuUsage(){
-		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
-		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
-		for (String member : membersNames) {
-			Member thisMember = new Member(member);
-			memberMap.put(thisMember.getCpuUsage(), thisMember.getMember());
-		}
-		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberCPUUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM2;
-			}else{
-				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM3;
-			}
-			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
-	    }
-	}
-
-
-	public void assertMemberSortingBySgHeapUsage(){
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			String[] sgs = thisMember.getGroups();
-
-			for (String sgName : sgs) {
-				HashMap<String, Member> sgMembers = sgMap.get(sgName);
-				if (sgMembers == null) {
-					sgMembers = new HashMap<String, Member>();
-					sgMap.put(sgName, sgMembers);
-				}
-				sgMembers.put(thisMember.getMember(), thisMember);
-			}
-		}
-		Map<Float, String> memberMap = new TreeMap<Float,String>(Collections.reverseOrder());
-
-		for(int sgId=1; sgId<=3; sgId++){
-			String sgName = "SG1";
-			String memName = "M" + sgId;
-			Member m = sgMap.get(sgName).get(memName);
-			memberMap.put((float) m.getCurrentHeapSize(), m.getMember());
-		}
-
-		for(Map.Entry<Float,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberCPUUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M2;
-			}else{
-				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M3;
-			}
-			assertTrue(findElementById("SG1(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
-	    }
-	}
-
-
-
-	public void assertMemberSortingBySgCpuUsage(){
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			String[] sgs = thisMember.getGroups();
-
-			for (String sgName : sgs) {
-				HashMap<String, Member> sgMembers = sgMap.get(sgName);
-				if (sgMembers == null) {
-					sgMembers = new HashMap<String, Member>();
-					sgMap.put(sgName, sgMembers);
-				}
-				sgMembers.put(thisMember.getMember(), thisMember);
-			}
-		}
-		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
-		//SG3(!)M3
-		for(int sgId=1; sgId<=3; sgId++){
-			String sgName = "SG1";
-			String memName = "M" + sgId;
-			Member m = sgMap.get(sgName).get(memName);
-			memberMap.put(m.getCpuUsage(), m.getMember());
-		}
-
-		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberCPUUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M2;
-			}else{
-				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M3;
-			}
-			assertTrue(findElementById("SG1(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
-	    }
-	}
-
-	public void assertMemberSortingByRzHeapUsage(){
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			String sgName = thisMember.getRedundancyZone();
-				HashMap<String, Member> rzMembers = rzMap.get(sgName);
-
-				if (rzMembers == null) {
-					rzMembers = new HashMap<String, Member>();
-					rzMap.put(sgName, rzMembers);
-				}
-
-				rzMembers.put(thisMember.getMember(), thisMember);
-		}
-		Map<Float, String> memberMap = new TreeMap<Float,String>(Collections.reverseOrder());
-		String rzName = "RZ1 RZ2";
-		String memName = "M1" ;
-		Member m = rzMap.get(rzName).get(memName);
-		memberMap.put((float) m.getCurrentHeapSize(), m.getMember());
-
-		for(Map.Entry<Float,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberHeapUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ1RZ2M1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ1RZ2M2;
-			}else{
-				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ3M3;
-			}
-			assertTrue(findElementById("RZ1 RZ2(!)"+entry.getValue()).getAttribute("style").contains(refMemberHeapUsage));
-	    }
-	}
-
-	public void assertMemeberSortingByRzCpuUsage(){
-		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
-		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
-		for (String member : memberNames) {
-			Member thisMember = new Member(member);
-			String sgName = thisMember.getRedundancyZone();
-				HashMap<String, Member> rzMembers = rzMap.get(sgName);
-
-				if (rzMembers == null) {
-					rzMembers = new HashMap<String, Member>();
-					rzMap.put(sgName, rzMembers);
-				}
-
-				rzMembers.put(thisMember.getMember(), thisMember);
-		}
-		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
-		String rzName = "RZ1 RZ2";
-		String memName = "M1" ;
-		Member m = rzMap.get(rzName).get(memName);
-		memberMap.put(m.getCpuUsage(), m.getMember());
-
-		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
-			//here matching painting style to validation that the members are painted according to their cpu usage
-			String refMemberCPUUsage = null;
-			if(entry.getValue().equalsIgnoreCase("M1")){
-				refMemberCPUUsage = PulseTestData.RedundancyZone.cpuUsagePaintStyleRZ1RZ2M1;
-			}else if(entry.getValue().equalsIgnoreCase("M2")){
-				refMemberCPUUsage = PulseTestData.RedundancyZone.cpuUsagePaintStyleRZ1RZ2M2;
-			}
-			assertTrue(findElementById("RZ1 RZ2(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
-	    }
-	}
-
-	public List<WebElement> getRegionsFromDataBrowser(){
-		List<WebElement> regionList = driver.findElements(By.xpath("//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]"));
-		return regionList;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseNoAuthTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseNoAuthTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseNoAuthTest.java
deleted file mode 100644
index e9765c5..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseNoAuthTest.java
+++ /dev/null
@@ -1,33 +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 com.vmware.geode.tools.pulse.tests;
-
-import org.apache.geode.test.junit.categories.UITest;
-import org.junit.BeforeClass;
-import org.junit.FixMethodOrder;
-import org.junit.experimental.categories.Category;
-import org.junit.runners.MethodSorters;
-
-@Category(UITest.class)
-@FixMethodOrder(MethodSorters.JVM)
-public class PulseNoAuthTest extends PulseAbstractTest {
-
-  @BeforeClass
-  public static void beforeClassSetup() throws Exception {
-    setUpServer("admin", "admin", null);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestData.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestData.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestData.java
deleted file mode 100644
index ca716fa..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestData.java
+++ /dev/null
@@ -1,106 +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 com.vmware.geode.tools.pulse.tests;
-
-public class PulseTestData {
-	
-	public static class TopNavigation{
-
-	}
-	
-	public static class ClusterStatus {
-
-		public static final String membersProperty = "members";
-	}
-	public static class Topology{
-		public static final String hotSpotHeapLbl = "Heap Usage";
-		public static final String hotSpotCPULbl = "CPU Usage";		
-		
-		public static final String cpuUsagePaintStyleM1 = "left: 497px; top: 0px;";
-		public static final String cpuUsagePaintStyleM2 = "left: 0px; top: 0px;";
-		public static final String cpuUsagePaintStyleM3 = "left: 265px; top: 0px;";		
-		
-		public static final String heapUsagePaintStyleM1 = "left: 0px; top: 0px;";
-		public static final String heapUsagePaintStyleM2 = "left: 559px; top: 0px;";
-		public static final String heapUsagePaintStyleM3 = "left: 280px; top: 0px;";
-	}
-	
-	public static class ServerGroups{
-		public static final String hotSpotHeapLbl = "Heap Usage";
-		public static final String hotSpotCPULbl = "CPU Usage";
-		
-		//Cpu Usage sorting
-//		public static final String cpuUsagePaintStyleM1 = "left: 497px; top: 0px;";
-//		public static final String cpuUsagePaintStyleM2 = "left: 0px; top: 0px;";
-//		public static final String cpuUsagePaintStyleM3 = "left: 265px; top: 0px;";		
-		
-		public static final String cpuUsagePaintStyleSG1M1 = "left: 0px; top: 295px;";
-		public static final String cpuUsagePaintStyleSG1M2 = "left: 0px; top: 30px;";
-		public static final String cpuUsagePaintStyleSG1M3 = "left: 0px; top: 171px;";
-		
-		public static final String cpuUsagePaintStyleSG2M1 = "left: 240px; top: 239px;";
-		public static final String cpuUsagePaintStyleSG2M2 = "left: 240px; top: 30px;";	
-		
-		public static final String cpuUsagePaintStyleSG3M3 = "left: 479px; top: 30px;"; 
-		
-		//heap usage sorting
-		public static final String heapUsagePaintStyleSG1M1 = "left: 0px; top: 30px;";
-		public static final String heapUsagePaintStyleSG1M2 = "left: 152px; top: 179px;";
-		public static final String heapUsagePaintStyleSG1M3 = "left: 0px; top: 179px;";
-		
-		public static final String heapUsagePaintStyleSG2M1 = "left: 240px; top: 30px;";
-		public static final String heapUsagePaintStyleSG2M2 = "left: 240px; top: 274px;";	
-		
-		public static final String heapUsagePaintStyleSG3M3 = "left: 479px; top: 30px;"; 
-	}
-	
-	public static class RedundancyZone{
-		
-		public static final String hotSpotHeapLbl = "Heap Usage";
-		public static final String hotSpotCPULbl = "CPU Usage";
-		
-		public static final String heapUsagePaintStyleRZ1RZ2M1 = "left: 0px; top: 30px;";
-		public static final String heapUsagePaintStyleRZ1RZ2M2 = "left: 0px; top: 274px;";
-		
-		public static final String heapUsagePaintStyleRZ3M3 = "left: 360px; top: 30px;";	
-		
-		public static final String cpuUsagePaintStyleRZ1RZ2M1 ="left: 0px; top: 239px;";
-		public static final String cpuUsagePaintStyleRZ1RZ2M2 ="left: 0px; top: 30px;";
-
-		
-	}
-	
-	public static class DataPerspectiveView {
-		
-	}
-
-	public static class DataBrowser {
-		public static final String partialRgnName = "R";
-		public static final String chkRgnClassName = "bttn chk checkbox_true_full";
-		public static final String notChkRgnClassName = "bttn chk checkbox_false_full";
-		
-		public static final String regName = "R1";
-		public static final String query1Text = "select * from /R1";
-		
-		public static final String datePattern = "EEE, MMM dd yyyy, HH:mm:ss z";		
-
-	}
-
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestLocators.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestLocators.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestLocators.java
deleted file mode 100644
index d5ff5d4..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseTestLocators.java
+++ /dev/null
@@ -1,225 +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 com.vmware.geode.tools.pulse.tests;
-
-public class PulseTestLocators {
-	public static class HtmlAttributes{
-		public static final String classAttribute = "class";
-		public static final String typeAttribute = "type";
-		public static final String idAttribute = "id";
-		public static final String nameAttribute = "name";
-		public static final String placeholderAttribute = "placeholder";
-		public static final String valueAttribute = "value";	
-		public static final String styleAttribute ="style";
-	}
-	
-	public static class TopNavigation {
-		public static final String clusterViewLinkXpath = "//a[text()='Cluster View']";
-	}
-
-	public static class ClusterStatus {
-
-	}
-
-	public static class MemberDetailsView {
-    public static final String gridButtonXpath = "//a[@id='btngridIcon']";
-  }
-
-  public static class TopologyView {
-
-		public static final String radioButtonId = "radio-default";
-		public static final String radioButtonXpath = "//label[text()='Topology']";
-		public static final String gridButtonId = "default_grid_button";
-		public static final String nodeH1Id = "h1";
-		public static final String nodeH2Id = "h2";
-		public static final String nodeH3Id = "h3";
-		public static final String memberM1Id = "M1";
-		public static final String memberM2Id = "M2";
-		public static final String memberM3Id = "M3";
-		public static final String treeMapButtonId = "default_treemap_button";
-		
-		// Host tootips
-		public static final String hostNameTTXpath = ".//*[@id='_tooltip']/div/div/div[1]";
-		public static final String cpuUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[1]/div[2]/div";
-		public static final String memoryUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div";
-		public static final String loadAvgTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div";
-		public static final String soketsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[4]/div[2]/div";
-		
-		// Member tooltips
-		public static final String memNameTTXpath = ".//*[@id='_tooltip']/div/div/div[1]";
-		public static final String memCpuUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[1]/div[2]/div";
-		public static final String threadsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div/text()";
-		public static final String jvmPausesTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div";
-		public static final String regionsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[4]/div[2]/div";
-		public static final String clientsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[5]/div[2]/div";
-		public static final String gatewaySenderTtXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[6]/div[2]/div";
-		public static final String portTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[7]/div[2]/div";
-
-		// Grid view
-		public static final String idM1Xpath = ".//*[@id='M1&M1']/td[1]";
-		public static final String nameM1Xpath = ".//*[@id='M1&M1']/td[2]";
-		public static final String hostH1Xpath = ".//*[@id='M1&M1']/td[3]";
-		public static final String idM2Xpath = ".//*[@id='M2&M2']/td[1]";
-		public static final String nameM2Xpath = ".//*[@id='M2&M2']/td[2]";
-		public static final String hostH2Xpath = ".//*[@id='M2&M2']/td[3]";
-		public static final String idM3Xpath = ".//*[@id='M3&M3']/td[1]";
-		public static final String nameM3Xpath = ".//*[@id='M3&M3']/td[2]";
-		public static final String hostH3Xpath = ".//*[@id='M3&M3']/td[3]";
-
-		// HotSpot locators 
-		public static final String hotSpotId = "currentHotSpot";
-		public static final String hotspotListDivId = "hotspotList";
-		public static final String heapUsageXpath = "//a[text()='Heap Usage']";
-		public static final String cpuUsageXpath = "//a[text()='CPU Usage']";
-		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";
-
-    }
-
-	public static class ServerGroups {
-
-		public static final String radioButtonId = "radio-servergroups";
-		public static final String radioButtonXpath = "//label[text()='Server Groups']";
-		public static final String gridButtonId = "servergroups_grid_button";
-		public static final String gridBlockId = "servergroups_grid_block";
-
-		public static final String serverGrpsRadioId = "member_view_option_servergroups";
-		
-		public static final String serverGrpsRadioXpath = "//label[@for='radio-servergroups']";
-
-		public static final String serverGrp1Id = "SG1";
-		public static final String serverGrp2Id = "SG2";
-		public static final String serverGrp3Id = "SG3";
-
-		public static final String serverGrp1Xpath = ".//*[@id='SG1']/div";
-		public static final String serverGrp2Xpath = ".//*[@id='SG2']/div";
-		public static final String serverGrp3Xpath = ".//*[@id='SG3']/div";
-
-		public static final String sg1M1Id = "SG1(!)M1";
-		public static final String sg1M2Id = "SG1(!)M2";
-		public static final String sg1M3Id = "SG1(!)M3";
-		public static final String sg2M1Id = "SG2(!)M1";
-		public static final String sg2M2Id = "SG2(!)M2";
-		public static final String sg3M3Id = "SG3(!)M3";
-
-		// Grid view
-		public static final String idSG1M3Xpath = ".//*[@id='M3&M3']/td[2]";
-		public static final String idSG1M2Xpath = ".//*[@id='M2&M2']/td[2]";
-		public static final String idSG1M1Xpath = ".//*[@id='M1&M1']/td[2]";
-		public static final String nameM3Xpath = ".//*[@id='M3&M3']/td[3]";
-		public static final String nameM2Xpath = ".//*[@id='M2&M2']/td[3]";
-		public static final String nameM1Xpath = ".//*[@id='M1&M1']/td[3]";
-		
-		//HotSpot locators
-		public static final String hotSpotId = "currentHotSpot";
-		public static final String hotspotListDivId= "hotspotList";
-		public static final String heapUsageXpath= "//a[text()='Heap Usage']";
-		public static final String cpuUsageXpath= "//a[text()='CPU Usage']";
-		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";		
-		
-	}
-
-	public static class RedundancyZone {
-
-		public static final String radioButtonId = "radio-redundancyzones";
-		public static final String radioButtonXpathAlt = "//label[text()='Redundancy Zones']";		
-		public static final String radioButtonXpath = "//label[@for='radio-redundancyzones']";
-		
-		public static final String gridButtonId = "redundancyzones_grid_button";
-
-		public static final String zoneRZ1Id = "RZ1 RZ2";
-		public static final String zoneRZ2Id = "RZ2";
-		
-
-		public static final String zoneRZ1RZ2Xpath = ".//*[@id='RZ1 RZ2']/div";
-		public static final String zoneRZ2Xpath = ".//*[@id='RZ2']/div";
-
-		public static final String m1RZ1RZ2Id = "RZ1 RZ2(!)M1";
-		public static final String m2RZ1Id = "RZ1 RZ2(!)M2";
-		public static final String m3RZ2Id = "RZ2(!)M3";
-//		public static final String m3RZ2Id = "RZ2(!)M3";
-//		public static final String m2RZ2Id = "RZ2(!)M2";
-		// Grid
-		public static final String idM2Xpath = ".//*[@id='M2&M2']/td[2]";
-		public static final String idM1Xpath = ".//*[@id='M1&M1']/td[2]";
-		public static final String idM3Xpath = ".//*[@id='M3&M3']/td[2]";
-		
-		//HotSpot locators
-		public static final String hotSpotId = "currentHotSpot";
-		public static final String hotspotListDivId= "hotspotList";
-		public static final String heapUsageXpath= "//a[text()='Heap Usage']";
-		public static final String cpuUsageXpath= "//a[text()='CPU Usage']";
-		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";
-	}
-
-	public static class DataPerspectiveView {
-		public static final String downarrowButtonXpath = "//a[text()='Members']";
-		public static final String dataViewButtonXpath = "//a[text()='Data']";
-		public static final String gridButtonId = "data_grid_button";
-	}
-
-	public static class RegionDetailsView {
-
-		public static final String regionNameDivId = "regionNameText";
-		public static final String regionPathId = "regionPath";
-		public static final String treeMapCanvasXpath = "//canvas[@id='GraphTreeMapClusterData-canvas']";
-		public static final String regionTypeId = "regionType";
-		public static final String regionMembersTextId = "regionMembersText";
-		public static final String regionEmptyNodesId = "regionEmptyNodes";
-		public static final String regionEntryCountTextId = "regionEntryCountText";
-		public static final String regionDiskUsageId = "regionDiskUsage";
-		public static final String regionPersistenceId = "regionPersistence";
-
-		public static final String gridButtonXpath = "//a[@id='btngridIcon']";
-		public static final String memoryUsedId = "memoryUsed";
-		public static final String totalMemoryId = "totalMemory";
-
-		public static final String inMemoryReadsId = "currentReadsPerSec";
-		public static final String inMemoryWritesId = "currentWritesPerSec";
-		public static final String diskReadsId = "currentDiskReadsPerSec";
-		public static final String diskWritesId = "currentDiskWritesPerSec";
-
-		public static final String memberNameId = "memberName";
-
-	}
-
-	public static class DataBrowser {
-		public static final String rgnFilterTxtBoxId = "filterTextRegion";
-		public static final String rgnNameSpanXpath = "//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]";
-		public static final String rgnNameTxtBoxXpath = "//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]";
-		public static final String rgnSpanFirstPart = "//span[@id='treeDemo_";
-		public static final String rgnSpanSecondPart = "_span']";
-		public static final String rgn1ChkBoxId = "treeDemo_1_check";
-		public static final String queryEditorTxtBoxId = "dataBrowserQueryText";
-		public static final String btnExecuteQueryId = "btnExecuteQuery";
-		
-		public static final String divDataRegions = "//div/ul[@id='treeDemo']/li";
-		
-		// History section		
-		public static final String historyIcon = "historyIcon";
-		public static final String historyLst = "//div[@id='detailsHistoryList']/div/div";
-		public static final String queryText = ".wrapHistoryContent";
-		public static final String historyDateTime = ".dateTimeHistory";
-		
-		//Clear button 
-		
-		public static final String btnClearXpath = "//input[@value='Clear']";
-
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Region.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Region.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Region.java
deleted file mode 100644
index fd835c7..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Region.java
+++ /dev/null
@@ -1,187 +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 com.vmware.geode.tools.pulse.tests;
-
-import java.util.HashMap;
-import java.util.Map;
-
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.CompositeDataSupport;
-import javax.management.openmbean.CompositeType;
-import javax.management.openmbean.OpenDataException;
-import javax.management.openmbean.OpenType;
-import javax.management.openmbean.SimpleType;
-
-public class Region extends JMXBaseBean implements RegionMBean {
-  private String name = null;
-
-  private static String[] regAttItemNames = { "compressionCodec",
-    "enableOffHeapMemory", "scope", "diskStoreName",
-    "diskSynchronous" };
-  private static String[] regAttItemDescriptions = { "compressionCodec",
-    "enableOffHeapMemory", "scope", "diskStoreName",
-    "diskSynchronous" };
-  private static OpenType[] regAttItemTypes = { SimpleType.STRING,
-    SimpleType.BOOLEAN, SimpleType.STRING,
-    SimpleType.STRING, SimpleType.BOOLEAN };
-  private static CompositeType listRegionAttributesCompData = null;
-
-  static {
-    try {
-      listRegionAttributesCompData = new CompositeType("listRegionAttributes",
-          "Regions attributes", regAttItemNames, regAttItemDescriptions,
-          regAttItemTypes);
-
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-    }
-  }
-
-  public Region(String name) {
-    this.name = name;
-  }
-
-  protected String getKey(String propName) {
-    return "region." + name + "." + propName;
-  }
-
-  @Override
-  public String[] getMembers() {
-    return getStringArray("members");
-  }
-
-  @Override
-  public String getFullPath() {
-    return getString("fullPath");
-  }
-
-  @Override
-  public double getDiskReadsRate() {
-    return getDouble("diskReadsRate");
-  }
-
-  @Override
-  public double getDiskWritesRate() {
-    return getDouble("diskWritesRate");
-  }
-
-  @Override
-  public int getEmptyNodes() {
-    return getInt("emptyNodes");
-  }
-
-  @Override
-  public double getGetsRate() {
-    return getDouble("getsRate");
-  }
-
-  @Override
-  public double getLruEvictionRate() {
-    return getDouble("lruEvictionRate");
-  }
-
-  @Override
-  public double getPutsRate() {
-    return getDouble("putsRate");
-  }
-
-  @Override
-  public String getRegionType() {
-    return getString("regionType");
-  }
-
-  @Override
-  public long getEntrySize() {
-    return getLong("entrySize");
-  }
-
-  @Override
-  public long getSystemRegionEntryCount() {
-    return getLong("systemRegionEntryCount");
-  }
-
-  @Override
-  public int getMemberCount() {
-    return getInt("memberCount");
-  }
-
-  @Override
-  public boolean getPersistentEnabled() {
-    return getBoolean("persistentEnabled");
-  }
-
-  @Override
-  public String getName() {
-    return getString("name");
-  }
-
-  @Override
-  public boolean getGatewayEnabled() {
-    return getBoolean("gatewayEnabled");
-  }
-
-  @Override
-  public long getDiskUsage() {
-    return getLong("diskUsage");
-  }
-
-  @Override
-  public CompositeData listRegionAttributes() {
-    String value = JMXProperties.getInstance().getProperty(
-        getKey("listRegionAttributes"), "");
-    String[] itemValues = value.split(",");
-    Map<String, Object> itemValuesHM = new HashMap<String, Object>();
-    
-    // compressionCodec
-    if (null != itemValues[0]) {
-      itemValuesHM.put(regAttItemNames[0], itemValues[0]);
-    }
-
-    // enableOffHeapMemory
-    if (null != itemValues[1]) {
-      itemValuesHM.put(regAttItemNames[1], Boolean.parseBoolean(itemValues[1]));
-    }
-
-    // scope
-    if (null != itemValues[3]) {
-      itemValuesHM.put(regAttItemNames[3], itemValues[3]);
-    }
-
-    // diskStoreName
-    if (null != itemValues[4]) {
-      itemValuesHM.put(regAttItemNames[4], itemValues[4]);
-    }
-
-    // diskSynchronous
-    if (null != itemValues[5]) {
-      itemValuesHM.put(regAttItemNames[5], Boolean.parseBoolean(itemValues[5]));
-    }
-
-    CompositeData lraCompData;
-    try {
-      lraCompData = new CompositeDataSupport(listRegionAttributesCompData,
-          itemValuesHM);
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-      lraCompData = null;
-    }
-    return lraCompData;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionMBean.java
deleted file mode 100644
index 0ee8201..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionMBean.java
+++ /dev/null
@@ -1,59 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.openmbean.CompositeData;
-
-public interface RegionMBean {
-  String OBJECT_NAME = "GemFire:service=Region,type=Distributed";
-
-  String[] getMembers();
-
-  String getFullPath();
-
-  double getDiskReadsRate();
-
-  double getDiskWritesRate();
-
-  int getEmptyNodes();
-
-  double getGetsRate();
-
-  double getLruEvictionRate();
-
-  double getPutsRate();
-
-  String getRegionType();
-
-  long getEntrySize();
-
-  long getSystemRegionEntryCount();
-
-  int getMemberCount();
-
-  boolean getPersistentEnabled();
-
-  String getName();
-
-  boolean getGatewayEnabled();
-
-  long getDiskUsage();
-
-  CompositeData listRegionAttributes();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMember.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMember.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMember.java
deleted file mode 100644
index 86ba550..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMember.java
+++ /dev/null
@@ -1,95 +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 com.vmware.geode.tools.pulse.tests;
-
-/**
- * Region on member mbean
- *
- *
- *
- */
-public class RegionOnMember extends JMXBaseBean implements RegionOnMemberMBean {
-  private String fullPath = null;
-  private String member = null;
-
-  public RegionOnMember(String fullPath, String member) {
-    this.fullPath = fullPath;
-    this.member = member;
-  }
-
-  @Override
-  protected String getKey(String propName) {
-    return "regionOnMember." + fullPath + "." + member + "." + propName;
-  }
-
-  @Override
-  public String getFullPath(){
-    return this.fullPath;
-  }
-
-  @Override
-  public String getMember(){
-    return this.member;
-  }
-
-  @Override
-  public String getName(){
-    return getString("name");
-  }
-
-  @Override
-  public String getRegionType(){
-    return getString("regionType");
-  }
-
-  @Override
-  public long getEntrySize(){
-    return getLong("entrySize");
-  }
-
-  @Override
-  public long getEntryCount(){
-    return getLong("entryCount");
-  }
-
-  @Override
-  public double getGetsRate(){
-    return getDouble("getsRate");
-  }
-
-  @Override
-  public double getPutsRate(){
-    return getDouble("putsRate");
-  }
-
-  @Override
-  public double getDiskReadsRate(){
-    return getDouble("diskGetsRate");
-  }
-
-  @Override
-  public double getDiskWritesRate(){
-    return getDouble("diskPutsRate");
-  }
-
-  @Override
-  public int getLocalMaxMemory(){
-    return getInt("localMaxMemory");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMemberMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMemberMBean.java
deleted file mode 100644
index 5fac9da..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/RegionOnMemberMBean.java
+++ /dev/null
@@ -1,49 +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 com.vmware.geode.tools.pulse.tests;
-
-/**
- * Region on members mbean
- *
- *
- */
-public interface RegionOnMemberMBean {
-
-  String getName();
-
-  String getRegionType(); // Ideally should be an Enum
-
-  String getFullPath();
-
-  String getMember();
-
-  long getEntrySize();
-
-  long getEntryCount();
-
-  double getGetsRate();
-
-  double getPutsRate();
-
-  double getDiskReadsRate();
-
-  double getDiskWritesRate();
-
-  int getLocalMaxMemory();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Server.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Server.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Server.java
deleted file mode 100644
index 20f5312..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Server.java
+++ /dev/null
@@ -1,247 +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 com.vmware.geode.tools.pulse.tests;
-
-import java.io.IOException;
-import java.lang.management.ManagementFactory;
-import java.net.Inet4Address;
-import java.net.Inet6Address;
-import java.net.InetAddress;
-import java.net.UnknownHostException;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Properties;
-
-import javax.management.InstanceAlreadyExistsException;
-import javax.management.MBeanRegistrationException;
-import javax.management.MBeanServer;
-import javax.management.MalformedObjectNameException;
-import javax.management.NotCompliantMBeanException;
-import javax.management.ObjectName;
-import javax.management.remote.JMXConnectorServer;
-import javax.management.remote.JMXConnectorServerFactory;
-import javax.management.remote.JMXServiceURL;
-
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import org.apache.geode.security.templates.SampleSecurityManager;
-import org.apache.shiro.SecurityUtils;
-import org.apache.shiro.mgt.DefaultSecurityManager;
-import org.apache.shiro.mgt.SecurityManager;
-import org.apache.shiro.realm.Realm;
-
-import org.apache.geode.internal.security.shiro.CustomAuthRealm;
-import org.apache.geode.internal.security.shiro.JMXShiroAuthenticator;
-import org.apache.geode.management.internal.security.AccessControlMBean;
-import org.apache.geode.management.internal.security.MBeanServerWrapper;
-import org.apache.geode.management.internal.security.ResourceConstants;
-
-public class Server {
-
-  private static final String DEFAULT_HOST = "127.0.0.1"; //"localhost"
-  private static final int DEFAULT_PORT = 9999;
-  private final JMXServiceURL url;
-  private MBeanServer mbs;
-  private JMXConnectorServer cs;
-  private String propFile = null;
-
-  public Server(int port, String properties, String jsonAuthFile) throws Exception {
-    this.propFile = properties;
-    mbs = ManagementFactory.getPlatformMBeanServer();
-    url = new JMXServiceURL(formJMXServiceURLString(DEFAULT_HOST, port));
-
-    // Load the beans first, otherwise we get access denied
-    loadMBeans();
-
-    if (jsonAuthFile != null) {
-      System.setProperty("spring.profiles.active", "pulse.authentication.gemfire");
-
-      Map<String, Object> env = new HashMap<String, Object>();
-
-      // set up Shiro Security Manager
-      Properties securityProperties = new Properties();
-      securityProperties.setProperty(SampleSecurityManager.SECURITY_JSON, jsonAuthFile);
-      Realm realm = new CustomAuthRealm(SampleSecurityManager.class.getName(), securityProperties);
-      SecurityManager securityManager = new DefaultSecurityManager(realm);
-      SecurityUtils.setSecurityManager(securityManager);
-
-      // register the AccessControll bean
-      AccessControlMBean acc = new AccessControlMBean();
-      ObjectName accessControlMBeanON = new ObjectName(ResourceConstants.OBJECT_NAME_ACCESSCONTROL);
-      MBeanServer platformMBeanServer = ManagementFactory.getPlatformMBeanServer();
-      platformMBeanServer.registerMBean(acc, accessControlMBeanON);
-
-      // wire in the authenticator and authorizaton
-      JMXShiroAuthenticator interceptor = new JMXShiroAuthenticator();
-      env.put(JMXConnectorServer.AUTHENTICATOR, interceptor);
-      cs = JMXConnectorServerFactory.newJMXConnectorServer(url, env, mbs);
-      cs.setMBeanServerForwarder(new MBeanServerWrapper());
-
-      //set up the AccessControlMXBean
-
-    } else {
-      System.setProperty("spring.profiles.active", "pulse.authentication.default");
-      cs = JMXConnectorServerFactory.newJMXConnectorServer(url, null, mbs);
-    }
-
-    try {
-      java.rmi.registry.LocateRegistry.createRegistry(port);
-      System.out.println("RMI registry ready.");
-    } catch (Exception e) {
-      System.out.println("Exception starting RMI registry:");
-      e.printStackTrace();
-    }
-
-    cs.start();
-  }
-
-  private String formJMXServiceURLString(String host, int port) throws UnknownHostException {
-    String jmxSerURL = "";
-
-    InetAddress inetAddr = InetAddress.getByName(host);
-    if (inetAddr instanceof Inet4Address) {
-      // Create jmx service url for IPv4 address
-      jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":" + port + "/jmxrmi";
-    } else if (inetAddr instanceof Inet6Address) {
-      // Create jmx service url for IPv6 address
-      jmxSerURL = "service:jmx:rmi://[" + host + "]/jndi/rmi://[" + host + "]:" + port + "/jmxrmi";
-    }
-
-    return jmxSerURL;
-  }
-
-  public void stop() {
-    try {
-      cs.stop();
-    } catch (IOException e) {
-      e.printStackTrace();
-    }
-  }
-
-  private synchronized void loadMBeans() {
-    JMXProperties props = JMXProperties.getInstance();
-    try {
-      props.load(propFile);
-    } catch (IOException e) {
-      e.printStackTrace();
-    }
-
-    // Add servers
-    String[] servers = getArrayProperty(props, "servers");
-    for (String server : servers) {
-      try {
-        addServerMBean(server);
-      } catch (InstanceAlreadyExistsException e) {
-        e.printStackTrace();
-      } catch (MBeanRegistrationException e) {
-        e.printStackTrace();
-      } catch (NotCompliantMBeanException e) {
-        e.printStackTrace();
-      } catch (MalformedObjectNameException e) {
-        e.printStackTrace();
-      } catch (NullPointerException e) {
-        e.printStackTrace();
-      }
-    }
-
-    // Add members
-    String[] members = getArrayProperty(props, "members");
-    for (String m : members) {
-      try {
-        addMemberMBean(m);
-      } catch (InstanceAlreadyExistsException e) {
-        e.printStackTrace();
-      } catch (MBeanRegistrationException e) {
-        e.printStackTrace();
-      } catch (NotCompliantMBeanException e) {
-        e.printStackTrace();
-      } catch (MalformedObjectNameException e) {
-        e.printStackTrace();
-      } catch (NullPointerException e) {
-        e.printStackTrace();
-      }
-    }
-
-    // Add regions
-    String[] regions = getArrayProperty(props, "regions");
-    for (String reg : regions) {
-      try {
-        addRegionMBean(reg);
-      } catch (InstanceAlreadyExistsException e) {
-        e.printStackTrace();
-      } catch (MBeanRegistrationException e) {
-        e.printStackTrace();
-      } catch (NotCompliantMBeanException e) {
-        e.printStackTrace();
-      } catch (MalformedObjectNameException e) {
-        e.printStackTrace();
-      } catch (NullPointerException e) {
-        e.printStackTrace();
-      }
-    }
-  }
-
-  private void addMemberMBean(
-      String m) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
-    Member m1 = new Member(m);
-    mbs.registerMBean(m1, new ObjectName(Member.OBJECT_NAME + ",member=" + m));
-  }
-
-  // For GemFire XD
-  private void addGemFireXDMemberMBean(
-      String xdm) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
-    GemFireXDMember xdmo = new GemFireXDMember(xdm);
-    mbs.registerMBean(xdmo, new ObjectName(GemFireXDMember.OBJECT_NAME + ",member=" + xdm));
-  }
-
-  private void addRegionMBean(
-      String reg) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
-    Region regionObject = new Region(reg);
-    mbs.registerMBean(regionObject, new ObjectName(Region.OBJECT_NAME + ",name=/" + reg));
-
-    for (String member : regionObject.getMembers()) {
-      RegionOnMember regionOnMemberObject = new RegionOnMember(regionObject.getFullPath(), member);
-      mbs.registerMBean(regionOnMemberObject, new ObjectName(
-          PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObject.getFullPath() + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + member));
-    }
-  }
-
-  private void addServerMBean(
-      String server) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
-    ServerObject so = new ServerObject(server);
-    mbs.registerMBean(so, new ObjectName(ServerObject.OBJECT_NAME));
-  }
-
-  private String[] getArrayProperty(JMXProperties props, String propName) {
-    String propVal = props.getProperty(propName, "");
-    return propVal.split(" ");
-  }
-
-  public static Server createServer(int port, String properties, String jsonAuthFile)
-      throws MalformedObjectNameException {
-    Server s = null;
-    try {
-      s = new Server(port, properties, jsonAuthFile);
-    } catch (Exception e) {
-      e.printStackTrace();
-      return null;
-    }
-
-    return s;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObject.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObject.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObject.java
deleted file mode 100644
index adc1361..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObject.java
+++ /dev/null
@@ -1,267 +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 com.vmware.geode.tools.pulse.tests;
-
-import java.io.IOException;
-
-import javax.management.NotificationBroadcasterSupport;
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.CompositeDataSupport;
-import javax.management.openmbean.CompositeType;
-import javax.management.openmbean.OpenDataException;
-import javax.management.openmbean.OpenType;
-import javax.management.openmbean.SimpleType;
-import javax.management.openmbean.TabularData;
-import javax.management.openmbean.TabularDataSupport;
-import javax.management.openmbean.TabularType;
-
-public class ServerObject extends NotificationBroadcasterSupport implements
-    ServerObjectMBean {
-  private String name = null;
-
-  private TabularDataSupport wanInfo;
-  private static String[] itemNames = { "key", "value" };
-  private static String[] itemDescriptions = { "Key", "Value" };
-  private static OpenType[] itemTypes = { SimpleType.STRING, SimpleType.BOOLEAN };
-  private static CompositeType wanInfoType = null;
-
-  private static String[] indexNames = { "key" };
-  private static TabularType wanType = null;
-
-  static {
-    try {
-      wanInfoType = new CompositeType("wanInfo", "WAN Information", itemNames,
-          itemDescriptions, itemTypes);
-
-      wanType = new TabularType("wanInfo", "WAN Information", wanInfoType,
-          indexNames);
-
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-    }
-  }
-
-  public ServerObject(String name) {
-    this.name = name;
-    this.wanInfo = new TabularDataSupport(wanType);
-  }
-
-  private String getKey(String propName) {
-    return "server." + name + "." + propName;
-  }
-
-  @Override
-  public String[] listCacheServers() {
-    return JMXProperties.getInstance()
-        .getProperty(getKey("listCacheServers"), "").split(" ");
-  }
-
-  @Override
-  public String[] listServers() {
-    return JMXProperties.getInstance()
-            .getProperty(getKey("listServers"), "").split(" ");
-  }
-
-  @Override
-  public TabularData viewRemoteClusterStatus() {
-    wanInfo.clear();
-    String[] wan = JMXProperties.getInstance()
-        .getProperty(getKey("wanInfo"), "").split(" ");
-    int cnt = 0;
-    while (wan.length >= (cnt + 2)) {
-      try {
-        wanInfo.put(buildWanInfoType(new String(wan[cnt]),
-            Boolean.parseBoolean(wan[cnt + 1])));
-      } catch (OpenDataException e) {
-        e.printStackTrace();
-      }
-      cnt += 2;
-    }
-
-    return (TabularData) wanInfo.clone();
-  }
-
-  @Override
-  public int getMemberCount() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("memberCount")));
-  }
-
-  @Override
-  public int getNumClients() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("numClients")));
-  }
-
-  @Override
-  public int getDistributedSystemId() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("distributedSystemId")));
-  }
-
-  @Override
-  public int getLocatorCount() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("locatorCount")));
-  }
-
-  @Override
-  public int getTotalRegionCount() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("totalRegionCount")));
-  }
-
-  @Override
-  public int getNumRunningFunctions() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("numRunningFunctions")));
-  }
-
-  @Override
-  public long getRegisteredCQCount() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("registeredCQCount")));
-  }
-
-  @Override
-  public int getNumSubscriptions() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("numSubscriptions")));
-  }
-
-  // For SQLFire/GemFireXD
-  @Override
-  public int getTransactionCommitted() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("TransactionCommitted")));
-  }
-
-  // For SQLFire/GemFireXD
-  @Override
-  public int getTransactionRolledBack() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("TransactionRolledBack")));
-  }
-
-  @Override
-  public long getTotalHeapSize() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("totalHeapSize")));
-  }
-
-  @Override
-  public long getUsedHeapSize() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("usedHeapSize")));
-  }
-
-  @Override
-  public long getMaxMemory() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("MaxMemory")));
-  }
-
-  @Override
-  public long getUsedMemory() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("UsedMemory")));
-  }
-
-  @Override
-  public long getTotalRegionEntryCount() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("totalRegionEntryCount")));
-  }
-
-  @Override
-  public int getCurrentQueryCount() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("currentQueryCount")));
-  }
-
-  @Override
-  public long getTotalDiskUsage() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("totalDiskUsage")));
-  }
-
-  @Override
-  public double getDiskWritesRate() {
-    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-        getKey("diskWritesRate")));
-  }
-
-  @Override
-  public double getAverageWrites() {
-    String val = JMXProperties.getInstance().getProperty(getKey("averageWrites"), "");
-    double ret = Double.parseDouble(val);
-    return ret;
-//    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-//        getKey("averageWrites"), ""));
-  }
-
-  @Override
-  public double getAverageReads() {
-    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-        getKey("averageReads"), ""));
-  }
-
-  @Override
-  public double getQueryRequestRate() {
-    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-        getKey("queryRequestRate"), ""));
-  }
-
-  @Override
-  public double getDiskReadsRate() {
-    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-        getKey("diskReadsRate"), ""));
-  }
-
-  @Override
-  public long getJVMPauses() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("jvmPauses"), ""));
-  }
-
-  private CompositeData buildWanInfoType(String key, Boolean state)
-      throws OpenDataException {
-    Object[] itemValues = { key, state };
-    CompositeData result = new CompositeDataSupport(wanInfoType, itemNames,
-        itemValues);
-
-    return result;
-  }
-
-  @Override
-  public String queryData(String p0, String p1, int p2) {
-    // p0 : query
-    // p1 : comma separated members
-    // p2 : limit
-    
-    DataBrowserResultLoader dbrLoader = DataBrowserResultLoader.getInstance();
-    
-    try {
-      return dbrLoader.load(p0);
-    } catch (IOException e) {
-      e.printStackTrace();
-      return e.getMessage();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObjectMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObjectMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObjectMBean.java
deleted file mode 100644
index 8f1bc54..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/ServerObjectMBean.java
+++ /dev/null
@@ -1,79 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.openmbean.TabularData;
-
-public interface ServerObjectMBean {
-  String OBJECT_NAME = "GemFire:service=System,type=Distributed";
-
-  TabularData viewRemoteClusterStatus();
-
-  int getMemberCount();
-
-  int getNumClients();
-
-  int getDistributedSystemId();
-
-  int getLocatorCount();
-
-  int getTotalRegionCount();
-
-  int getNumRunningFunctions();
-
-  long getRegisteredCQCount();
-
-  int getNumSubscriptions();
-
-  int getTransactionCommitted();
-
-  int getTransactionRolledBack();
-
-  long getTotalHeapSize();
-
-  long getUsedHeapSize();
-
-  long getMaxMemory();
-
-  long getUsedMemory();
-
-  long getTotalRegionEntryCount();
-
-  int getCurrentQueryCount();
-
-  long getTotalDiskUsage();
-
-  double getDiskWritesRate();
-
-  double getAverageWrites();
-
-  double getAverageReads();
-
-  double getQueryRequestRate();
-
-  double getDiskReadsRate();
-
-  long getJVMPauses();
-
-  String[] listCacheServers();
-
-  String[] listServers();
-
-  String queryData(String p0, String p1, int p2);
-}


[39/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
index c917d4d..51ea8e4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteRegionFunctionSingleHopOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.HashSet;
@@ -24,31 +24,31 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionException;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTargetException;
-import com.gemstone.gemfire.internal.cache.execute.MemberMappedArgument;
-import com.gemstone.gemfire.internal.cache.execute.ServerRegionFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.execute.InternalFunctionException;
+import org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException;
+import org.apache.geode.internal.cache.execute.MemberMappedArgument;
+import org.apache.geode.internal.cache.execute.ServerRegionFunctionExecutor;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * @since GemFire 6.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExplicitConnectionSourceImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExplicitConnectionSourceImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExplicitConnectionSourceImpl.java
index 7b7c3d7..73c12c6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExplicitConnectionSourceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExplicitConnectionSourceImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.security.GemFireSecurityException;
 import org.apache.logging.log4j.Logger;
 
 import java.net.InetSocketAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetAllOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetAllOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetAllOp.java
index 0aaa2ad..259fc76 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetAllOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetAllOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.HashSet;
@@ -24,18 +24,18 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region getAll on a server
@@ -149,7 +149,7 @@ public class GetAllOp {
     private final Object callback;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetAllOpImpl(String region,
                         List keys,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPRMetaDataOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPRMetaDataOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPRMetaDataOp.java
index 240aabb..1b72c7a 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPRMetaDataOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPRMetaDataOp.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.BucketServerLocation66;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.BucketServerLocation66;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Retrieves {@link ClientPartitionAdvisor} for the specified PartitionedRegion from

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPartitionAttributesOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPartitionAttributesOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPartitionAttributesOp.java
index 7f5ba9d..6da0531 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPartitionAttributesOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetClientPartitionAttributesOp.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
index 6630614..ef1f511 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.EntrySnapshot;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.EntrySnapshot;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * does getEntry on the server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEventValueOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEventValueOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEventValueOp.java
index 80bc7a7..7e4ca97 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEventValueOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEventValueOp.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
 
 /**
  * Gets (full) value (unlike GetOp, which may get either a full value or a delta
@@ -50,7 +50,7 @@ public class GetEventValueOp {
 
   static class GetEventValueOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetEventValueOpImpl(EventID event, Object callbackArg) {
       super(MessageType.REQUEST_EVENT_VALUE, callbackArg != null ? 2 : 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetFunctionAttributeOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetFunctionAttributeOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetFunctionAttributeOp.java
index 177ea26..e72976c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetFunctionAttributeOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetFunctionAttributeOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 public class GetFunctionAttributeOp {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
index 00f81fd..350df88 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetOp.java
@@ -14,27 +14,27 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheLoaderException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.client.AllConnectionsInUseException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.client.AllConnectionsInUseException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region get on a server
@@ -120,7 +120,7 @@ public class GetOp {
     }
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetOpImpl(LocalRegion region,
                      Object key,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumByIdOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumByIdOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumByIdOp.java
index 7240346..09ef6e4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumByIdOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumByIdOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.pdx.internal.EnumInfo;
 
 /**
  * Retrieve the PDXType, given an integer PDX id, from a server.
@@ -42,7 +42,7 @@ public class GetPDXEnumByIdOp {
   
   private static class GetPDXEnumByIdOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetPDXEnumByIdOpImpl(int enumId) {
       super(MessageType.GET_PDX_ENUM_BY_ID, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumsOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumsOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumsOp.java
index 748a94f..8c412ca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumsOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXEnumsOp.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Map;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.pdx.internal.EnumInfo;
 
 /**
  * Retrieve all known PDX types.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForEnumOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForEnumOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForEnumOp.java
index 2185eac..c247e64 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForEnumOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForEnumOp.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.pdx.internal.EnumInfo;
 
 /**
  * Retrieve the PDXType, given an integer PDX id, from a server.
@@ -47,7 +47,7 @@ public class GetPDXIdForEnumOp {
   
   private static class GetPDXIdForEnumOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetPDXIdForEnumOpImpl(EnumInfo ei) {
       super(MessageType.GET_PDX_ID_FOR_ENUM, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForTypeOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForTypeOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForTypeOp.java
index 92dad3d..f1a3f50 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForTypeOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXIdForTypeOp.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.pdx.internal.PdxType;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.pdx.internal.PdxType;
 
 /**
  * Retrieve the PDXType, given an integer PDX id, from a server.
@@ -47,7 +47,7 @@ public class GetPDXIdForTypeOp {
   
   private static class GetPDXIdForTypeOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetPDXIdForTypeOpImpl(PdxType type) {
       super(MessageType.GET_PDX_ID_FOR_TYPE, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypeByIdOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypeByIdOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypeByIdOp.java
index 982eb27..48c2f13 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypeByIdOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypeByIdOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.pdx.internal.PdxType;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.pdx.internal.PdxType;
 
 /**
  * Retrieve the PDXType, given an integer PDX id, from a server.
@@ -42,7 +42,7 @@ public class GetPDXTypeByIdOp {
   
   private static class GetPDXTypeByIdOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public GetPDXTypeByIdOpImpl(int pdxId) {
       super(MessageType.GET_PDX_TYPE_BY_ID, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypesOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypesOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypesOp.java
index 5fa0cc0..8444ef9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypesOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetPDXTypesOp.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Map;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.pdx.internal.PdxType;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.pdx.internal.PdxType;
 
 /**
  * Retrieve all known PDX types.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/InstantiatorRecoveryListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InstantiatorRecoveryListener.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InstantiatorRecoveryListener.java
index 8776863..a34acad 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InstantiatorRecoveryListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InstantiatorRecoveryListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.RejectedExecutionException;
 import java.util.concurrent.ScheduledExecutorService;
@@ -23,13 +23,13 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.internal.InternalInstantiator;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A listener which will try to resend the instantiators to all servers if the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/InternalPool.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InternalPool.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InternalPool.java
index fa27d99..80bacc7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InternalPool.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InternalPool.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Map;
 
 import java.util.concurrent.ScheduledExecutorService;
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.internal.cache.PoolStats;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.internal.cache.PoolStats;
 
 /**
  * The contract between a connection source and a connection pool.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/InvalidateOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InvalidateOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InvalidateOp.java
index 2819ad9..89ca446 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/InvalidateOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/InvalidateOp.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region invalidate on a server
@@ -55,7 +55,7 @@ public class InvalidateOp {
   private static class InvalidateOpImpl extends AbstractOp {
     private EntryEventImpl event;
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public InvalidateOpImpl(String region,
                          EntryEventImpl event) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/KeySetOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/KeySetOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/KeySetOp.java
index c30a90a..3bff61d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/KeySetOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/KeySetOp.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.cache.client.ServerOperationException;
 
 import java.util.List;
 import java.util.Set;
@@ -52,7 +52,7 @@ public class KeySetOp {
   
   private static class KeySetOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public KeySetOpImpl(String region) {
       super(MessageType.KEY_SET, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/LiveServerPinger.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LiveServerPinger.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LiveServerPinger.java
index 4dfd79e..43fcbd2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LiveServerPinger.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LiveServerPinger.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
@@ -24,10 +24,10 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.client.internal.EndpointManager.EndpointListenerAdapter;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.client.internal.EndpointManager.EndpointListenerAdapter;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Responsible for pinging live

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallback.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallback.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallback.java
index 12ec348..945c559 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallback.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallback.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallbackAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallbackAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallbackAdapter.java
index 6639e5e..55e5ac6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallbackAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/LocatorDiscoveryCallbackAdapter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/MakePrimaryOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/MakePrimaryOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/MakePrimaryOp.java
index 3320aab..6d42dca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/MakePrimaryOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/MakePrimaryOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Tell a server to become the primary host of a server-to-client queue
@@ -42,7 +42,7 @@ public class MakePrimaryOp {
   
   private static class MakePrimaryOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public MakePrimaryOpImpl(boolean sentClientReady) {
       super(MessageType.MAKE_PRIMARY, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/Op.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Op.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Op.java
index 5247317..7813a0e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/Op.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/Op.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 /**
  * An operation to perform on a server. Used by

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/OpExecutorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/OpExecutorImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/OpExecutorImpl.java
index bbec12f..8f20b2c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/OpExecutorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/OpExecutorImpl.java
@@ -14,35 +14,35 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.SynchronizationCommitConflictException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.client.*;
-import com.gemstone.gemfire.cache.client.internal.ExecuteFunctionOp.ExecuteFunctionOpImpl;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
-import com.gemstone.gemfire.cache.client.internal.QueueManager.QueueConnections;
-import com.gemstone.gemfire.cache.client.internal.pooling.ConnectionDestroyedException;
-import com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.TXStateProxy;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTargetException;
-import com.gemstone.gemfire.internal.cache.tier.BatchException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.MessageTooLargeException;
-import com.gemstone.gemfire.internal.cache.wan.BatchException70;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.security.AuthenticationRequiredException;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.*;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.SynchronizationCommitConflictException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.client.*;
+import org.apache.geode.cache.client.internal.ExecuteFunctionOp.ExecuteFunctionOpImpl;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
+import org.apache.geode.cache.client.internal.QueueManager.QueueConnections;
+import org.apache.geode.cache.client.internal.pooling.ConnectionDestroyedException;
+import org.apache.geode.cache.client.internal.pooling.ConnectionManager;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.PoolManagerImpl;
+import org.apache.geode.internal.cache.PutAllPartialResultException;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.cache.TXStateProxy;
+import org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException;
+import org.apache.geode.internal.cache.tier.BatchException;
+import org.apache.geode.internal.cache.tier.sockets.MessageTooLargeException;
+import org.apache.geode.internal.cache.wan.BatchException70;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.security.AuthenticationRequiredException;
+import org.apache.geode.security.GemFireSecurityException;
 import org.apache.logging.log4j.Logger;
 
 import java.io.EOFException;
@@ -312,7 +312,7 @@ public class OpExecutorImpl implements ExecutablePool {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.OpExecutor#executeOn(com.gemstone.gemfire.distributed.internal.ServerLocation, com.gemstone.gemfire.cache.client.internal.Op)
+   * @see org.apache.geode.cache.client.internal.OpExecutor#executeOn(org.apache.geode.distributed.internal.ServerLocation, org.apache.geode.cache.client.internal.Op)
    */
   public Object executeOn(ServerLocation server, Op op) {
     return executeOn(server, op, true,false);
@@ -447,7 +447,7 @@ public class OpExecutorImpl implements ExecutablePool {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ExecutablePool#executeOnPrimary(com.gemstone.gemfire.cache.client.internal.Op)
+   * @see org.apache.geode.cache.client.internal.ExecutablePool#executeOnPrimary(org.apache.geode.cache.client.internal.Op)
    */
   public Object executeOnPrimary(Op op) {
     if(queueManager == null) {
@@ -512,7 +512,7 @@ public class OpExecutorImpl implements ExecutablePool {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ExecutablePool#executeOnAllQueueServers(com.gemstone.gemfire.cache.client.internal.Op)
+   * @see org.apache.geode.cache.client.internal.ExecutablePool#executeOnAllQueueServers(org.apache.geode.cache.client.internal.Op)
    */
   public Object executeOnQueuesAndReturnPrimaryResult(Op op) {
     if(queueManager == null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PdxRegistryRecoveryListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PdxRegistryRecoveryListener.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PdxRegistryRecoveryListener.java
index 2d4104c..ef030c7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PdxRegistryRecoveryListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PdxRegistryRecoveryListener.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.pdx.internal.TypeRegistry;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.pdx.internal.TypeRegistry;
 
 /**
  * A listener which will wipe out the PDX registry on the client side if the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PingOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PingOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PingOp.java
index fbe0186..509eebe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PingOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PingOp.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Ping a server to see if it is still alive.
@@ -46,7 +46,7 @@ public class PingOp {
     private long startTime;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public PingOpImpl() {
       super(MessageType.PING, 0);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
index 371098d..1561ef9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
@@ -14,35 +14,35 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.SubscriptionNotEnabledException;
-import com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager;
-import com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManagerImpl;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.PoolCancelledException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.statistics.DummyStatisticsFactory;
-import com.gemstone.gemfire.internal.ScheduledThreadPoolExecutorWithKeepAlive;
-import com.gemstone.gemfire.internal.admin.ClientStatsManager;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.cache.client.internal;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.SubscriptionNotEnabledException;
+import org.apache.geode.cache.client.internal.pooling.ConnectionManager;
+import org.apache.geode.cache.client.internal.pooling.ConnectionManagerImpl;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.PoolCancelledException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.statistics.DummyStatisticsFactory;
+import org.apache.geode.internal.ScheduledThreadPoolExecutorWithKeepAlive;
+import org.apache.geode.internal.admin.ClientStatsManager;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.tier.sockets.AcceptorImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.net.InetSocketAddress;
@@ -354,7 +354,7 @@ public class PoolImpl implements InternalPool {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.Pool#getName()
+   * @see org.apache.geode.cache.Pool#getName()
    */
   public String getName() {
     return this.name;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
index a0459d2..9c9a49a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 import java.util.Iterator;
 import java.util.List;
@@ -50,7 +50,7 @@ public class PrimaryAckOp {
   
   private static class PrimaryAckOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public PrimaryAckOpImpl(List events) {
       super(MessageType.PERIODIC_ACK, events.size());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCache.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCache.java
index 9c7b6ec..703f935 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCache.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.ProxyQueryService;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxInstanceFactory;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceFactoryImpl;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.ProxyQueryService;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxInstanceFactory;
+import org.apache.geode.pdx.internal.PdxInstanceFactoryImpl;
 
 import java.util.Collections;
 import java.util.HashSet;
@@ -173,7 +173,7 @@ public class ProxyCache implements RegionService {
 
   protected class Stopper extends CancelCriterion {
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.CancelCriterion#cancelInProgress()
+     * @see org.apache.geode.CancelCriterion#cancelInProgress()
      */
     @Override
     public String cancelInProgress() {
@@ -188,7 +188,7 @@ public class ProxyCache implements RegionService {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.CancelCriterion#generateCancelledException(java.lang.Throwable)
+     * @see org.apache.geode.CancelCriterion#generateCancelledException(java.lang.Throwable)
      */
     @Override
     public RuntimeException generateCancelledException(Throwable e) {
@@ -221,7 +221,7 @@ public class ProxyCache implements RegionService {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.RegionService#rootRegions()
+   * @see org.apache.geode.cache.RegionService#rootRegions()
    */
   public Set<Region<?, ?>> rootRegions() {
     preOp();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCacheCloseOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCacheCloseOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCacheCloseOp.java
index 2747fa8..2d385fa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCacheCloseOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyCacheCloseOp.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
 
 public class ProxyCacheCloseOp {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyRegion.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyRegion.java
index 1113927..ca962df 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ProxyRegion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -25,28 +25,28 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.locks.Lock;
 
-import com.gemstone.gemfire.cache.AttributesMutator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheLoaderException;
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
-import com.gemstone.gemfire.internal.cache.snapshot.RegionSnapshotServiceImpl;
+import org.apache.geode.cache.AttributesMutator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.snapshot.RegionSnapshotService;
+import org.apache.geode.internal.cache.snapshot.RegionSnapshotServiceImpl;
 
 /**
  * A wrapper class over an actual Region instance. This is used when the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutAllOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutAllOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutAllOp.java
index 112d533..ab0ad58 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutAllOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutAllOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.HashMap;
@@ -28,23 +28,23 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException.PutAllPartialResult;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PutAllPartialResultException;
+import org.apache.geode.internal.cache.PutAllPartialResultException.PutAllPartialResult;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region putAll on a server
@@ -267,7 +267,7 @@ public class PutAllOp {
     private ArrayList keys = null;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public PutAllOpImpl(Region region, Map map,
         EventID eventId, boolean prSingleHopEnabled, boolean skipCallbacks, Object callbackArg) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
index 35760b5..30d1a92 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.AllConnectionsInUseException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.AllConnectionsInUseException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueryOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueryOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueryOp.java
index 30c28d5..6b3747e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueryOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueryOp.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Arrays;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ObjectPartList;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.internal.QueryUtils;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.ObjectPartList;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.internal.QueryUtils;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.SerializationException;
+import org.apache.geode.cache.client.ServerOperationException;
 
 /**
  * Does a region query on a server
@@ -68,7 +68,7 @@ public class QueryOp {
    */
   protected static class QueryOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public QueryOpImpl(String queryPredicate) {
       super(MessageType.QUERY, 1);
@@ -76,7 +76,7 @@ public class QueryOp {
     }
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public QueryOpImpl(String queryPredicate, Object[] queryParams) {
       super(MessageType.QUERY_WITH_PARAMETERS, 2 + queryParams.length);
@@ -89,7 +89,7 @@ public class QueryOp {
 
     /**
      * This constructor is used by our subclass CreateCQWithIROpImpl
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     protected QueryOpImpl(int msgType, int numParts) {
       super(msgType, numParts);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueConnectionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueConnectionImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueConnectionImpl.java
index 40cf58b..f405fca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueConnectionImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueConnectionImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.InputStream;
 import java.io.OutputStream;
@@ -26,11 +26,11 @@ import java.util.concurrent.atomic.AtomicReference;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.client.internal.ServerBlackList.FailureTracker;
-import com.gemstone.gemfire.cache.client.internal.pooling.ConnectionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.client.internal.ServerBlackList.FailureTracker;
+import org.apache.geode.cache.client.internal.pooling.ConnectionDestroyedException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.internal.logging.LogService;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManager.java
index 436a13b..b4a0c37 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManager.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 
 import java.util.concurrent.ScheduledExecutorService;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 /**
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
index 38ca6b1..b817fc8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueManagerImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -38,39 +38,39 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.NoSubscriptionServersAvailableException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.cache.client.internal.RegisterInterestTracker.RegionInterestEntry;
-import com.gemstone.gemfire.cache.client.internal.ServerBlackList.BlackListListener;
-import com.gemstone.gemfire.cache.client.internal.ServerBlackList.BlackListListenerAdapter;
-import com.gemstone.gemfire.cache.client.internal.ServerBlackList.FailureTracker;
-import com.gemstone.gemfire.cache.query.internal.CqStateImpl;
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.query.internal.cq.ClientCQ;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.ClientServerObserver;
-import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientUpdater;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.security.GemFireSecurityException;
-import com.gemstone.gemfire.i18n.StringId;
+import org.apache.geode.CancelException;
+import org.apache.geode.GemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.NoSubscriptionServersAvailableException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.cache.client.internal.RegisterInterestTracker.RegionInterestEntry;
+import org.apache.geode.cache.client.internal.ServerBlackList.BlackListListener;
+import org.apache.geode.cache.client.internal.ServerBlackList.BlackListListenerAdapter;
+import org.apache.geode.cache.client.internal.ServerBlackList.FailureTracker;
+import org.apache.geode.cache.query.internal.CqStateImpl;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.query.internal.cq.ClientCQ;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.ClientServerObserver;
+import org.apache.geode.internal.cache.ClientServerObserverHolder;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientUpdater;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.security.GemFireSecurityException;
+import org.apache.geode.i18n.StringId;
 
 /**
  * Manages Client Queues. Responsible for creating callback connections and
@@ -1384,7 +1384,7 @@ public class QueueManagerImpl implements QueueManager {
     public Set/* <ServerLocation> */getAllLocations() {
       HashSet locations = new HashSet();
       for (Iterator itr = connectionMap.keySet().iterator(); itr.hasNext();) {
-        com.gemstone.gemfire.cache.client.internal.Endpoint endpoint = (com.gemstone.gemfire.cache.client.internal.Endpoint) itr.next();
+        org.apache.geode.cache.client.internal.Endpoint endpoint = (org.apache.geode.cache.client.internal.Endpoint) itr.next();
         locations.add(endpoint.getLocation());
       }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueState.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueState.java
index 4259c5e..76ca2c4 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueState.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueState.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.ScheduledExecutorService;
-import com.gemstone.gemfire.internal.cache.EventID;
+import org.apache.geode.internal.cache.EventID;
 
 public interface QueueState {
 



[44/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupRequest.java b/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupRequest.java
index 582ab62..2de4b08 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -29,22 +29,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.admin.remote.AdminFailureResponse;
-import com.gemstone.gemfire.internal.admin.remote.AdminMultipleReplyProcessor;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
-import com.gemstone.gemfire.internal.admin.remote.CliLegacyMessage;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.admin.remote.AdminFailureResponse;
+import org.apache.geode.internal.admin.remote.AdminMultipleReplyProcessor;
+import org.apache.geode.internal.admin.remote.AdminResponse;
+import org.apache.geode.internal.admin.remote.CliLegacyMessage;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A request send from an admin VM to all of the peers to indicate

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupResponse.java b/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupResponse.java
index eee8917..d3595ef 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/FinishBackupResponse.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.HashSet;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.AdminResponse;
 
 /**
  * The reply for a {@link FinishBackupRequest}. The

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskRequest.java b/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskRequest.java
index 9c84820..2232377 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskRequest.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.Collection;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.admin.remote.AdminMultipleReplyProcessor;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
-import com.gemstone.gemfire.internal.admin.remote.CliLegacyMessage;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.admin.remote.AdminMultipleReplyProcessor;
+import org.apache.geode.internal.admin.remote.AdminResponse;
+import org.apache.geode.internal.admin.remote.CliLegacyMessage;
+import org.apache.geode.internal.cache.DiskStoreImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 /**
  * A request to from an admin VM to all non admin members

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskResponse.java b/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskResponse.java
index 050f4ac..622abd3 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/FlushToDiskResponse.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.AdminResponse;
 
 /**
  * The response to the {@link FlushToDiskRequest}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthConfigImpl.java
index 11122d3..754b0fb 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthConfigImpl.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 // @todo davidw Delegate to a "parent" config for properties that are not overridden.
 // This will be made easier with a special <code>HealthConfigAttribute</code> class.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthEvaluator.java
index ddd1358..f07cb2c 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthEvaluator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -22,12 +22,12 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Evaluates the health of various GemFire components in the VM

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthImpl.java
index f8ae44a..f944482 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/GemFireHealthImpl.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.CancelException;
+import org.apache.geode.admin.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.net.InetAddress;
 import java.net.UnknownHostException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/InetAddressUtil.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/InetAddressUtil.java b/geode-core/src/main/java/org/apache/geode/admin/internal/InetAddressUtil.java
index 43d8e44..cc70cc4 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/InetAddressUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/InetAddressUtil.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.net.InetAddress;
 import java.net.NetworkInterface;
@@ -23,11 +23,11 @@ import java.util.Enumeration;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/InternalManagedEntity.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/InternalManagedEntity.java b/geode-core/src/main/java/org/apache/geode/admin/internal/InternalManagedEntity.java
index 4ead1df..d963a21 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/InternalManagedEntity.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/InternalManagedEntity.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.ManagedEntity;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.ManagedEntity;
+import org.apache.geode.admin.ManagedEntityConfig;
 
 /**
  * Provides internal-only functionality that is expected of all

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/LogCollator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/LogCollator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/LogCollator.java
index 633fa89..6a183c5 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/LogCollator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/LogCollator.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.internal.admin.GfManagerAgent;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.ApplicationVM;
-import com.gemstone.gemfire.internal.logging.MergeLogFiles;
+import org.apache.geode.internal.admin.GfManagerAgent;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.ApplicationVM;
+import org.apache.geode.internal.logging.MergeLogFiles;
 
 import java.io.ByteArrayInputStream;
 import java.io.InputStream;  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigImpl.java
index 69751e9..086bf84 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-//import com.gemstone.gemfire.admin.DistributedSystemConfig;
-//import com.gemstone.gemfire.admin.ManagedEntity;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.SocketCreator;
+package org.apache.geode.admin.internal;
+
+//import org.apache.geode.admin.DistributedSystemConfig;
+//import org.apache.geode.admin.ManagedEntity;
+import org.apache.geode.admin.ManagedEntityConfig;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.SocketCreator;
 
 import java.io.File;
 import java.net.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXml.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXml.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXml.java
index ff6deca..6313e21 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXml.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXml.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.distributed.ConfigurationProperties;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.ConfigurationProperties;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 import org.xml.sax.*;
 
 import java.io.InputStream;
 
 /**
  * The abstract superclass of classes that convert XML into a {@link
- * com.gemstone.gemfire.admin.DistributedSystemConfig} and vice versa.
+ * org.apache.geode.admin.DistributedSystemConfig} and vice versa.
  * It provides helper methods and constants.
  *
  * @since GemFire 4.0
@@ -34,7 +34,7 @@ abstract class ManagedEntityConfigXml implements EntityResolver, ErrorHandler {
 
   /** The location of the DTD file */
   protected static final String DTD_LOCATION =
-    "/com/gemstone/gemfire/admin/doc-files/ds5_0.dtd";
+    "/org/apache/geode/admin/doc-files/ds5_0.dtd";
 
   /** The URL for the DTD */
   protected static final String SYSTEM_ID =
@@ -150,7 +150,7 @@ abstract class ManagedEntityConfigXml implements EntityResolver, ErrorHandler {
   }
 
   /**
-   * Throws a {@link com.gemstone.gemfire.cache.CacheXmlException}
+   * Throws a {@link org.apache.geode.cache.CacheXmlException}
    */
   public void error(SAXParseException ex) throws SAXException {
     IllegalArgumentException ex2 = new IllegalArgumentException(LocalizedStrings.ManagedEntityConfigXml_ERROR_WHILE_PARSING_XML.toLocalizedString());
@@ -159,7 +159,7 @@ abstract class ManagedEntityConfigXml implements EntityResolver, ErrorHandler {
   }
   
   /**
-   * Throws a {@link com.gemstone.gemfire.cache.CacheXmlException}
+   * Throws a {@link org.apache.geode.cache.CacheXmlException}
    */
   public void fatalError(SAXParseException ex) throws SAXException {
     IllegalArgumentException ex2 = new IllegalArgumentException(LocalizedStrings.ManagedEntityConfigXml_FATAL_ERROR_WHILE_PARSING_XML.toLocalizedString());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlGenerator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlGenerator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlGenerator.java
index e406ba3..80f183d 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlGenerator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlGenerator.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import javax.xml.transform.*; 
 //import javax.xml.transform.dom.DOMSource; 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlParser.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlParser.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlParser.java
index 58e90e9..1065caf 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlParser.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityConfigXmlParser.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import javax.xml.parsers.SAXParser;
 import javax.xml.parsers.SAXParserFactory;
@@ -88,7 +88,7 @@ public class ManagedEntityConfigXmlParser
   /**
    * Helper method for parsing an integer
    *
-   * @throws com.gemstone.gemfire.cache.CacheXmlException
+   * @throws org.apache.geode.cache.CacheXmlException
    *         If <code>s</code> is a malformed integer
    */
   private static int parseInt(String s) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityController.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityController.java
index 85193ef..c1a3fd1 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityController.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityController.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.admin.ManagedEntity;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.admin.ManagedEntity;
+import org.apache.geode.admin.ManagedEntityConfig;
 
 /**
  * Defines the actual administration (starting, stopping, etc.) of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityControllerFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityControllerFactory.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityControllerFactory.java
index c745835..372b2ed 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityControllerFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedEntityControllerFactory.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.ManagedEntity;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.ManagedEntity;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Creates ManagedEntityController for administration (starting, stopping, etc.) 
@@ -33,7 +33,7 @@ public class ManagedEntityControllerFactory {
 
   private static final Logger logger = LogService.getLogger();
   
-  private static final String ENABLED_MANAGED_ENTITY_CONTROLLER_CLASS_NAME = "com.gemstone.gemfire.admin.internal.EnabledManagedEntityController";
+  private static final String ENABLED_MANAGED_ENTITY_CONTROLLER_CLASS_NAME = "org.apache.geode.admin.internal.EnabledManagedEntityController";
   
   static ManagedEntityController createManagedEntityController(final AdminDistributedSystem system) {
     if (isEnabledManagedEntityController()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
index e0ba1bb..f6ca2cc 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ManagedSystemMemberImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.ConfigurationParameter;
+import org.apache.geode.admin.ManagedEntityConfig;
+import org.apache.geode.internal.admin.GemFireVM;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
 
 /**
  * A <code>SystemMember</code> that is also managed (or manageable) by

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthConfigImpl.java
index 08fd5a0..e58e975 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthConfigImpl.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
+import org.apache.geode.admin.*;
 
 // @todo Make this class (and all of its subclasses) {@link java.io.Externalizable} or
-// {@link com.gemstone.gemfire.DataSerializable}. 
+// {@link org.apache.geode.DataSerializable}. 
 /**
  * The implementation of <code>MemberHealthConfig</code>
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthEvaluator.java
index 5344724..6c76f69 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/MemberHealthEvaluator.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
-import com.gemstone.gemfire.internal.statistics.platform.ProcessStats;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.admin.*;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
+import org.apache.geode.internal.statistics.platform.ProcessStats;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupRequest.java b/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupRequest.java
index 482dac8..f90a8e7 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.IOException;
 import java.util.Collection;
@@ -26,22 +26,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.admin.remote.AdminFailureResponse;
-import com.gemstone.gemfire.internal.admin.remote.AdminMultipleReplyProcessor;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
-import com.gemstone.gemfire.internal.admin.remote.CliLegacyMessage;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.persistence.BackupManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.admin.remote.AdminFailureResponse;
+import org.apache.geode.internal.admin.remote.AdminMultipleReplyProcessor;
+import org.apache.geode.internal.admin.remote.AdminResponse;
+import org.apache.geode.internal.admin.remote.CliLegacyMessage;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.persistence.BackupManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A request to from an admin VM to all non admin members

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupResponse.java b/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupResponse.java
index 41f0b51..4368cce 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/PrepareBackupResponse.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.HashSet;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.AdminResponse;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.AdminResponse;
 
 /**
  * The response to the {@link PrepareBackupRequest}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticImpl.java
index 8ab39eb..987bdfa 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticImpl.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.internal.admin.Stat;
+import org.apache.geode.internal.admin.Stat;
 
 /**
  * Implementation of a single statistic in a <code>StatisticResource</code>
@@ -26,7 +26,7 @@ import com.gemstone.gemfire.internal.admin.Stat;
  *
  */
 public class StatisticImpl
-implements com.gemstone.gemfire.admin.Statistic {
+implements org.apache.geode.admin.Statistic {
 
   private static final long serialVersionUID = 3899296873901634399L;
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticResourceImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticResourceImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticResourceImpl.java
index e8054d0..9458759 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticResourceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/StatisticResourceImpl.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.SystemMember;
-import com.gemstone.gemfire.admin.Statistic;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.admin.Stat;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.admin.SystemMember;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.SystemMember;
+import org.apache.geode.admin.Statistic;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.admin.Stat;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.admin.SystemMember;
 
 import java.util.ArrayList;
 //import java.util.Date;
@@ -35,7 +35,7 @@ import java.util.List;
  * @since GemFire     3.5
  */
 public class StatisticResourceImpl 
-implements com.gemstone.gemfire.admin.StatisticResource {
+implements org.apache.geode.admin.StatisticResource {
 
   /** The underlying remote StatResource which this object delegates to */
   protected StatResource statResource;
@@ -59,12 +59,12 @@ implements com.gemstone.gemfire.admin.StatisticResource {
    *
    * @param statResource  the admin StatResource to manage/monitor
    * @param member        the SystemMember owning this resource
-   * @exception com.gemstone.gemfire.admin.AdminException 
+   * @exception org.apache.geode.admin.AdminException 
    *            if unable to create this StatisticResource for administration
    */
   public StatisticResourceImpl(StatResource statResource,
                                SystemMember member)
-                        throws com.gemstone.gemfire.admin.AdminException {
+                        throws org.apache.geode.admin.AdminException {
     this.statResource = statResource;
     this.member = member;
     this.name = this.statResource.getName();
@@ -112,7 +112,7 @@ implements com.gemstone.gemfire.admin.StatisticResource {
   //   Operations
   // -------------------------------------------------------------------------
 
-  public void refresh() throws com.gemstone.gemfire.admin.AdminException {
+  public void refresh() throws org.apache.geode.admin.AdminException {
     Stat[] stats = null;
     if (this.statResource != null) {
       stats = this.statResource.getStats();
@@ -143,7 +143,7 @@ implements com.gemstone.gemfire.admin.StatisticResource {
   
   /**
    * Updates the value of the {@link Statistic} corresponding to the internal 
-   * {@link com.gemstone.gemfire.internal.admin.Stat}
+   * {@link org.apache.geode.internal.admin.Stat}
    *
    * @param stat  the internal stat to use in updating the matching statistic
    */
@@ -159,7 +159,7 @@ implements com.gemstone.gemfire.admin.StatisticResource {
   
   /**
    * Creates a new {@link StatisticImpl} to represent the internal {@link 
-   * com.gemstone.gemfire.internal.admin.Stat}
+   * org.apache.geode.internal.admin.Stat}
    *
    * @param stat  the internal stat to wrap in a new statistic
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberBridgeServerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberBridgeServerImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberBridgeServerImpl.java
index 0c7e941..546983c 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberBridgeServerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberBridgeServerImpl.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.Serializable;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.SystemMemberBridgeServer;
-import com.gemstone.gemfire.admin.SystemMemberCacheServer;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.SystemMemberBridgeServer;
+import org.apache.geode.admin.SystemMemberCacheServer;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Implementation of an object used for managing cache servers.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventImpl.java
index 9907234..e4f7e60 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventImpl.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.cache.Operation;
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.cache.Operation;
 
 /**
  * An event that describes an operation on a cache.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventProcessor.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventProcessor.java
index df3d83e..43f9b89 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheEventProcessor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,17 +25,17 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.SystemMemberCacheEvent;
-import com.gemstone.gemfire.admin.SystemMemberCacheListener;
-import com.gemstone.gemfire.admin.SystemMemberRegionEvent;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.SystemMemberCacheEvent;
+import org.apache.geode.admin.SystemMemberCacheListener;
+import org.apache.geode.admin.SystemMemberRegionEvent;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * This class processes the message to be delivered to admin node.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheImpl.java
index ec7650c..7c1ba71 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberCacheImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ObjIdMap;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ObjIdMap;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
@@ -136,7 +136,7 @@ public class SystemMemberCacheImpl implements SystemMemberCache {
   }
 
   public SystemMemberRegion getRegion(String path)
-    throws com.gemstone.gemfire.admin.AdminException
+    throws org.apache.geode.admin.AdminException
   {
     Region r = this.vm.getRegion(this.info, path);
     if (r == null) {
@@ -234,7 +234,7 @@ public class SystemMemberCacheImpl implements SystemMemberCache {
     return new StatisticImpl(stat);
   }
   protected SystemMemberRegion createSystemMemberRegion(Region r)
-    throws com.gemstone.gemfire.admin.AdminException
+    throws org.apache.geode.admin.AdminException
   {
     SystemMemberRegionImpl sysMemberRegion = new SystemMemberRegionImpl(this, r);
     sysMemberRegion.refresh();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
index 5bd8e5b..57db801 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberImpl.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Config;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Config;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.net.InetAddress;
@@ -41,8 +41,8 @@ import java.util.*;
  * @since GemFire     3.5
  */
 public class SystemMemberImpl 
-implements com.gemstone.gemfire.admin.SystemMember,
-           com.gemstone.gemfire.admin.internal.ConfigurationParameterListener {
+implements org.apache.geode.admin.SystemMember,
+           org.apache.geode.admin.internal.ConfigurationParameterListener {
 
   private static final Logger logger = LogService.getLogger();
   
@@ -209,7 +209,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
   }
 
   public StatisticResource[] getStat(String statisticsTypeName) 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     StatisticResource[] res = new StatisticResource[0];
     if (this.vm != null) {
       res = getStatsImpl(this.vm.getStats(statisticsTypeName));
@@ -218,7 +218,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
   }
 
   public StatisticResource[] getStats() 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     StatisticResource[] statsImpl = new StatisticResource[0];
     if (this.vm != null) {
       statsImpl = getStatsImpl(this.vm.getStats(null));
@@ -237,7 +237,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
   }
 
   public final SystemMemberCache getCache()
-    throws com.gemstone.gemfire.admin.AdminException
+    throws org.apache.geode.admin.AdminException
   {
     GemFireVM vm = getGemFireVM(); // fix for bug 33505
     if (vm == null) return null;
@@ -253,7 +253,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
   }
   
   public void refreshConfig() 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     GemFireVM vm = getGemFireVM();
     if (vm == null) return;
     refreshConfig(vm.getConfig());
@@ -264,7 +264,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
    * configuration based on the given <code>Config</code> object.
    */
   public final void refreshConfig(Config config) 
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     if (config == null) {
       throw new AdminException(LocalizedStrings.SystemMemberImpl_FAILED_TO_REFRESH_CONFIGURATION_PARAMETERS_FOR_0.toLocalizedString(new Object[] {getId()}));
     }
@@ -327,11 +327,11 @@ implements com.gemstone.gemfire.admin.SystemMember,
   //   Listener callbacks
   // -------------------------------------------------------------------------
   
-  // -- com.gemstone.gemfire.admin.internal.ConfigurationParameterListener ---
+  // -- org.apache.geode.admin.internal.ConfigurationParameterListener ---
   public void configurationParameterValueChanged(ConfigurationParameter parm) {
     try {
       setConfiguration(new ConfigurationParameter[] { parm });
-    } catch (com.gemstone.gemfire.admin.AdminException e) {
+    } catch (org.apache.geode.admin.AdminException e) {
       // this shouldn't occur since this is a config listener method...
       logger.warn(e.getMessage(), e);
       throw new RuntimeAdminException(e);
@@ -442,7 +442,7 @@ implements com.gemstone.gemfire.admin.SystemMember,
    * @return new impl instance of {@link StatisticResource}
    */
   protected StatisticResource createStatisticResource(StatResource stat)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     return new StatisticResourceImpl(stat, this);
   }
   
@@ -472,14 +472,14 @@ implements com.gemstone.gemfire.admin.SystemMember,
    * @return new impl instance of {@link SystemMemberCache}
    */
   protected SystemMemberCache createSystemMemberCache(GemFireVM vm)
-    throws com.gemstone.gemfire.admin.AdminException
+    throws org.apache.geode.admin.AdminException
   {
     return new SystemMemberCacheImpl(vm);
   }
 
   /** Wrap the internal stats with impls of {@link StatisticResource} */
   protected StatisticResource[] getStatsImpl(StatResource[] stats)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     List statList = new ArrayList();
     for (int i = 0; i < stats.length; i++) {
       statList.add(createStatisticResource(stats[i]));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionEventImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionEventImpl.java
index 931d67a..c59e049 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionEventImpl.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.cache.Operation;
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.cache.Operation;
 
 /**
  * An event that describes an operation on a region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionImpl.java
index c1655f5..9e8f392 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMemberRegionImpl.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.Assert;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.admin.remote.*;
+import org.apache.geode.admin.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.Assert;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.admin.remote.*;
 
 import java.io.File;
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMembershipEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMembershipEventImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMembershipEventImpl.java
index ebc5270..6ec9e94 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMembershipEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/SystemMembershipEventImpl.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * An event delivered to a {@link SystemMembershipListener} when a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/package.html b/geode-core/src/main/java/org/apache/geode/admin/internal/package.html
index a233ec5..38f9174 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/package.html
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/package.html
@@ -18,28 +18,28 @@ limitations under the License.
 <BODY>
 
 <P>Contains the implementation of the external admin APIs from
-<a href="{@docRoot}/com/gemstone/gemfire/admin/package-summary.html#package_description">com.gemstone.gemfire.admin</a>.</P>
+<a href="{@docRoot}/org/apache/geode/admin/package-summary.html#package_description">org.apache.geode.admin</a>.</P>
 
 <H2>Monitoring the "health" of GemFire</H2>
 
 <P>The health monitoring implementation comes in two pieces.  On the
 client (administrator) side there is a {@link
-com.gemstone.gemfire.admin.internal.GemFireHealthImpl} object that is
+org.apache.geode.admin.internal.GemFireHealthImpl} object that is
 responsible for configuring a {@link
-com.gemstone.gemfire.distributed.internal.HealthMonitorImpl} that runs
+org.apache.geode.distributed.internal.HealthMonitorImpl} that runs
 in the member VMs.  The communication between the administration
 process and the member process is accomplised via a {@link
-com.gemstone.gemfire.internal.admin.GemFireVM GemFireVM} from the
+org.apache.geode.internal.admin.GemFireVM GemFireVM} from the
 "internal admin" API.  The <code>HealthMonitorImpl</code> is a thread
 that periodically consults a {@link
-com.gemstone.gemfire.admin.internal.GemFireHealthEvaluator} that uses
-a {@link com.gemstone.gemfire.admin.internal.GemFireHealthConfigImpl}
+org.apache.geode.admin.internal.GemFireHealthEvaluator} that uses
+a {@link org.apache.geode.admin.internal.GemFireHealthConfigImpl}
 to determine the health of a GemFire component.  Most of the health
-criteria are based on {@linkplain com.gemstone.gemfire.Statistics
+criteria are based on {@linkplain org.apache.geode.Statistics
 statistics} that are maintained by GemFire.  When the
 <code>HealthMonitorImpl</code> determines that the health of a GemFire
 component has changed, it alerts the administrator process via a
-{@link com.gemstone.gemfire.internal.admin.HealthListener}.</P>
+{@link org.apache.geode.internal.admin.HealthListener}.</P>
 
 
 <P>The below diagram explains how the classes that monitor the health

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/Agent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/Agent.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/Agent.java
index f4139eb..9daa866 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/Agent.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/Agent.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx;
+package org.apache.geode.admin.jmx;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
+import org.apache.geode.LogWriter;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.AdminDistributedSystem;
 
 //import javax.management.MBeanException;
 import javax.management.MalformedObjectNameException;
@@ -67,7 +67,7 @@ import javax.management.ObjectName;
  * @see AgentFactory
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface Agent {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentConfig.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentConfig.java
index 9bb4c25..b2f04c8 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentConfig.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx;
+package org.apache.geode.admin.jmx;
 
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-//import com.gemstone.gemfire.admin.internal.InetAddressUtil;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
+//import org.apache.geode.admin.internal.InetAddressUtil;
 
 /**
  * A configuration object for a JMX administration {@linkplain Agent
@@ -274,7 +274,7 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
  * 
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface AgentConfig extends DistributedSystemConfig {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentFactory.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentFactory.java
index 72a7ba6..69bae36 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/AgentFactory.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx;
+package org.apache.geode.admin.jmx;
 
-//import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.jmx.internal.AgentConfigImpl;
-import com.gemstone.gemfire.admin.jmx.internal.AgentImpl;
+//import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.jmx.internal.AgentConfigImpl;
+import org.apache.geode.admin.jmx.internal.AgentImpl;
 
 /**
  * A factory class that creates JMX administration entities.
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AgentFactory {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
index fa5a1ea..5ff4bfa 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AdminDistributedSystemJmxImpl.java
@@ -14,27 +14,27 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.admin.internal.CacheServerConfigImpl;
-import com.gemstone.gemfire.admin.internal.DistributionLocatorImpl;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-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.internal.Assert;
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.admin.remote.UpdateAlertDefinitionMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.admin.jmx.internal;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.*;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.admin.internal.CacheServerConfigImpl;
+import org.apache.geode.admin.internal.DistributionLocatorImpl;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.admin.Alert;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.admin.remote.UpdateAlertDefinitionMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import javax.management.*;
@@ -98,7 +98,7 @@ public class AdminDistributedSystemJmxImpl
    *          configuration defining the JMX agent.
    */
   public AdminDistributedSystemJmxImpl(AgentConfigImpl config)
-      throws com.gemstone.gemfire.admin.AdminException {
+      throws org.apache.geode.admin.AdminException {
     super(config);
     this.mbeanName = "GemFire:type=AdminDistributedSystem,id="
         + MBeanUtil.makeCompliantMBeanNameProperty(getId());
@@ -147,7 +147,7 @@ public class AdminDistributedSystemJmxImpl
   /**
    * Registers the MBeans for monitoring the health of GemFire 
    *
-   * @see com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl#getGemFireHealth
+   * @see org.apache.geode.admin.internal.AdminDistributedSystemImpl#getGemFireHealth
    */
   public ObjectName monitorGemFireHealth() throws MalformedObjectNameException {
     GemFireHealthJmxImpl health = (GemFireHealthJmxImpl) getGemFireHealth();
@@ -234,7 +234,7 @@ public class AdminDistributedSystemJmxImpl
   /** Override createSystemMember by instantiating SystemMemberJmxImpl */
   @Override
   protected SystemMember createSystemMember(ApplicationVM app)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     return new SystemMemberJmxImpl(this, app);
   }
 
@@ -246,13 +246,13 @@ public class AdminDistributedSystemJmxImpl
    *          InternalDistributedMember instance for which a SystemMember
    *          instance is to be constructed.
    * @return constructed SystemMember instance
-   * @throws com.gemstone.gemfire.admin.AdminException
+   * @throws org.apache.geode.admin.AdminException
    *           if construction of SystemMember instance fails
    *
    * @since GemFire 6.5
    */
   protected SystemMember createSystemMember(InternalDistributedMember member)
-      throws com.gemstone.gemfire.admin.AdminException {
+      throws org.apache.geode.admin.AdminException {
     return new SystemMemberJmxImpl(this, member);
   }
   
@@ -274,7 +274,7 @@ public class AdminDistributedSystemJmxImpl
   /** Override createGemFireHealth by instantiating GemFireHealthJmxImpl */
   @Override
   protected GemFireHealth createGemFireHealth(GfManagerAgent system) 
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     if (system == null) {
       throw new IllegalStateException(LocalizedStrings.AdminDistributedSystemJmxImpl_GFMANAGERAGENT_MUST_NOT_BE_NULL.toLocalizedString());
     }
@@ -316,7 +316,7 @@ public class AdminDistributedSystemJmxImpl
   private static final String EML_SUBJ_PRFX_GFE_NOTFY = "[GemFire Notification] ";
   private static final String EML_SUBJ_ITEM_GFE_DS = "Distributed System: ";
 
-  // --------- com.gemstone.gemfire.internal.admin.JoinLeaveListener ---------
+  // --------- org.apache.geode.internal.admin.JoinLeaveListener ---------
   /** 
    * Listener callback for when a member has joined this DistributedSystem.
    * <p>
@@ -325,7 +325,7 @@ public class AdminDistributedSystemJmxImpl
    *
    * @param source  the distributed system that fired nodeJoined
    * @param joined  the VM that joined
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeJoined
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeJoined
    */
   @Override
   public void nodeJoined(GfManagerAgent source, GemFireVM joined) {
@@ -397,7 +397,7 @@ public class AdminDistributedSystemJmxImpl
    *
    * @param source  the distributed system that fired nodeLeft
    * @param left    the VM that left
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeLeft
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeLeft
    */
   @Override
   public void nodeLeft(GfManagerAgent source, GemFireVM left) {
@@ -459,7 +459,7 @@ public class AdminDistributedSystemJmxImpl
    *
    * @param source  the distributed system that fired nodeCrashed
    * @param crashed the VM that crashed
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeCrashed
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeCrashed
    */
   @Override
   public void nodeCrashed(GfManagerAgent source, GemFireVM crashed) {
@@ -516,7 +516,7 @@ public class AdminDistributedSystemJmxImpl
     }
   }
 
-  // ----------- com.gemstone.gemfire.internal.admin.AlertListener -----------
+  // ----------- org.apache.geode.internal.admin.AlertListener -----------
   /** 
    * Listener callback for when a SystemMember of this DistributedSystem has 
    * crashed.
@@ -524,7 +524,7 @@ public class AdminDistributedSystemJmxImpl
    * Fires a Notification with the information from the alert.
    *
    * @param alert the gemfire alert to broadcast as a notification
-   * @see com.gemstone.gemfire.internal.admin.AlertListener#alert
+   * @see org.apache.geode.internal.admin.AlertListener#alert
    */
   @Override
   public void alert(Alert alert) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentConfigImpl.java
index a71c479..e9ffd51 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentConfigImpl.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
-
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.admin.DistributionLocatorConfig;
-import com.gemstone.gemfire.admin.internal.DistributedSystemConfigImpl;
-import com.gemstone.gemfire.admin.internal.InetAddressUtil;
-import com.gemstone.gemfire.admin.jmx.Agent;
-import com.gemstone.gemfire.admin.jmx.AgentConfig;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.util.IOUtils;
+package org.apache.geode.admin.jmx.internal;
+
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.admin.DistributionLocatorConfig;
+import org.apache.geode.admin.internal.DistributedSystemConfigImpl;
+import org.apache.geode.admin.internal.InetAddressUtil;
+import org.apache.geode.admin.jmx.Agent;
+import org.apache.geode.admin.jmx.AgentConfig;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.util.IOUtils;
 
 import java.io.*;
 import java.net.InetAddress;
@@ -35,7 +35,7 @@ import java.util.Iterator;
 import java.util.Properties;
 import java.util.StringTokenizer;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Provides the JMX Agent configuration properties.
@@ -1494,7 +1494,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Returns {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_HTTP_PORT}
+   * org.apache.geode.admin.jmx.AgentConfig#DEFAULT_HTTP_PORT}
    * if httpPort is empty; else validates
    * that it's an integer and returns the int form.
    */
@@ -1508,8 +1508,8 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Validates that httpPort is either zero or within the {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#MIN_HTTP_PORT} and {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#MAX_HTTP_PORT} values.
+   * org.apache.geode.admin.jmx.AgentConfig#MIN_HTTP_PORT} and {@link
+   * org.apache.geode.admin.jmx.AgentConfig#MAX_HTTP_PORT} values.
    */
   private int validateHttpPort(int val) {
     if (val < 0 || val > MAX_HTTP_PORT) {
@@ -1521,7 +1521,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Returns {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_HTTP_BIND_ADDRESS}
+   * org.apache.geode.admin.jmx.AgentConfig#DEFAULT_HTTP_BIND_ADDRESS}
    * unless httpBindAddress can be used to
    * create a valid InetAddress.
    */
@@ -1548,7 +1548,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Returns {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_SNMP_BIND_ADDRESS}
+   * org.apache.geode.admin.jmx.AgentConfig#DEFAULT_SNMP_BIND_ADDRESS}
    * unless snmpBindAddress can be used to
    * create a valid InetAddress.
    */
@@ -1590,7 +1590,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
   // RMIConnectorServer property validators...
 
   /**
-   * Returns {@link com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_RMI_PORT}
+   * Returns {@link org.apache.geode.admin.jmx.AgentConfig#DEFAULT_RMI_PORT}
    * if rmiPort is empty; else validates
    * that it's an integer and returns the int form.
    */
@@ -1604,8 +1604,8 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Validates that rmiPort is either zero or within the {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#MIN_RMI_PORT}
-   * and {@link com.gemstone.gemfire.admin.jmx.AgentConfig#MAX_RMI_PORT}
+   * org.apache.geode.admin.jmx.AgentConfig#MIN_RMI_PORT}
+   * and {@link org.apache.geode.admin.jmx.AgentConfig#MAX_RMI_PORT}
    * values.
    */
   private int validateRmiPort(int val) {
@@ -1617,7 +1617,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
   }
 
   /**
-   * Returns {@link com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_RMI_SERVER_PORT}
+   * Returns {@link org.apache.geode.admin.jmx.AgentConfig#DEFAULT_RMI_SERVER_PORT}
    * if rmi-server-port is empty; else validates that it's an integer within the
    * allowed range and returns the int form.
    */
@@ -1631,8 +1631,8 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Validates that rmiPort is either zero or within the {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#MIN_RMI_PORT}
-   * and {@link com.gemstone.gemfire.admin.jmx.AgentConfig#MAX_RMI_PORT}
+   * org.apache.geode.admin.jmx.AgentConfig#MIN_RMI_PORT}
+   * and {@link org.apache.geode.admin.jmx.AgentConfig#MAX_RMI_PORT}
    * values.
    */
   private int validateRmiServerPort(int val) {
@@ -1645,7 +1645,7 @@ public class AgentConfigImpl extends DistributedSystemConfigImpl
 
   /**
    * Returns {@link
-   * com.gemstone.gemfire.admin.jmx.AgentConfig#DEFAULT_RMI_BIND_ADDRESS}
+   * org.apache.geode.admin.jmx.AgentConfig#DEFAULT_RMI_BIND_ADDRESS}
    * unless rmiBindAddress can be used to create a
    * valid InetAddress.
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
index 7d880ad..37e7eea 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/AgentImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.jmx.internal;
+package org.apache.geode.admin.jmx.internal;
 
 import java.io.File;
 import java.io.IOException;
@@ -48,31 +48,31 @@ import mx4j.tools.adaptor.http.HttpAdaptor;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.jmx.Agent;
-import com.gemstone.gemfire.admin.jmx.AgentConfig;
-import com.gemstone.gemfire.admin.jmx.AgentFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Banner;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.admin.remote.TailLogResponse;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogConfig;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.GemFireException;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.LogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.jmx.Agent;
+import org.apache.geode.admin.jmx.AgentConfig;
+import org.apache.geode.admin.jmx.AgentFactory;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Banner;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.admin.remote.TailLogResponse;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogConfig;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterFactory;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.logging.log4j.LogWriterAppender;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
 
 /**
  * The GemFire JMX Agent provides the ability to administrate one GemFire
@@ -81,8 +81,8 @@ import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
  * @since GemFire     3.5
  */
 public class AgentImpl
-implements com.gemstone.gemfire.admin.jmx.Agent,
-           com.gemstone.gemfire.admin.jmx.internal.ManagedResource {
+implements org.apache.geode.admin.jmx.Agent,
+           org.apache.geode.admin.jmx.internal.ManagedResource {
 
   private static final Logger logger = LogService.getLogger();
   
@@ -185,7 +185,7 @@ implements com.gemstone.gemfire.admin.jmx.Agent,
    * Constructs a new Agent using the specified configuration.
    *
    * @param agentConfig instance of configuration for Agent
-   * @throws com.gemstone.gemfire.admin.AdminException TODO-javadocs
+   * @throws org.apache.geode.admin.AdminException TODO-javadocs
    * @throws IllegalArgumentException if agentConfig is null
    */
   public AgentImpl(AgentConfigImpl agentConfig)
@@ -861,13 +861,13 @@ implements com.gemstone.gemfire.admin.jmx.Agent,
    * Adds a ShutdownHook to the Agent for cleaning up any resources
    */
   private void addShutdownHook() {
-    if( ! Boolean.getBoolean( com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DISABLE_SHUTDOWN_HOOK_PROPERTY)) {
+    if( ! Boolean.getBoolean( org.apache.geode.distributed.internal.InternalDistributedSystem.DISABLE_SHUTDOWN_HOOK_PROPERTY)) {
       Runtime.getRuntime().addShutdownHook(shutdownHook);
     }
   }
 
   private void removeShutdownHook() {
-    if( ! Boolean.getBoolean( com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DISABLE_SHUTDOWN_HOOK_PROPERTY)) {
+    if( ! Boolean.getBoolean( org.apache.geode.distributed.internal.InternalDistributedSystem.DISABLE_SHUTDOWN_HOOK_PROPERTY)) {
       Runtime.getRuntime().removeShutdownHook(shutdownHook);
     }
   }
@@ -876,7 +876,7 @@ implements com.gemstone.gemfire.admin.jmx.Agent,
    * Creates a LogWriterI18n for this Agent to use in logging.
    */
   @edu.umd.cs.findbugs.annotations.SuppressWarnings(value="RV_RETURN_VALUE_IGNORED_BAD_PRACTICE", justification="Return value for file delete is not important here.") 
-  private void initLogWriter() throws com.gemstone.gemfire.admin.AdminException {
+  private void initLogWriter() throws org.apache.geode.admin.AdminException {
     final LogConfig logConfig = this.agentConfig.createLogConfig();
     
     // LOG: create logWriterAppender here
@@ -1031,7 +1031,7 @@ implements com.gemstone.gemfire.admin.jmx.Agent,
    * @param config
    */
   private AdminDistributedSystem createDistributedSystem(AgentConfigImpl config)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     return new AdminDistributedSystemJmxImpl(config);
   }
 
@@ -1043,7 +1043,7 @@ implements com.gemstone.gemfire.admin.jmx.Agent,
    * Command-line main for running the GemFire Management Agent.
    * <p>
    * Accepts command-line arguments matching the options in {@link AgentConfig}
-   * and {@link com.gemstone.gemfire.admin.DistributedSystemConfig}.
+   * and {@link org.apache.geode.admin.DistributedSystemConfig}.
    * <p>
    * <code>AgentConfig</code> will convert -Jarguments to System properties.
    */


[20/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesRequest.java
index 23c778f..ec9cac2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesResponse.java
index 305168e..360ce49 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectNamesResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link ObjectNamesResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/PrepareRevokePersistentIDRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/PrepareRevokePersistentIDRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/PrepareRevokePersistentIDRequest.java
index 414bc59..a227ee4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/PrepareRevokePersistentIDRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/PrepareRevokePersistentIDRequest.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.persistence.RevokeFailedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.persistence.RevokeFailedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * An instruction to all members that they should forget 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotRequest.java
index 3d2ecd5..975e3d7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotRequest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 
 /**
  * A message that is sent to a particular distribution manager to get its
- * current {@link com.gemstone.gemfire.admin.GemFireMemberStatus}
+ * current {@link org.apache.geode.admin.GemFireMemberStatus}
  * 
  */
 public class RefreshMemberSnapshotRequest extends AdminRequest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotResponse.java
index f77dd0f..b942560 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RefreshMemberSnapshotResponse.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.GemFireMemberStatus;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.GemFireMemberStatus;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 /**
  * A message that is sent to a particular distribution manager to get its
- * current {@link com.gemstone.gemfire.admin.GemFireMemberStatus}.
+ * current {@link org.apache.geode.admin.GemFireMemberStatus}.
  * 
  */
 public class RefreshMemberSnapshotResponse extends AdminResponse {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminMessage.java
index 0c2e83f..7fe89e3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminMessage.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.DistributedSystem;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.cache.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.DistributedSystem;
 import java.io.*;
 //import java.util.*;
 
@@ -44,7 +44,7 @@ public abstract class RegionAdminMessage extends PooledDistributionMessage {
   }
 
   /**
-   * @throws com.gemstone.gemfire.cache.CacheRuntimeException if no cache created
+   * @throws org.apache.geode.cache.CacheRuntimeException if no cache created
    */
   protected Region getRegion(DistributedSystem sys) {
     Cache cache = CacheFactory.getInstance(sys);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminRequest.java
index 1e50077..82a8016 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAdminRequest.java
@@ -16,18 +16,18 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.admin.OperationCancelledException;
-import com.gemstone.gemfire.admin.RegionNotFoundException;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.cache.*;
-//import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.*;
+//import org.apache.geode.admin.OperationCancelledException;
+import org.apache.geode.admin.RegionNotFoundException;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.cache.*;
+//import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 
@@ -48,7 +48,7 @@ public abstract class RegionAdminRequest extends AdminRequest {
   }
 
   /**
-   * @throws com.gemstone.gemfire.cache.CacheRuntimeException if no cache created
+   * @throws org.apache.geode.cache.CacheRuntimeException if no cache created
    */
   protected Region getRegion(DistributedSystem sys) {
     Cache cache = CacheFactory.getInstance(sys);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesRequest.java
index dfe9035..b356162 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesResponse.java
index 0eb5cb8..cc4800c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionAttributesResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link RegionAttributesResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionRequest.java
index e078197..6e1fc90 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionRequest.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 import java.io.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionResponse.java
index 8077d5f..fa0403f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionResponse.java
@@ -16,17 +16,17 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.distributed.internal.*;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link RegionResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeRequest.java
index 5cf2402..eff350a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 //import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeResponse.java
index 55ec372..c979b0d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSizeResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link RegionSizeRequest}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsRequest.java
index a57994c..f5e269e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsResponse.java
index 9225711..137dac2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionStatisticsResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link RegionStatisticsResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionSizeRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionSizeRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionSizeRequest.java
index b238d01..ebbbb47 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionSizeRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionSizeRequest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionManager;
 
 /**
  * Admin request to transfer region info for a member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionsSizeResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionsSizeResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionsSizeResponse.java
index 3126404..c990c17 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionsSizeResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RegionSubRegionsSizeResponse.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,15 +24,15 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.RegionSubRegionSnapshot;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.RegionSubRegionSnapshot;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Admin response carrying region info for a member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteAlert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteAlert.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteAlert.java
index 6b89b7b..706d32e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteAlert.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteAlert.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.DateFormatter;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.DateFormatter;
+import org.apache.geode.internal.logging.LogWriterImpl;
 
 import java.io.*;
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteApplicationVM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteApplicationVM.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteApplicationVM.java
index 4b037ad..7f6e2f3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteApplicationVM.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteApplicationVM.java
@@ -16,10 +16,10 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Represents an application VM (member of the distributed system).

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteBridgeServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteBridgeServer.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteBridgeServer.java
index fa0d26e..7cdfb17 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteBridgeServer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteBridgeServer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,23 +22,23 @@ import java.io.IOException;
 import java.io.Serializable;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.ClientSession;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.cache.InterestRegistrationListener;
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.cache.server.ServerLoadProbeAdapter;
-import com.gemstone.gemfire.cache.server.ServerMetrics;
-import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.cache.AbstractCacheServer;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.ClientSession;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.cache.InterestRegistrationListener;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.cache.server.ServerLoadProbeAdapter;
+import org.apache.geode.cache.server.ServerMetrics;
+import org.apache.geode.cache.server.ClientSubscriptionConfig;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.AdminBridgeServer;
+import org.apache.geode.internal.cache.AbstractCacheServer;
+import org.apache.geode.internal.cache.CacheServerImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A remote (serializable) implementation of <code>BridgeServer</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheInfo.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheInfo.java
index 8c7157a..e81c7a3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheInfo.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.admin.CacheInfo;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.admin.CacheInfo;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
 
-//import com.gemstone.gemfire.internal.*;
+//import org.apache.geode.internal.*;
 
 /**
  * This class is an implementation of the {@link CacheInfo} interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheStatistics.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheStatistics.java
index bd619d6..314e9e5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteCacheStatistics.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.cache.*;
 import java.io.*;
 
 /**
- * This class represents a snapshot of a {@link com.gemstone.gemfire.cache.CacheStatistics}
+ * This class represents a snapshot of a {@link org.apache.geode.cache.CacheStatistics}
  * from a remote vm
  */
 public class RemoteCacheStatistics implements CacheStatistics, DataSerializable {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteDLockInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteDLockInfo.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteDLockInfo.java
index 117b95c..e6ec776 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteDLockInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteDLockInfo.java
@@ -16,17 +16,17 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.admin.*;
-//import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.locks.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.admin.*;
+//import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.locks.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 import java.util.Date;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 public class RemoteDLockInfo implements DLockInfo, DataSerializable {
   private static final long serialVersionUID = 3350265007784675017L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteEntrySnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteEntrySnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteEntrySnapshot.java
index 5525cd5..4c3117f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteEntrySnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteEntrySnapshot.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.admin.*;
 //import java.util.*;
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGemFireVM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGemFireVM.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGemFireVM.java
index 7374222..e92f5e5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGemFireVM.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGemFireVM.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -26,31 +26,31 @@ import java.util.Properties;
 import java.util.concurrent.BlockingQueue;
 import java.util.concurrent.LinkedBlockingQueue;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.GemFireMemberStatus;
-import com.gemstone.gemfire.admin.OperationCancelledException;
-import com.gemstone.gemfire.admin.RegionSubRegionSnapshot;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Config;
-import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.admin.CacheInfo;
-import com.gemstone.gemfire.internal.admin.DLockInfo;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.GfManagerAgent;
-import com.gemstone.gemfire.internal.admin.HealthListener;
-import com.gemstone.gemfire.internal.admin.ListenerIdMap;
-import com.gemstone.gemfire.internal.admin.Stat;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
-import com.gemstone.gemfire.internal.admin.StatListener;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.GemFireMemberStatus;
+import org.apache.geode.admin.OperationCancelledException;
+import org.apache.geode.admin.RegionSubRegionSnapshot;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Config;
+import org.apache.geode.internal.admin.AdminBridgeServer;
+import org.apache.geode.internal.admin.Alert;
+import org.apache.geode.internal.admin.CacheInfo;
+import org.apache.geode.internal.admin.DLockInfo;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.GfManagerAgent;
+import org.apache.geode.internal.admin.HealthListener;
+import org.apache.geode.internal.admin.ListenerIdMap;
+import org.apache.geode.internal.admin.Stat;
+import org.apache.geode.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.StatListener;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides access to a remote gemfire VM for purposes of gathering statistics
@@ -443,7 +443,7 @@ public abstract class RemoteGemFireVM implements GemFireVM {
   }
   
   /**
-   * Returns the runtime {@link com.gemstone.gemfire.admin.GemFireMemberStatus} from the vm
+   * Returns the runtime {@link org.apache.geode.admin.GemFireMemberStatus} from the vm
    * The idea is this snapshot is similar to stats that represent the current state of a 
    * running VM. However, this is a bit higher level than a stat 
    */
@@ -454,7 +454,7 @@ public abstract class RemoteGemFireVM implements GemFireVM {
   }
 
   /**
-   * Returns the runtime {@link com.gemstone.gemfire.admin.RegionSubRegionSnapshot} from the vm
+   * Returns the runtime {@link org.apache.geode.admin.RegionSubRegionSnapshot} from the vm
    * The idea is this snapshot is quickly salvageable to present a cache's region's info 
    */
   public RegionSubRegionSnapshot getRegionSnapshot(){
@@ -837,10 +837,10 @@ public abstract class RemoteGemFireVM implements GemFireVM {
 
   /**
    * A daemon thread that reads  
-   * com.gemstone.gemfire.internal.admin.remote.RemoteGemFireVM.DispatchArgs 
+   * org.apache.geode.internal.admin.remote.RemoteGemFireVM.DispatchArgs 
    * off of a queue
    * and delivers callbacks to the appropriate {@link 
-   * com.gemstone.gemfire.internal.admin.StatListener}.
+   * org.apache.geode.internal.admin.StatListener}.
    */
   private class StatDispatcher extends Thread {
     private BlockingQueue queue = new LinkedBlockingQueue();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGfManagerAgent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGfManagerAgent.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGfManagerAgent.java
index 9394bb2..cf1bed4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGfManagerAgent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteGfManagerAgent.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.IncompatibleSystemException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.OperationCancelledException;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DisconnectListener;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.ReconnectListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.IncompatibleSystemException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.OperationCancelledException;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.DisconnectListener;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.ReconnectListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterFactory;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.security.AuthenticationFailedException;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;
@@ -88,7 +88,7 @@ public
   
   /** 
    * Optional display name used for {@link 
-   * com.gemstone.gemfire.distributed.DistributedSystem#getName()}.
+   * org.apache.geode.distributed.DistributedSystem#getName()}.
    */
   private final String displayName;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteObjectName.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteObjectName.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteObjectName.java
index cb105c1..90a7d8b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteObjectName.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteObjectName.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-//import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+//import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+//import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionAttributes.java
index f8740db..d19aed3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionAttributes.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,33 +25,33 @@ import java.util.HashSet;
 import java.util.Properties;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheCallback;
-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.CustomExpiry;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.DiskWriteAttributes;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.LoaderHelper;
-import com.gemstone.gemfire.cache.MembershipAttributes;
-import com.gemstone.gemfire.cache.MirrorType;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.SubscriptionAttributes;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheCallback;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.CustomExpiry;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.DiskWriteAttributes;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.LoaderHelper;
+import org.apache.geode.cache.MembershipAttributes;
+import org.apache.geode.cache.MirrorType;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.SubscriptionAttributes;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.cache.EvictionAttributesImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides an implementation of RegionAttributes that can be used from a VM
@@ -580,14 +580,14 @@ public class RemoteRegionAttributes implements RegionAttributes,
     }
     
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.cache.CustomExpiry#getExpiry(com.gemstone.gemfire.cache.Region.Entry)
+     * @see org.apache.geode.cache.CustomExpiry#getExpiry(org.apache.geode.cache.Region.Entry)
      */
     public ExpirationAttributes getExpiry(Entry entry) {
       return null;
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.cache.Declarable#init(java.util.Properties)
+     * @see org.apache.geode.cache.Declarable#init(java.util.Properties)
      */
     public void init(Properties props) {
     }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionSnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionSnapshot.java
index 6e2b43c..57c34c9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteRegionSnapshot.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.admin.*;
 
 import java.util.*;
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStat.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStat.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStat.java
index 6127e45..7bf6f32 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStat.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStat.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.statistics.StatisticDescriptorImpl;
+import org.apache.geode.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.statistics.StatisticDescriptorImpl;
 //import java.util.*;
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStatResource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStatResource.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStatResource.java
index edbc954..b2cf110 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStatResource.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteStatResource.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.*;
+import org.apache.geode.internal.admin.*;
 import java.io.*;
 
 public class RemoteStatResource implements StatResource, DataSerializable {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteTransportConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteTransportConfig.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteTransportConfig.java
index d846fa1..e2bb077 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteTransportConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoteTransportConfig.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.admin.SSLConfig;
-import com.gemstone.gemfire.internal.admin.TransportConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.admin.SSLConfig;
+import org.apache.geode.internal.admin.TransportConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Tranport config for RemoteGfManagerAgent.
@@ -254,7 +254,7 @@ public class RemoteTransportConfig implements TransportConfig {
   /**
    * Returns a <code>Properties</code> based on this config that is
    * appropriate to use with {@link
-   * com.gemstone.gemfire.distributed.DistributedSystem#connect}.
+   * org.apache.geode.distributed.DistributedSystem#connect}.
    *
    * @since GemFire 4.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerRequest.java
index 35bae00..7fbbbc7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerRequest.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerResponse.java
index 5b4a07a..f410d72 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RemoveHealthListenerResponse.java
@@ -16,15 +16,15 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * The response to adding a health listener.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusRequest.java
index 8522f59..ca14362 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusRequest.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusResponse.java
index a126813..1cd670f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ResetHealthStatusResponse.java
@@ -16,15 +16,15 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * The response to reseting the health status.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDRequest.java
index 88fd7ce..3829a3e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDRequest.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.CancelException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
 
 /**
  * An instruction to all members that they should forget 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDResponse.java
index ed6ae27..93c4e20 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RevokePersistentIDResponse.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionRequest.java
index 738dbaf..faf313d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionResponse.java
index bc1dbb7..07bd8cf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/RootRegionResponse.java
@@ -16,18 +16,18 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -37,7 +37,7 @@ import java.util.Collection;
 import java.util.Iterator;
 import java.util.List;
 
-//import com.gemstone.gemfire.internal.*;
+//import org.apache.geode.internal.*;
 
 /**
  * Responds to {@link RootRegionResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllGatewayHubsRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllGatewayHubsRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllGatewayHubsRequest.java
index 23fc3a2..98c148c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllGatewayHubsRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllGatewayHubsRequest.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyMessage;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllRequest.java
index 1b80844..4800271 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllRequest.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.tcp.ConnectionTable;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -245,7 +245,7 @@ public class ShutdownAllRequest extends AdminRequest {
      * If response arrives, we will save into results and keep wait for member's 
      * departure. If the member is departed before sent response, no wait
      * for its response
-     * @see com.gemstone.gemfire.distributed.internal.ReplyProcessor21#process(com.gemstone.gemfire.distributed.internal.DistributionMessage)
+     * @see org.apache.geode.distributed.internal.ReplyProcessor21#process(org.apache.geode.distributed.internal.DistributionMessage)
      */
     @Override
     public void process(DistributionMessage msg) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllResponse.java
index 2111b7f..60e3c7f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ShutdownAllResponse.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SnapshotResultMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SnapshotResultMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SnapshotResultMessage.java
index a19447f..262eaf7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SnapshotResultMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SnapshotResultMessage.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.cache.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatAlertsManagerAssignMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatAlertsManagerAssignMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatAlertsManagerAssignMessage.java
index 6d13d52..567b7b9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatAlertsManagerAssignMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatAlertsManagerAssignMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
-import com.gemstone.gemfire.internal.admin.StatAlertsManager;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.StatAlertsManager;
 
 /**
  * This class represents a request object to set an alert manager for the newly

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatListenerMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatListenerMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatListenerMessage.java
index acd980d..f531126 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatListenerMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StatListenerMessage.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgRequest.java
index 00bc240..26b8292 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgRequest.java
@@ -16,19 +16,19 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 //import java.util.*;
 
 /**
  * A message that is sent to a particular distribution manager to
- * modify its current {@link com.gemstone.gemfire.internal.Config}.
+ * modify its current {@link org.apache.geode.internal.Config}.
  */
 public final class StoreSysCfgRequest extends AdminRequest {
   // instance variables

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgResponse.java
index 83d94ba..d6bc85d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/StoreSysCfgResponse.java
@@ -16,17 +16,17 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.*;
 
 import java.io.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent to a particular distribution manager to
- * modify its current {@link com.gemstone.gemfire.internal.Config}.
+ * modify its current {@link org.apache.geode.internal.Config}.
  */
 public final class StoreSysCfgResponse extends AdminResponse {
   // instance variables

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionRequest.java
index 860f162..3a4906e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionResponse.java
index 7646fd8..777f63f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/SubRegionResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link SubRegionResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogRequest.java
index e53e0f8..b6b195a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogResponse.java
index 6a210ca..c8043d9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/TailLogResponse.java
@@ -16,23 +16,23 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-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.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogWriterAppender;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
 
-//import com.gemstone.gemfire.distributed.DistributedSystem;
+//import org.apache.geode.distributed.DistributedSystem;
 //import java.util.*;
 
 public final class TailLogResponse extends AdminResponse {



[18/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation.java
index 03ceab1..54d78bc 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * Represents the {@link ServerLocation} of a {@link BucketRegion}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation66.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation66.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation66.java
index b2c79e1..a610344 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation66.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketServerLocation66.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * Represents the {@link ServerLocation} of a {@link BucketRegion}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BytesAndBitsForCompactor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BytesAndBitsForCompactor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BytesAndBitsForCompactor.java
index e4048a9..f9f6ff2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BytesAndBitsForCompactor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BytesAndBitsForCompactor.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  * Used to fetch a record's raw bytes and user bits.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheClientStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheClientStatus.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheClientStatus.java
index 44e17f1..c73f1f0 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheClientStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheClientStatus.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 import java.io.Serializable;
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheConfig.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheConfig.java
index 4035645..60034ff 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheConfig.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.List;
 
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheServerCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxSerializer;
-import com.gemstone.gemfire.pdx.ReflectionBasedAutoSerializer;
-import com.gemstone.gemfire.pdx.internal.AutoSerializableManager;
+import org.apache.geode.internal.cache.xmlcache.CacheServerCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxSerializer;
+import org.apache.geode.pdx.ReflectionBasedAutoSerializer;
+import org.apache.geode.pdx.internal.AutoSerializableManager;
 
 /**
  * This is helper class used by CacheFactory to pass the cache configuration

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisee.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisee.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisee.java
index 3163c32..0975421 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisee.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisee.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
 
 /**
  * Distributed cache object (typically a <code>Region</code>) which uses

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisor.java
index fff9bab..6370aed 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheDistributionAdvisor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -31,27 +31,27 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.InterestPolicy;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.SubscriptionAttributes;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.partitioned.PRLocallyDestroyedException;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.InterestPolicy;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.SubscriptionAttributes;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DSCODE;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.partitioned.PRLocallyDestroyedException;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Adds bookkeeping info and cache-specific behavior to DistributionAdvisor.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheLifecycleListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheLifecycleListener.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheLifecycleListener.java
index e21f3bc..7838cb1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheLifecycleListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheLifecycleListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Defines callbacks that are invoked when a <code>GemFireCache</code> is 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserver.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserver.java
index ae3a40b..3e76fef 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserver.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.nio.ByteBuffer;
 
-import com.gemstone.gemfire.cache.RegionEvent;
+import org.apache.geode.cache.RegionEvent;
 
 /**
  * This interface is used by testing/debugging code to be notified of query
  * events. See the documentation for class CacheObserverHolder for details. Also
  * the callback is issed only if the boolean ISSUE_CALLBACKS_TO_CACHE_OBSERVER
- * present in com.gemstone.gemfire.internal.cache.LocalRegion is made true
+ * present in org.apache.geode.internal.cache.LocalRegion is made true
  * 
  */
 public interface CacheObserver

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverAdapter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverAdapter.java
index e6ac989..4ac8359 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverAdapter.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.nio.ByteBuffer;
 
-import com.gemstone.gemfire.cache.RegionEvent;
+import org.apache.geode.cache.RegionEvent;
 
 /**
  * This class provides 'do-nothing' implementations of all of the methods of
  * interface CacheObserver. See the documentation for class CacheObserverHolder
  * for details. Also the callback is issed only if the boolean
  * ISSUE_CALLBACKS_TO_CACHE_OBSERVER present in
- * com.gemstone.gemfire.internal.cache.LocalRegion is made true
+ * org.apache.geode.internal.cache.LocalRegion is made true
  * 
  */
 public class CacheObserverAdapter implements CacheObserver {
@@ -71,7 +71,7 @@ public class CacheObserverAdapter implements CacheObserver {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.cache.CacheObserver#afterConflation(java.nio.ByteBuffer,
+   * @see org.apache.geode.internal.cache.CacheObserver#afterConflation(java.nio.ByteBuffer,
    *      java.nio.ByteBuffer)
    */
   public void afterConflation(ByteBuffer origBB, ByteBuffer conflatedBB)
@@ -80,7 +80,7 @@ public class CacheObserverAdapter implements CacheObserver {
   }
   /*
    *  (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.CacheObserver#afterSettingOplogOffSet()
+   * @see org.apache.geode.internal.cache.CacheObserver#afterSettingOplogOffSet()
    */
   public void afterSettingOplogOffSet(long offset) {
     // TODO Auto-generated method stub
@@ -99,7 +99,7 @@ public class CacheObserverAdapter implements CacheObserver {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.CacheObserver#beforeStoppingCompacter()
+   * @see org.apache.geode.internal.cache.CacheObserver#beforeStoppingCompacter()
    */
   public void beforeStoppingCompactor()
   {
@@ -125,7 +125,7 @@ public class CacheObserverAdapter implements CacheObserver {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.CacheObserver#afterSwitchingWriteAndFlushMaps()
+   * @see org.apache.geode.internal.cache.CacheObserver#afterSwitchingWriteAndFlushMaps()
    */
   public void afterSwitchingWriteAndFlushMaps()
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverHolder.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverHolder.java
index 8bc77f8..4c0fc04 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheObserverHolder.java
@@ -19,7 +19,7 @@
  *
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * This class is intended to hold a single 'observer' which will receive
@@ -35,7 +35,7 @@ package com.gemstone.gemfire.internal.cache;
  * of interest ... }
  * 
  * CacheObserver old = CacheObserverHolder.setInstance(new MyCacheObserver());
- * com.gemstone.gemfire.internal.cache.LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER=true;
+ * org.apache.geode.internal.cache.LocalRegion.ISSUE_CALLBACKS_TO_CACHE_OBSERVER=true;
  * 
  * try { Call region methods here } finally { // reset to the original
  * CacheObserver. CacheObserverHolder.setInstance(old); }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CachePerfStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CachePerfStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CachePerfStats.java
index 7fa2183..9bbd2a6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CachePerfStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CachePerfStats.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.distributed.internal.PoolStatHelper;
-import com.gemstone.gemfire.distributed.internal.QueueStatHelper;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.distributed.internal.PoolStatHelper;
+import org.apache.geode.distributed.internal.QueueStatHelper;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * CachePerfStats tracks statistics about GemFire cache performance.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerAdvisor.java
index 01e8210..8becf16 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerAdvisor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,12 +23,12 @@ import java.io.IOException;
 import java.util.Arrays;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerImpl.java
index 37c05eb..aa0a60c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerImpl.java
@@ -14,36 +14,36 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InvalidValueException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.cache.server.internal.LoadMonitor;
-import com.gemstone.gemfire.cache.wan.GatewayTransportFilter;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.membership.MemberAttributes;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.admin.ClientHealthMonitoringRegion;
-import com.gemstone.gemfire.internal.cache.CacheServerAdvisor.CacheServerProfile;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-import com.gemstone.gemfire.internal.cache.tier.Acceptor;
-import com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.management.membership.ClientMembership;
-import com.gemstone.gemfire.management.membership.ClientMembershipListener;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InvalidValueException;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.server.ClientSubscriptionConfig;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.cache.server.internal.LoadMonitor;
+import org.apache.geode.cache.wan.GatewayTransportFilter;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.membership.MemberAttributes;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.admin.ClientHealthMonitoringRegion;
+import org.apache.geode.internal.cache.CacheServerAdvisor.CacheServerProfile;
+import org.apache.geode.internal.cache.ha.HARegionQueue;
+import org.apache.geode.internal.cache.tier.Acceptor;
+import org.apache.geode.internal.cache.tier.sockets.AcceptorImpl;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.management.membership.ClientMembership;
+import org.apache.geode.management.membership.ClientMembershipListener;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerLauncher.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerLauncher.java
index fcb0876..2a35514 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerLauncher.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServerLauncher.java
@@ -15,36 +15,36 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.ConfigurationProperties;
-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.InternalDistributedSystem;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.PureJavaMode;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerHelper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.process.StartupStatus;
-import com.gemstone.gemfire.internal.process.StartupStatusListener;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.internal.util.JavaCommandBuilder;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.ConfigurationProperties;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.PureJavaMode;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerHelper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.process.StartupStatus;
+import org.apache.geode.internal.process.StartupStatusListener;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.internal.util.JavaCommandBuilder;
 
 import java.io.*;
 import java.net.URL;
 import java.util.*;
 import java.util.concurrent.TimeUnit;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOG_FILE;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.SERVER_BIND_ADDRESS;
+import static org.apache.geode.distributed.ConfigurationProperties.LOG_FILE;
+import static org.apache.geode.distributed.ConfigurationProperties.SERVER_BIND_ADDRESS;
 
 /**
  * Launcher program to start a cache server.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheService.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheService.java
index b1d3b62..22465ee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheService.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheService.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.management.internal.beans.CacheServiceMBeanBase;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.management.internal.beans.CacheServiceMBeanBase;
 
 /**
  * Interface for a service that is linked to a cache.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServiceProfile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServiceProfile.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServiceProfile.java
index d25e92a..043ab60 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServiceProfile.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheServiceProfile.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
  * CacheServiceProfiles track additions to a {@link Region} made by a {@link CacheService}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CacheStatisticsImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheStatisticsImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheStatisticsImpl.java
index 9fd56c7..26104ef 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CacheStatisticsImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CacheStatisticsImpl.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-//import com.gemstone.gemfire.InternalGemFireException;
-//import com.gemstone.gemfire.internal.util.Callable;
-//import com.gemstone.gemfire.util.concurrent.locks.Lock;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+//import org.apache.geode.InternalGemFireException;
+//import org.apache.geode.internal.util.Callable;
+//import org.apache.geode.util.concurrent.locks.Lock;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializable.java
index 472b9ff..8833c44 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializable.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.util.BlobHelper;
 
 /**
  * Provides protocol for getting the deserialized value from a potentially

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializableFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializableFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializableFactory.java
index ae60056..ee749b7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializableFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CachedDeserializableFactory.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.NullDataOutputStream;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.DSCODE;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.NullDataOutputStream;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
 
 import java.io.IOException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClientRegionEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientRegionEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientRegionEventImpl.java
index 15d02cd..f61d2a6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientRegionEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientRegionEventImpl.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
-//import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+//import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 /**
  * Class <code>ClientRegionEventImpl</code> is a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserver.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserver.java
index 92578a0..5101378 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserver.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * This interface is used by testing/debugging code to be notified of different

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverAdapter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverAdapter.java
index 6069297..0fe6a23 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverAdapter.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * This class provides 'do-nothing' implementations of all of the methods of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverHolder.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverHolder.java
index ec81a2f..f59a3f7 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientServerObserverHolder.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.Support;
 
 /**
  * This class is intended to hold a single 'observer' which will receive

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClientSubscriptionConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientSubscriptionConfigImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientSubscriptionConfigImpl.java
index a4a8882..fe49e54 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClientSubscriptionConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClientSubscriptionConfigImpl.java
@@ -17,10 +17,10 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.server.ClientSubscriptionConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 /**
  * 
  * Configuration parameters for client subscription

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CloseCacheMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CloseCacheMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CloseCacheMessage.java
index 5067d92..cd7ae17 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CloseCacheMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CloseCacheMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,12 +23,12 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.internal.logging.LogService;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ClusterConfigurationLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ClusterConfigurationLoader.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ClusterConfigurationLoader.java
index e362389..793f794 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ClusterConfigurationLoader.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ClusterConfigurationLoader.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.UnmodifiableException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.SharedConfiguration;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpClient;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.JarClassLoader;
-import com.gemstone.gemfire.internal.JarDeployer;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.process.ClusterConfigurationNotAvailableException;
-import com.gemstone.gemfire.management.internal.configuration.domain.Configuration;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationRequest;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationResponse;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.UnmodifiableException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.SharedConfiguration;
+import org.apache.geode.distributed.internal.tcpserver.TcpClient;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.JarClassLoader;
+import org.apache.geode.internal.JarDeployer;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.process.ClusterConfigurationNotAvailableException;
+import org.apache.geode.management.internal.configuration.domain.Configuration;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationRequest;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationResponse;
 import org.apache.logging.log4j.Logger;
 
 import java.io.ByteArrayInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationHelper.java
index aec8ef8..12ce85a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationHelper.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.execute.InternalRegionFunctionContext;
-import com.gemstone.gemfire.internal.cache.partitioned.PRLocallyDestroyedException;
-import com.gemstone.gemfire.internal.cache.persistence.PRPersistentConfig;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.execute.InternalRegionFunctionContext;
+import org.apache.geode.internal.cache.partitioned.PRLocallyDestroyedException;
+import org.apache.geode.internal.cache.persistence.PRPersistentConfig;
+import org.apache.geode.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 import org.apache.logging.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationLogger.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationLogger.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationLogger.java
index fab8eca..0a37547 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationLogger.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ColocationLogger.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -22,12 +22,12 @@ import java.util.Map;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Provides logging when regions are missing from a colocation hierarchy. This logger runs in

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CommitReplyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CommitReplyException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CommitReplyException.java
index bf3e341..d25b146 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CommitReplyException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CommitReplyException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyException;
 import java.util.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CompactableOplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CompactableOplog.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CompactableOplog.java
index 8691ec9..7780204 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CompactableOplog.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CompactableOplog.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.OplogCompactor;
-import com.gemstone.gemfire.internal.cache.persistence.BytesAndBits;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.DiskStoreImpl.OplogCompactor;
+import org.apache.geode.internal.cache.persistence.BytesAndBits;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
 /**
  * Contract that must be implemented by oplogs so that
  * they can be compacted.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/Conflatable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/Conflatable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/Conflatable.java
index cb5cb0d..26a4bc6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/Conflatable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/Conflatable.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ControllerAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ControllerAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ControllerAdvisor.java
index fb826f4..87c956e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ControllerAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ControllerAdvisor.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.List;
 
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ServerLocator;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ServerLocator;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CountingDataInputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CountingDataInputStream.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CountingDataInputStream.java
index ce0273d..8468e4e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CountingDataInputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CountingDataInputStream.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CreateRegionProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CreateRegionProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CreateRegionProcessor.java
index bc44c1c..7517f9b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CreateRegionProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CreateRegionProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,40 +27,40 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.InitialImageAdvice;
-import com.gemstone.gemfire.internal.cache.partitioned.PRLocallyDestroyedException;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.InitialImageAdvice;
+import org.apache.geode.internal.cache.partitioned.PRLocallyDestroyedException;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * This message processor handles creation and initial exchange of
- * com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.Profiles. It 
+ * org.apache.geode.internal.cache.CacheDistributionAdvisor.Profiles. It 
  * represents creation of
  * a {@link CacheDistributionAdvisee}. Name remains CreateRegion to avoid
  * merge conflicts.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/CustomEntryExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/CustomEntryExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/CustomEntryExpiryTask.java
index 2c380f2..1b52125 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/CustomEntryExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/CustomEntryExpiryTask.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.ExpirationAttributes;
+import org.apache.geode.cache.ExpirationAttributes;
 
 /**
  * Remembers the expiration attributes returned from

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DataLocationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DataLocationException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DataLocationException.java
index fc98762..1332668 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DataLocationException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DataLocationException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * This exception is meant to represent the class of exceptions that occur

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyOperation.java
index 5bfb3cc..90e9d2e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,18 +23,18 @@ import java.io.IOException;
 import java.util.Collections;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.ConflationKey;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.ConflationKey;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * Handles distribution messaging for destroying an entry in a region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyPartitionedRegionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyPartitionedRegionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyPartitionedRegionMessage.java
index 4539526..67e4df5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyPartitionedRegionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyPartitionedRegionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,35 +24,35 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is sent for two purposes <br>
  * 1) To destroy the
- * {@link com.gemstone.gemfire.internal.cache.PartitionedRegion} for all members
+ * {@link org.apache.geode.internal.cache.PartitionedRegion} for all members
  * specified (typically sent to all members that have the
  * <code>PartitionedRegion</code> defined.) <br>
- * 2) To inform the other nodes that {@link com.gemstone.gemfire.internal.cache.PartitionedRegion} is closed/locally destroyed or cache is closed on a node<br>
+ * 2) To inform the other nodes that {@link org.apache.geode.internal.cache.PartitionedRegion} is closed/locally destroyed or cache is closed on a node<br>
  * This results in updating of the RegionAdvisor of the remote nodes.
  * 
  * Sending this message should flush all previous
- * {@link com.gemstone.gemfire.cache.Region} operations, which means this
+ * {@link org.apache.geode.cache.Region} operations, which means this
  * operation should not over-ride
- * {@link com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage#getProcessorId()}.  It is critical 
+ * {@link org.apache.geode.internal.cache.partitioned.PartitionMessage#getProcessorId()}.  It is critical 
  * guarantee delivery of events sent prior to this message.
 
  * A standard {@link ReplyMessage} is used to send the reply, however any exception that it carries

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyRegionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyRegionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyRegionOperation.java
index 2cb83ea..ee02075 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyRegionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyRegionOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,34 +23,34 @@ import java.io.IOException;
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.Set;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.distributed.internal.*;
 import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.partitioned.PRLocallyDestroyedException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.partitioned.PRLocallyDestroyedException;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyedEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyedEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyedEntry.java
index c5533a1..3a971ce 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyedEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DestroyedEntry.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
 
 /**
  * Represents a destroyed entry that can be returned from an <code>Iterator</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DirectReplyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DirectReplyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DirectReplyMessage.java
index a5e6d85..25982da 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DirectReplyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DirectReplyMessage.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionMessage;
 
 /**
  * A message that can reply directly to the sender
@@ -35,14 +35,14 @@ public interface DirectReplyMessage {
   /**
    * Indicates whether the message could send an acknowledgement
    * back on the connection the request was sent on.  This flag 
-   * only takes effect when {@link com.gemstone.gemfire.distributed.DistributedSystem#setThreadsSocketPolicy(boolean)} 
+   * only takes effect when {@link org.apache.geode.distributed.DistributedSystem#setThreadsSocketPolicy(boolean)} 
    * is set to <code>false</code>
    * If this flag is set to true, the process method <b> must </b> reply
-   * by calling {@link DistributionMessage#getReplySender(com.gemstone.gemfire.distributed.internal.DM)} and using
+   * by calling {@link DistributionMessage#getReplySender(org.apache.geode.distributed.internal.DM)} and using
    * the result to send the reply. the ReplySender determines whether to reply
    * directly or through the shared channel.
    * @return true if a direct acknowledgement is allowed
-   * @see com.gemstone.gemfire.distributed.internal.direct.DirectChannel
+   * @see org.apache.geode.distributed.internal.direct.DirectChannel
    */
   boolean supportsDirectAck();
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DirectoryHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DirectoryHolder.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DirectoryHolder.java
index d3ad07e..0239123 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DirectoryHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DirectoryHolder.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.File;
 import java.util.concurrent.atomic.AtomicLong;
 
-import com.gemstone.gemfire.StatisticsFactory;
+import org.apache.geode.StatisticsFactory;
 
 /**
  * A holder for a disk Directory. Used for maintaining the available space and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskDirectoryStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskDirectoryStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskDirectoryStats.java
index a0d7022..2dfdec1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskDirectoryStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskDirectoryStats.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.NanoTimer;
-//import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+//import org.apache.geode.internal.NanoTimer;
+//import org.apache.geode.cache.Region;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * GemFire statistics about Disk Directories

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskEntry.java
index 144ffe4..20e11ce 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskEntry.java
@@ -14,40 +14,40 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.nio.ByteBuffer;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.AsyncDiskEntry;
-import com.gemstone.gemfire.internal.cache.Token.Tombstone;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.persistence.BytesAndBits;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.AddressableMemoryManager;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.ReferenceCountHelper;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.DiskStoreImpl.AsyncDiskEntry;
+import org.apache.geode.internal.cache.Token.Tombstone;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.persistence.BytesAndBits;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.AddressableMemoryManager;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.offheap.ReferenceCountHelper;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.BlobHelper;
 
 /**
  * Represents an entry in an {@link RegionMap} whose value may be

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskId.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskId.java
index 3da3879..a22c522 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskId.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskId.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This id stores seven pieces of information:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskInitFile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskInitFile.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskInitFile.java
index 0d8ff05..83fc7c5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskInitFile.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskInitFile.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import it.unimi.dsi.fastutil.ints.Int2ObjectMap;
 import it.unimi.dsi.fastutil.ints.Int2ObjectOpenHashMap;
@@ -51,37 +51,37 @@ import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.FileUtil;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.InternalInstantiator.InstantiatorAttributesHolder;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.persistence.CanonicalIdHolder;
-import com.gemstone.gemfire.internal.cache.persistence.DiskExceptionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.DiskInitFileInterpreter;
-import com.gemstone.gemfire.internal.cache.persistence.DiskInitFileParser;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.persistence.PRPersistentConfig;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.cache.versions.DiskRegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionHolder;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.FileUtil;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.InternalInstantiator;
+import org.apache.geode.internal.InternalInstantiator.InstantiatorAttributesHolder;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.persistence.CanonicalIdHolder;
+import org.apache.geode.internal.cache.persistence.DiskExceptionHandler;
+import org.apache.geode.internal.cache.persistence.DiskInitFileInterpreter;
+import org.apache.geode.internal.cache.persistence.DiskInitFileParser;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.persistence.PRPersistentConfig;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.cache.versions.DiskRegionVersionVector;
+import org.apache.geode.internal.cache.versions.RegionVersionHolder;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Does all the IF file work for a DiskStoreImpl.



[19/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/UpdateAlertDefinitionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/UpdateAlertDefinitionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/UpdateAlertDefinitionMessage.java
index cfd18b6..38eeead 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/UpdateAlertDefinitionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/UpdateAlertDefinitionMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
-import com.gemstone.gemfire.internal.admin.StatAlertsManager;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.StatAlertsManager;
 
 /**
  * distribution message to register alert's definition

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoRequest.java
index 6596053..cf32ee7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoResponse.java
index 754dec0..ad3e4b6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionInfoResponse.java
@@ -16,15 +16,15 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.internal.*;
 import java.io.*;
 //import java.net.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent in response to a {@link VersionInfoRequest}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionMismatchAlert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionMismatchAlert.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionMismatchAlert.java
index b6985ee..e79eea2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionMismatchAlert.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/VersionMismatchAlert.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.*;
 import java.util.*;
 
 public class VersionMismatchAlert implements Alert {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/package.html b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/package.html
index a47f53d..e8f32f3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/package.html
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/package.html
@@ -18,7 +18,7 @@ limitations under the License.
 <BODY>
 
 <P>Provides an implementation of the
-<a href="{@docRoot}/com/gemstone/gemfire/internal/admin/package-summary.html#package_description">internal admin API</a> that uses
+<a href="{@docRoot}/org/apache/geode/internal/admin/package-summary.html#package_description">internal admin API</a> that uses
 GemFire's distribution mechanism to obtain information about members
 of a distributed system.  The below diagram describes the
 relationships between the various classes in this package.</P>
@@ -34,7 +34,7 @@ relationships between the various classes in this package.</P>
 <H2>Statistics</H2>
 
 <code>StatListener</code>s are assigned a {@link
-com.gemstone.gemfire.internal.statistics.GemFireStatSampler#addListener} unique
+org.apache.geode.internal.statistics.GemFireStatSampler#addListener} unique
 id} in the remote VM.</code>
 
 </BODY>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/BaseDecoratorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/BaseDecoratorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/BaseDecoratorImpl.java
index e74762f..02bd26e 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/BaseDecoratorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/BaseDecoratorImpl.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Base class for all the decorators

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/DummyStatisticInfoImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/DummyStatisticInfoImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/DummyStatisticInfoImpl.java
index 6e4d5f3..8540eec 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/DummyStatisticInfoImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/DummyStatisticInfoImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.internal.admin.StatAlertsManager;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.internal.admin.StatAlertsManager;
 
 /**
  * Implementation {@link StatisticInfo} This does not contains associated

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionDecoratorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionDecoratorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionDecoratorImpl.java
index 41d837a..f9e9a38 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionDecoratorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionDecoratorImpl.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Implementation of {@link StatAlertDefinition}, which defines function

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionHelper.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionHelper.java
index 759f7fb..1b047a8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/FunctionHelper.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
-import com.gemstone.gemfire.SystemFailure;
+import org.apache.geode.SystemFailure;
 
 import java.util.Arrays;
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/GaugeThresholdDecoratorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/GaugeThresholdDecoratorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/GaugeThresholdDecoratorImpl.java
index c33db67..6ab7cb4 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/GaugeThresholdDecoratorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/GaugeThresholdDecoratorImpl.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Implementation of {@link StatAlertDefinition}, represents threshold as data

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/MultiAttrDefinitionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/MultiAttrDefinitionImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/MultiAttrDefinitionImpl.java
index f8f9740..84e2a6b 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/MultiAttrDefinitionImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/MultiAttrDefinitionImpl.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
 
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Implementation of {@link StatAlertDefinition} This provides the definition

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/NumberThresholdDecoratorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/NumberThresholdDecoratorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/NumberThresholdDecoratorImpl.java
index 67db490..8096abe 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/NumberThresholdDecoratorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/NumberThresholdDecoratorImpl.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Implementation of {@link StatAlertDefinition}, represents threshold as

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/SingleAttrDefinitionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/SingleAttrDefinitionImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/SingleAttrDefinitionImpl.java
index e79b944..a01d398 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/SingleAttrDefinitionImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/SingleAttrDefinitionImpl.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.internal.admin.StatAlert;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.internal.admin.StatAlert;
+import org.apache.geode.internal.admin.StatAlertDefinition;
 
 /**
  * Implementation of {@link StatAlertDefinition} This provides the definition
@@ -132,7 +132,7 @@ public final class SingleAttrDefinitionImpl implements StatAlertDefinition {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.admin.StatAlertDefinition#getStatisticInfo()
+   * @see org.apache.geode.internal.admin.StatAlertDefinition#getStatisticInfo()
    */
   public StatisticInfo[] getStatisticInfo() {
     return new StatisticInfo[] { statisticInfo };
@@ -141,7 +141,7 @@ public final class SingleAttrDefinitionImpl implements StatAlertDefinition {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.admin.StatAlertDefinition#setStatisticInfo(com.gemstone.gemfire.internal.admin.StatisticInfo[])
+   * @see org.apache.geode.internal.admin.StatAlertDefinition#setStatisticInfo(org.apache.geode.internal.admin.StatisticInfo[])
    */
   public void setStatisticInfo(StatisticInfo[] info) {
     if (info == null || info.length != 1)
@@ -165,7 +165,7 @@ public final class SingleAttrDefinitionImpl implements StatAlertDefinition {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.admin.StatAlertDefinition#evaluate(java.lang.Number[])
+   * @see org.apache.geode.internal.admin.StatAlertDefinition#evaluate(java.lang.Number[])
    */
   public boolean evaluate(Number[] params) {
     return evaluate() && params != null && params.length == 1;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfo.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfo.java
index d07e6c2..cfd2883 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfo.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsType;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsType;
 
 /**
  * Provides informations of the statistic

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfoImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfoImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfoImpl.java
index f66bbff..f2453e6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfoImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/statalerts/StatisticInfoImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.statalerts;
+package org.apache.geode.internal.admin.statalerts;
 
 import java.io.DataOutput;
 import java.io.DataInput;
@@ -22,11 +22,11 @@ import java.io.IOException;
 
 import org.apache.commons.lang.StringUtils;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.admin.Statistic;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.admin.Statistic;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractBucketRegionQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractBucketRegionQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractBucketRegionQueue.java
index 70fb12d..8fa8597 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractBucketRegionQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractBucketRegionQueue.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderStats;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.GatewaySenderStats;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractCacheServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractCacheServer.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractCacheServer.java
index 60e256d..07b1c8d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractCacheServer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractCacheServer.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.distributed.DistributedMember;
-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.internal.admin.ClientMembershipMessage;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.management.membership.ClientMembership;
-import com.gemstone.gemfire.management.membership.ClientMembershipEvent;
-import com.gemstone.gemfire.management.membership.ClientMembershipListener;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.server.ClientSubscriptionConfig;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.admin.ClientMembershipMessage;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.management.membership.ClientMembership;
+import org.apache.geode.management.membership.ClientMembershipEvent;
+import org.apache.geode.management.membership.ClientMembershipListener;
 
 import java.io.IOException;
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskLRURegionEntry.java
index a193014..d532d56 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskLRURegionEntry.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.lru.LRUEntry;
 
 /**
  * Abstract implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegion.java
index 231aa7a..562c002 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.PrintStream;
 import java.util.EnumSet;
@@ -26,24 +26,24 @@ import java.util.concurrent.atomic.AtomicLong;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.CopyOnWriteHashSet;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.cache.versions.DiskRegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionHolder;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.CopyOnWriteHashSet;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.cache.versions.DiskRegionVersionVector;
+import org.apache.geode.internal.cache.versions.RegionVersionHolder;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap;
 import joptsimple.internal.Strings;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegionEntry.java
index 41cd110..4440417 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractDiskRegionEntry.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.serial.SerialGatewaySenderQueue;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.serial.SerialGatewaySenderQueue;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionEntry.java
index 036b8a6..d22bfd3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionEntry.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.lru.LRUEntry;
 
 /**
  * Abstract implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionMap.java
index af9a389..95d2a3f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractLRURegionMap.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Iterator;
 import java.util.List;
@@ -23,29 +23,29 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-import com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController;
-import com.gemstone.gemfire.internal.cache.lru.LRUAlgorithm;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.cache.lru.MemLRUCapacityController;
-import com.gemstone.gemfire.internal.cache.lru.NewLIFOClockHand;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.size.ReflectionSingleObjectSizer;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.HeapEvictor;
+import org.apache.geode.internal.cache.lru.HeapLRUCapacityController;
+import org.apache.geode.internal.cache.lru.LRUAlgorithm;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.lru.MemLRUCapacityController;
+import org.apache.geode.internal.cache.lru.NewLIFOClockHand;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.size.ReflectionSingleObjectSizer;
 
 /**
  * Abstract implementation of {@link RegionMap} that adds LRU behaviour.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractOplogDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractOplogDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractOplogDiskRegionEntry.java
index d9b1008..fcd1400 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractOplogDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractOplogDiskRegionEntry.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * Abstract implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegion.java
index 2d44979..f47c236 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegion.java
@@ -15,35 +15,35 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueImpl;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.cache.extension.Extensible;
-import com.gemstone.gemfire.internal.cache.extension.ExtensionPoint;
-import com.gemstone.gemfire.internal.cache.extension.SimpleExtensionPoint;
-import com.gemstone.gemfire.internal.cache.lru.LRUAlgorithm;
-import com.gemstone.gemfire.internal.cache.snapshot.RegionSnapshotServiceImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.ArrayUtils;
-import com.gemstone.gemfire.pdx.internal.PeerTypeRegistration;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueImpl;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.snapshot.RegionSnapshotService;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.cache.extension.Extensible;
+import org.apache.geode.internal.cache.extension.ExtensionPoint;
+import org.apache.geode.internal.cache.extension.SimpleExtensionPoint;
+import org.apache.geode.internal.cache.lru.LRUAlgorithm;
+import org.apache.geode.internal.cache.snapshot.RegionSnapshotServiceImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.ArrayUtils;
+import org.apache.geode.pdx.internal.PeerTypeRegistration;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionEntry.java
index 5778a82..be82bd4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionEntry.java
@@ -15,53 +15,53 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.util.GatewayConflictHelper;
-import com.gemstone.gemfire.cache.util.GatewayConflictResolver;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.versions.*;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.*;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.internal.util.Versionable;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializable;
-import com.gemstone.gemfire.pdx.PdxSerializationException;
-import com.gemstone.gemfire.pdx.PdxSerializer;
-import com.gemstone.gemfire.pdx.internal.ConvertableToBytes;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.IndexMaintenanceException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.util.GatewayConflictHelper;
+import org.apache.geode.cache.util.GatewayConflictResolver;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.versions.*;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.*;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.internal.util.Versionable;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxSerializationException;
+import org.apache.geode.pdx.PdxSerializer;
+import org.apache.geode.pdx.internal.ConvertableToBytes;
+import org.apache.geode.pdx.internal.PdxInstanceImpl;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;
 import java.util.Arrays;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_FILL_IN_VALUE;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_PREPARE_VALUE_FOR_CACHE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_FILL_IN_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_PREPARE_VALUE_FOR_CACHE;
 
 /**
  * Abstract implementation class of RegionEntry interface.
@@ -1476,7 +1476,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
    * supporting concurrency versioning.  It also sets the entry's version
    * stamp to the tag's values.
    * 
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#generateVersionTag(com.gemstone.gemfire.distributed.DistributedMember, boolean)
+   * @see org.apache.geode.internal.cache.RegionEntry#generateVersionTag(org.apache.geode.distributed.DistributedMember, boolean)
    */
   public VersionTag generateVersionTag(VersionSource mbr, boolean withDelta, LocalRegion region, EntryEventImpl event) {
     VersionStamp stamp = this.getVersionStamp();
@@ -1590,7 +1590,7 @@ public abstract class AbstractRegionEntry implements RegionEntry,
    * @throws ConcurrentCacheModificationException if the event conflicts with
    * an event that has already been applied to the entry.
    * 
-   * @see com.gemstone.gemfire.internal.cache.RegionEntry#concurrencyCheck(com.gemstone.gemfire.cache.EntryEvent)
+   * @see org.apache.geode.internal.cache.RegionEntry#concurrencyCheck(org.apache.geode.cache.EntryEvent)
    */
   public void processVersionTag(EntryEvent cacheEvent) {
     processVersionTag(cacheEvent, true);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionMap.java
index 81e4d9f..738fef1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractRegionMap.java
@@ -15,44 +15,44 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.ha.HAContainerWrapper;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.region.entry.RegionEntryFactoryBuilder;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessageImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
-import com.gemstone.gemfire.internal.cache.versions.*;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.concurrent.MapCallbackAdapter;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.ReferenceCountHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.IndexMaintenanceException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.ha.HAContainerWrapper;
+import org.apache.geode.internal.cache.ha.HARegionQueue;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.region.entry.RegionEntryFactoryBuilder;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.HAEventWrapper;
+import org.apache.geode.internal.cache.versions.*;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.concurrent.MapCallbackAdapter;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.ReferenceCountHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.sequencelog.EntryLogger;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap;
 
 import org.apache.logging.log4j.Logger;
 
@@ -2246,7 +2246,7 @@ public abstract class AbstractRegionMap implements RegionMap {
 
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.RegionMap#updateEntryVersion(com.gemstone.gemfire.internal.cache.EntryEventImpl)
+   * @see org.apache.geode.internal.cache.RegionMap#updateEntryVersion(org.apache.geode.internal.cache.EntryEventImpl)
    */
   @Override
   public void updateEntryVersion(EntryEventImpl event) throws EntryNotFoundException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractUpdateOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractUpdateOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractUpdateOperation.java
index 5a6351e..0593f20 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractUpdateOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AbstractUpdateOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,26 +24,26 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.InvalidVersionException;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.DelayedAction;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.InvalidVersionException;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.DelayedAction;
 
 /**
  * Common code for both UpdateOperation and DistributedPutAllOperation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AcceptHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AcceptHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AcceptHelper.java
index 7675619..f90dd9a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AcceptHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AcceptHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/AddCacheServerProfileMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/AddCacheServerProfileMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/AddCacheServerProfileMessage.java
index 4609472..c6a732c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/AddCacheServerProfileMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/AddCacheServerProfileMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,12 +24,12 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * OperationMessage synchronously propagates a change in the profile to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BackupLock.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BackupLock.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BackupLock.java
index f304135..d03547f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BackupLock.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BackupLock.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.concurrent.locks.Condition;
 import java.util.concurrent.locks.ReentrantLock;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketAdvisor.java
index 078e595..54fa618 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketAdvisor.java
@@ -14,36 +14,36 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.client.internal.locator.SerializationHelper;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.LockNotHeldException;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DistributedMemberLock;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketProfileUpdateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DeposePrimaryBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DeposePrimaryBucketMessage.DeposePrimaryBucketResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.StopWatch;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.client.internal.locator.SerializationHelper;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.LockNotHeldException;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.locks.DistributedMemberLock;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.partitioned.Bucket;
+import org.apache.geode.internal.cache.partitioned.BucketProfileUpdateMessage;
+import org.apache.geode.internal.cache.partitioned.DeposePrimaryBucketMessage;
+import org.apache.geode.internal.cache.partitioned.DeposePrimaryBucketMessage.DeposePrimaryBucketResponse;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.StopWatch;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketDump.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketDump.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketDump.java
index 22bab88..7ccdcee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketDump.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketDump.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.HashMap;
 import java.util.Map;
 import java.util.Map.Entry;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * This class is used for getting the contents of buckets and then optionally

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketNotFoundException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketNotFoundException.java
index 2881e1f..d017304 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketNotFoundException.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * A version of ForceReattemptException that should be used when the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketPersistenceAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketPersistenceAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketPersistenceAdvisor.java
index 8c821ad..6683113 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketPersistenceAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketPersistenceAdvisor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -27,23 +27,23 @@ import java.util.concurrent.CountDownLatch;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.persistence.PartitionOfflineException;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.BucketLock;
-import com.gemstone.gemfire.internal.cache.partitioned.RedundancyAlreadyMetException;
-import com.gemstone.gemfire.internal.cache.persistence.PersistenceAdvisorImpl;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberView;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentStateListener.PersistentStateAdapter;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.TransformUtils;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.persistence.PartitionOfflineException;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.PartitionedRegion.BucketLock;
+import org.apache.geode.internal.cache.partitioned.RedundancyAlreadyMetException;
+import org.apache.geode.internal.cache.persistence.PersistenceAdvisorImpl;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberView;
+import org.apache.geode.internal.cache.persistence.PersistentStateListener.PersistentStateAdapter;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.TransformUtils;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegion.java
index 4e4c417..34beb9e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegion.java
@@ -14,51 +14,51 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.AtomicLongWithTerminalState;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor.BucketProfile;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
-import com.gemstone.gemfire.internal.cache.partitioned.DestroyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.InvalidateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.LockObject;
-import com.gemstone.gemfire.internal.cache.partitioned.PRTombstoneMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientTombstoneMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessage;
-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.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.concurrent.AtomicLong5;
-import com.gemstone.gemfire.internal.concurrent.Atomics;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.AtomicLongWithTerminalState;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.BucketAdvisor.BucketProfile;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.control.MemoryEvent;
+import org.apache.geode.internal.cache.partitioned.Bucket;
+import org.apache.geode.internal.cache.partitioned.DestroyMessage;
+import org.apache.geode.internal.cache.partitioned.InvalidateMessage;
+import org.apache.geode.internal.cache.partitioned.LockObject;
+import org.apache.geode.internal.cache.partitioned.PRTombstoneMessage;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.PutMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientTombstoneMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessage;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.concurrent.AtomicLong5;
+import org.apache.geode.internal.concurrent.Atomics;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataOutput;
@@ -75,7 +75,7 @@ import java.util.concurrent.locks.Lock;
  * It does not support transactions
  * 
  * Primary election for a BucketRegion can be found in the 
- * {@link com.gemstone.gemfire.internal.cache.BucketAdvisor} class
+ * {@link org.apache.geode.internal.cache.BucketAdvisor} class
  * 
  * @since GemFire 5.1
  *
@@ -1617,7 +1617,7 @@ implements Bucket
   
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#invokeDestroyCallbacks(com.gemstone.gemfire.internal.cache.EnumListenerEvent, com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean)
+   * @see org.apache.geode.internal.cache.LocalRegion#invokeDestroyCallbacks(org.apache.geode.internal.cache.EnumListenerEvent, org.apache.geode.internal.cache.EntryEventImpl, boolean)
    */
   @Override
   public void invokeDestroyCallbacks(
@@ -1644,7 +1644,7 @@ implements Bucket
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#invokeInvalidateCallbacks(com.gemstone.gemfire.internal.cache.EnumListenerEvent, com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean)
+   * @see org.apache.geode.internal.cache.LocalRegion#invokeInvalidateCallbacks(org.apache.geode.internal.cache.EnumListenerEvent, org.apache.geode.internal.cache.EntryEventImpl, boolean)
    */
   @Override
   public void invokeInvalidateCallbacks(
@@ -1671,7 +1671,7 @@ implements Bucket
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#invokePutCallbacks(com.gemstone.gemfire.internal.cache.EnumListenerEvent, com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean)
+   * @see org.apache.geode.internal.cache.LocalRegion#invokePutCallbacks(org.apache.geode.internal.cache.EnumListenerEvent, org.apache.geode.internal.cache.EntryEventImpl, boolean)
    */
   @Override
   public void invokePutCallbacks(
@@ -1776,12 +1776,12 @@ implements Bucket
         return;
       }
       Object instance = cd.getValue();
-      if (instance instanceof com.gemstone.gemfire.Delta
-          && ((com.gemstone.gemfire.Delta)instance).hasDelta()) {
+      if (instance instanceof org.apache.geode.Delta
+          && ((org.apache.geode.Delta)instance).hasDelta()) {
         try {
           HeapDataOutputStream hdos = new HeapDataOutputStream(Version.CURRENT);
           long start = DistributionStats.getStatTime();
-          ((com.gemstone.gemfire.Delta)instance).toDelta(hdos);
+          ((org.apache.geode.Delta)instance).toDelta(hdos);
           event.setDeltaBytes(hdos.toByteArray());
           this.partitionedRegion.getCachePerfStats().endDeltaPrepared(start);
         }
@@ -2017,7 +2017,7 @@ implements Bucket
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.partitioned.Bucket#getBucketOwners()
+   * @see org.apache.geode.internal.cache.partitioned.Bucket#getBucketOwners()
    * @since GemFire 5.9
    */
   public Set getBucketOwners() {
@@ -2064,7 +2064,7 @@ implements Bucket
       return 0;
     }
     if (!(value instanceof byte[]) && !(value instanceof CachedDeserializable)
-        && !(value instanceof com.gemstone.gemfire.Delta)
+        && !(value instanceof org.apache.geode.Delta)
         && !(value instanceof GatewaySenderEventImpl)) {
     // ezoerner:20090401 it's possible this value is a Delta
       throw new InternalGemFireError("DEBUG: calcMemSize: weird value (class " 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionEvictior.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionEvictior.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionEvictior.java
index fca7801..2e35c98 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionEvictior.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionEvictior.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.concurrent.Callable;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionQueue.java
index 92442d9..294b616 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/BucketRegionQueue.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -36,24 +36,24 @@ import java.util.concurrent.atomic.AtomicReference;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.persistence.query.mock.ByteComparator;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.parallel.BucketRegionQueueUnavailableException;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.concurrent.Atomics;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.persistence.query.mock.ByteComparator;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.parallel.BucketRegionQueueUnavailableException;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
+import org.apache.geode.internal.concurrent.Atomics;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * 



[37/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/control/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/control/package.html b/geode-core/src/main/java/org/apache/geode/cache/control/package.html
index 74c0aa0..4cc3920 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/control/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/control/package.html
@@ -17,7 +17,7 @@ limitations under the License.
 <html>
 <body>
 
-<p>Controls the resources used by the local GemFire <code>Cache</code>. The {@linkplain com.gemstone.gemfire.cache.control.ResourceManager} exposes options affecting how the resources are controlled. Additionally, <code>Cache</code> resources can also be rebalanced across the GemFire distributed system.</p>
+<p>Controls the resources used by the local GemFire <code>Cache</code>. The {@linkplain org.apache.geode.cache.control.ResourceManager} exposes options affecting how the resources are controlled. Additionally, <code>Cache</code> resources can also be rebalanced across the GemFire distributed system.</p>
 
 </body>
 </html>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/EmptyRegionFunctionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/EmptyRegionFunctionException.java b/geode-core/src/main/java/org/apache/geode/cache/execute/EmptyRegionFunctionException.java
index ddb49b3..bdafb89 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/EmptyRegionFunctionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/EmptyRegionFunctionException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Exception to indicate that Region is empty for data aware functions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/Execution.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/Execution.java b/geode-core/src/main/java/org/apache/geode/cache/execute/Execution.java
index 41b1097..50a312d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/Execution.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/Execution.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.LowMemoryException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.LowMemoryException;
 
 /**
  * Provides methods to build the context for the execution of a {@link Function}
@@ -49,7 +49,7 @@ public interface Execution {
    *           if filter passed is null.
    * @throws UnsupportedOperationException
    *           if not called after
-   *           {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)}
+   *           {@link FunctionService#onRegion(org.apache.geode.cache.Region)}
    * @since GemFire 6.0
    */
   public Execution withFilter(Set<?> filter);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/Function.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/Function.java b/geode-core/src/main/java/org/apache/geode/cache/execute/Function.java
index 79364a9..14b0f9a 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/Function.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/Function.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.lang.Identifiable;
+import org.apache.geode.cache.Region;
+import org.apache.geode.lang.Identifiable;
 
 /**
  * Defines the interface a user defined function implements.
@@ -84,15 +84,15 @@ public interface Function extends Identifiable<String> {
 
   /**
    * <p>Return true to indicate to GemFire the method
-   * requires optimization for writing the targeted {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)} and any
+   * requires optimization for writing the targeted {@link FunctionService#onRegion(org.apache.geode.cache.Region)} and any
    * associated {@linkplain Execution#withFilter(java.util.Set) routing objects}.</p>
    *
    * <p>Returning false will optimize for read behavior on the targeted
-   * {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)} and any
+   * {@link FunctionService#onRegion(org.apache.geode.cache.Region)} and any
    * associated {@linkplain Execution#withFilter(java.util.Set) routing objects}.</p>
    *
    * <p>This method is only consulted when Region passed to 
-   * FunctionService#onRegion(com.gemstone.gemfire.cache.Region) is a partitioned region
+   * FunctionService#onRegion(org.apache.geode.cache.Region) is a partitioned region
    * </p>
    *
    * @return false if the function is read only, otherwise returns true

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionAdapter.java
index 7ee262a..29b63f3 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionAdapter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 /**
  * Application developers can extend this class instead of implementing the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
index 844e4c8..fc85684 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 /**
  * Defines the execution context of a {@link Function}. It is required

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
index b6f017c..d0305a7 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.List;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.GemFireException;
+import org.apache.geode.internal.Assert;
 
 /**
  * Thrown to indicate an error or exceptional condition during the execution of 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionInvocationTargetException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionInvocationTargetException.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionInvocationTargetException.java
index 392db12..15343c6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionInvocationTargetException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionInvocationTargetException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
index 5536978..2eb715d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 import java.util.Map;
 import java.util.Properties;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.execute.internal.FunctionServiceManager;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.execute.internal.FunctionServiceManager;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides the entry point into execution of user defined {@linkplain Function}s.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/RegionFunctionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/RegionFunctionContext.java b/geode-core/src/main/java/org/apache/geode/cache/execute/RegionFunctionContext.java
index a5f90d9..149e7d6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/RegionFunctionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/RegionFunctionContext.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
 
 /**
  * Defines the execution context of a data dependent {@link Function}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
index 32b7545..5fc5628 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * <p>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
index ee02258..28952df 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.execute;
+package org.apache.geode.cache.execute;
 
 /**
  * Provides methods to send results back to the ResultCollector. A ResultSender
  * adds the ability for an execute method to send a single result back, or break
  * its result into multiple pieces and send each piece back to the calling
  * thread's {@link ResultCollector}. For each result sent using this method,
- * {@link ResultCollector#addResult(com.gemstone.gemfire.distributed.DistributedMember, Object)} is called,
+ * {@link ResultCollector#addResult(org.apache.geode.distributed.DistributedMember, Object)} is called,
  * making that result available to the calling thread immediately.
  * 
  * <p>
@@ -48,13 +48,13 @@ package com.gemstone.gemfire.cache.execute;
  * 
  * @since GemFire 6.0
  * 
- * @see ResultCollector#addResult(com.gemstone.gemfire.distributed.DistributedMember, Object)
+ * @see ResultCollector#addResult(org.apache.geode.distributed.DistributedMember, Object)
  * 
  */
 public interface ResultSender<T> {
   /**
    * Sends a result back to the FunctionService calling thread and invokes
-   * {@link ResultCollector#addResult(com.gemstone.gemfire.distributed.DistributedMember, Object)}.
+   * {@link ResultCollector#addResult(org.apache.geode.distributed.DistributedMember, Object)}.
    * 
    * @param oneResult
    */
@@ -62,7 +62,7 @@ public interface ResultSender<T> {
 
   /**
    * Sends a result back to the FunctionService calling thread and invokes
-   * {@link ResultCollector#addResult(com.gemstone.gemfire.distributed.DistributedMember, Object)} and then
+   * {@link ResultCollector#addResult(org.apache.geode.distributed.DistributedMember, Object)} and then
    * {@link ResultCollector#endResults()} if it is the last instance of the
    * Function to report results. The ResultCollector will keep waiting for
    * results until it receives last result. Therefore, it is very important to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java b/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
index 32756ea..f0688bc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
@@ -14,29 +14,29 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.execute.internal;
+package org.apache.geode.cache.execute.internal;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.ProxyRegion;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.InternalEntity;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.execute.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.ProxyRegion;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.InternalEntity;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.execute.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 import java.util.concurrent.ConcurrentHashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/execute/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/package.html b/geode-core/src/main/java/org/apache/geode/cache/execute/package.html
index f66eec4..ce3046e 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/package.html
@@ -17,11 +17,11 @@ limitations under the License.
 -->
 <HTML>
   <HEAD>
-    <TITLE>com.gemstone.gemfire.cache.execute package</TITLE>
+    <TITLE>org.apache.geode.cache.execute package</TITLE>
   </HEAD>
   <BODY>
   <p>
-  The <code>com.gemstone.gemfire.cache.execute</code> package provides APIs used
+  The <code>org.apache.geode.cache.execute</code> package provides APIs used
   for function execution on gemfire system members.
   </p>
   <p>
@@ -41,10 +41,10 @@ limitations under the License.
 	<li>The FunctionService class provides methods to execute functions on targeted GemFire 
 	 system members.</li>
 
-	<li>Functions are java classes that implement the {@link com.gemstone.gemfire.cache.execute.Function} interface. Functions
-	can be registered with the {@linkplain com.gemstone.gemfire.cache.execute.FunctionService Function Execution Service}.</li>
+	<li>Functions are java classes that implement the {@link org.apache.geode.cache.execute.Function} interface. Functions
+	can be registered with the {@linkplain org.apache.geode.cache.execute.FunctionService Function Execution Service}.</li>
 	
-	<li>The application obtains the execution object {@link com.gemstone.gemfire.cache.execute.Execution} and uses its methods to target 
+	<li>The application obtains the execution object {@link org.apache.geode.cache.execute.Execution} and uses its methods to target 
 	execution.</li>
 	
         <li>Calling the execute() method on the Execution object

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/CloseCQOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/CloseCQOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/CloseCQOperationContext.java
index 1924605..aa38d32 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/CloseCQOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/CloseCQOperationContext.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CLOSE_CQ} operation for the pre-operation
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CLOSE_CQ} operation for the pre-operation
  * case.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/DestroyOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/DestroyOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/DestroyOperationContext.java
index c00b1a7..2c37dc2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/DestroyOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/DestroyOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#DESTROY} region operation having the key
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#DESTROY} region operation having the key
  * object for both the pre-operation case and for post-operation updates.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteCQOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteCQOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteCQOperationContext.java
index a2b8ab2..a77dd32 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteCQOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteCQOperationContext.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteFunctionOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteFunctionOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteFunctionOperationContext.java
index dafc5c0..187612f 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteFunctionOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/ExecuteFunctionOperationContext.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.io.Serializable;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/GetDurableCQsOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/GetDurableCQsOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/GetDurableCQsOperationContext.java
index abec6b6..4f1dff2 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/GetDurableCQsOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/GetDurableCQsOperationContext.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#GET_DURABLE_CQS} operation for the pre-operation
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#GET_DURABLE_CQS} operation for the pre-operation
  * case.
  * 
  * @since GemFire 7.0

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/GetOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/GetOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/GetOperationContext.java
index f276d2c..291afbd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/GetOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/GetOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#GET} region operation having the key
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#GET} region operation having the key
  * object for the pre-operation case and both key, value objects for the
  * post-operation case.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/InterestOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/InterestOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/InterestOperationContext.java
index 2cdd13e..bb2a993 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/InterestOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/InterestOperationContext.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/InterestType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/InterestType.java b/geode-core/src/main/java/org/apache/geode/cache/operations/InterestType.java
index 906125d..e8ceb17 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/InterestType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/InterestType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 /**
  * Enumeration for various interest types supported by GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/InvalidateOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/InvalidateOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/InvalidateOperationContext.java
index dd8ce38..e024df3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/InvalidateOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/InvalidateOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#INVALIDATE} region operation having the key
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#INVALIDATE} region operation having the key
  * object for both the pre-operation case and for post-operation updates.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/KeyOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/KeyOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/KeyOperationContext.java
index 985af0b..e2b09a3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/KeyOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/KeyOperationContext.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
  * Encapsulates a region operation that requires only a key object for the
  * pre-operation case. The operations this class encapsulates are
- * {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#DESTROY} 
- * and {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}.
+ * {@link org.apache.geode.cache.operations.OperationContext.OperationCode#DESTROY} 
+ * and {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}.
  * 
  * @since GemFire 5.5
  */
@@ -68,11 +68,11 @@ public abstract class KeyOperationContext extends OperationContext {
    * object.
    * 
    * @return The <code>OperationCode</code> of this operation. This is one of
-   *         {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#DESTROY} 
-   *         or {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}
+   *         {@link org.apache.geode.cache.operations.OperationContext.OperationCode#DESTROY} 
+   *         or {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}
    *         for <code>KeyOperationContext</code>, and one of
-   *         {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#GET} or 
-   *         {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#PUT} for
+   *         {@link org.apache.geode.cache.operations.OperationContext.OperationCode#GET} or 
+   *         {@link org.apache.geode.cache.operations.OperationContext.OperationCode#PUT} for
    *         <code>KeyValueOperationContext</code>.
    */
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/KeySetOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/KeySetOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/KeySetOperationContext.java
index 0b8bccc..2eb14ff 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/KeySetOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/KeySetOperationContext.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.operations.OperationContext;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.operations.OperationContext;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#KEY_SET} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#KEY_SET} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/KeyValueOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/KeyValueOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/KeyValueOperationContext.java
index 415f842..e993409 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/KeyValueOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/KeyValueOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SerializationException;
+import org.apache.geode.internal.cache.EntryEventImpl;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/OperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/OperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/OperationContext.java
index 3a7d34c..b8d0e93 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/OperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/OperationContext.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import org.apache.geode.security.ResourcePermission;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/PutAllOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/PutAllOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/PutAllOperationContext.java
index d8acba9..122bdfa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/PutAllOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/PutAllOperationContext.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.operations.OperationContext;
-import com.gemstone.gemfire.cache.operations.internal.UpdateOnlyMap;
+import org.apache.geode.cache.operations.OperationContext;
+import org.apache.geode.cache.operations.internal.UpdateOnlyMap;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#PUTALL} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#PUTALL} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/PutOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/PutOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/PutOperationContext.java
index de24fd1..49af7ef 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/PutOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/PutOperationContext.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
- * Encapsulates an {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#PUT} region operation having both key
+ * Encapsulates an {@link org.apache.geode.cache.operations.OperationContext.OperationCode#PUT} region operation having both key
  * and value objects for for both the pre-operation case and for post-operation
  * updates.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/QueryOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/QueryOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/QueryOperationContext.java
index 9113f79..917cb08 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/QueryOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/QueryOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.operations.OperationContext;
+import org.apache.geode.cache.operations.OperationContext;
 
 /**
  * Encapsulates a cache query operation for both the pre-operation and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RegionClearOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionClearOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionClearOperationContext.java
index f3ac414..188df25 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionClearOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionClearOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CLEAR} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CLEAR} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RegionCreateOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionCreateOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionCreateOperationContext.java
index 4b92ae9..9965eef 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionCreateOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionCreateOperationContext.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CREATE} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CREATE} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RegionDestroyOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionDestroyOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionDestroyOperationContext.java
index b2d19c1..d5b7b9a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionDestroyOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionDestroyOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_DESTROY} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_DESTROY} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RegionOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionOperationContext.java
index c631a78..49c0338 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RegionOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RegionOperationContext.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
  * Encapsulates a region-level operation in both the pre-operation and
  * post-operation cases. The operations this class encapsulates are
- * {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CLEAR} 
- * and {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.
+ * {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CLEAR} 
+ * and {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.
  * 
  * @since GemFire 5.5
  */
@@ -50,8 +50,8 @@ public abstract class RegionOperationContext extends OperationContext {
    * object.
    * 
    * @return The <code>OperationCode</code> of this operation. This is one of
-   *         {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CLEAR} or
-   *         {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.
+   *         {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CLEAR} or
+   *         {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.
    */
   @Override
   public abstract OperationCode getOperationCode();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RegisterInterestOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RegisterInterestOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RegisterInterestOperationContext.java
index f5cda63..845ce5b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RegisterInterestOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RegisterInterestOperationContext.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
-import com.gemstone.gemfire.cache.InterestResultPolicy;
+import org.apache.geode.cache.InterestResultPolicy;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGISTER_INTEREST} region operation for
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGISTER_INTEREST} region operation for
  * the pre-operation case.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/RemoveAllOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/RemoveAllOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/RemoveAllOperationContext.java
index c33d85d..b5c9f44 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/RemoveAllOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/RemoveAllOperationContext.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Collection;
 import java.util.Collections;
 
-import com.gemstone.gemfire.cache.operations.OperationContext;
+import org.apache.geode.cache.operations.OperationContext;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REMOVEALL} operation for both the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REMOVEALL} operation for both the
  * pre-operation and post-operation cases.
  * 
  * @since GemFire 8.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/StopCQOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/StopCQOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/StopCQOperationContext.java
index eae3ec5..064bd96 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/StopCQOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/StopCQOperationContext.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 import java.util.Set;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#STOP_CQ} operation for the pre-operation
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#STOP_CQ} operation for the pre-operation
  * case.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/UnregisterInterestOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/UnregisterInterestOperationContext.java b/geode-core/src/main/java/org/apache/geode/cache/operations/UnregisterInterestOperationContext.java
index 868d455..15bf9cb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/UnregisterInterestOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/UnregisterInterestOperationContext.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.operations;
+package org.apache.geode.cache.operations;
 
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#UNREGISTER_INTEREST} region operation for
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#UNREGISTER_INTEREST} region operation for
  * the pre-operation case.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/internal/GetOperationContextImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/internal/GetOperationContextImpl.java b/geode-core/src/main/java/org/apache/geode/cache/operations/internal/GetOperationContextImpl.java
index 2904776..82716ad 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/internal/GetOperationContextImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/internal/GetOperationContextImpl.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.operations.internal;
+package org.apache.geode.cache.operations.internal;
 
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.cache.operations.GetOperationContext;
-import com.gemstone.gemfire.internal.offheap.Releasable;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.SerializationException;
+import org.apache.geode.cache.operations.GetOperationContext;
+import org.apache.geode.internal.offheap.Releasable;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  * This subclass's job is to keep customers from getting a reference to a value

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/internal/UpdateOnlyMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/internal/UpdateOnlyMap.java b/geode-core/src/main/java/org/apache/geode/cache/operations/internal/UpdateOnlyMap.java
index 843e75d..2bbc3cd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/internal/UpdateOnlyMap.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/internal/UpdateOnlyMap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.operations.internal;
+package org.apache.geode.cache.operations.internal;
 
 import java.io.Serializable;
 
@@ -28,8 +28,8 @@ import java.util.Objects;
 import java.util.Set;
 import java.util.Map.Entry;
 
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.Token;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.Token;
 
 /**
  * This map only allows updates. No creates or removes.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/operations/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/operations/package.html b/geode-core/src/main/java/org/apache/geode/cache/operations/package.html
index c7ad91b..131a7a2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/operations/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/operations/package.html
@@ -18,89 +18,89 @@ limitations under the License.
 <BODY>
 
 
-<P>Contains the {@link com.gemstone.gemfire.cache.operations.OperationContext} interface that encapsulates an operation and the data associated with it for both the pre-operation and post-operation cases. 
-It also contains implementations of the {@link com.gemstone.gemfire.cache.operations.OperationContext} interface for  various kinds of cache operations.</P> 
+<P>Contains the {@link org.apache.geode.cache.operations.OperationContext} interface that encapsulates an operation and the data associated with it for both the pre-operation and post-operation cases. 
+It also contains implementations of the {@link org.apache.geode.cache.operations.OperationContext} interface for  various kinds of cache operations.</P> 
 
 These include: 
 	
 
-<P> {@link com.gemstone.gemfire.cache.operations.KeyOperationContext}: Implementation for operations that require a key for the operation. 
+<P> {@link org.apache.geode.cache.operations.KeyOperationContext}: Implementation for operations that require a key for the operation. 
 It provides a getKey method to obtain the key. Also provided are setCallbackArg and getCallbackArg methods that can be used to set/get an optional callback argument. 
-The operations returned as KeyOperationContext are {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#DESTROY} 
-and {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}. 
+The operations returned as KeyOperationContext are {@link org.apache.geode.cache.operations.OperationContext.OperationCode#DESTROY} 
+and {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CONTAINS_KEY}. 
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.KeyValueOperationContext}: Implementation for operations that require both key and value for the operation. 
-It extends the {@link com.gemstone.gemfire.cache.operations.KeyOperationContext} implementation providing getValue and setValue methods
+<P> {@link org.apache.geode.cache.operations.KeyValueOperationContext}: Implementation for operations that require both key and value for the operation. 
+It extends the {@link org.apache.geode.cache.operations.KeyOperationContext} implementation providing getValue and setValue methods
 in addition to those provided by the KeyOperationContext class. 
-The operations returned as KeyValueOperationContext are {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#GET} and {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#PUT}. 
+The operations returned as KeyValueOperationContext are {@link org.apache.geode.cache.operations.OperationContext.OperationCode#GET} and {@link org.apache.geode.cache.operations.OperationContext.OperationCode#PUT}. 
 For the GET operation this is used to both the pre and post operation cases. </P>
 
-<P>{@link com.gemstone.gemfire.cache.operations.InterestOperationContext}: Implementation for register and unregister of interest in a region. 
-It defines a sub-class {@link com.gemstone.gemfire.cache.operations.InterestType} that encapsulates different kinds of interest viz. 
+<P>{@link org.apache.geode.cache.operations.InterestOperationContext}: Implementation for register and unregister of interest in a region. 
+It defines a sub-class {@link org.apache.geode.cache.operations.InterestType} that encapsulates different kinds of interest viz. 
 KEY, LIST, REGULAR_EXPRESSION, FILTER_CLASS and OQL_QUERY. 
 It provides getInterestType method to get the interest type, 
-getInterestResultPolicy method to get the {@link com.gemstone.gemfire.cache.InterestResultPolicy} of the request, 
+getInterestResultPolicy method to get the {@link org.apache.geode.cache.InterestResultPolicy} of the request, 
 isUnregister method that returns true if this is an unregister operation, and getKey/setKey methods to get/set the key being registered. 
-The key may be a single key, a list of keys, a regular expression string or an OQL {@link com.gemstone.gemfire.cache.query.Query}. </P>
+The key may be a single key, a list of keys, a regular expression string or an OQL {@link org.apache.geode.cache.query.Query}. </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.QueryOperationContext}: Implementation for a cache query operation for both the pre and post operation cases. 
+<P> {@link org.apache.geode.cache.operations.QueryOperationContext}: Implementation for a cache query operation for both the pre and post operation cases. 
 It provides getQuery to get the query string as well as a modifyQuery method to be able to modify it. 
 A utility getRegionNames method is also provided to obtain the list of regions as referenced by the query string. 
 For the results in the post operation phase, getQueryResult allows getting the result and setQueryResult allows modification of the result.</P>
 	
 
-<P> {@link com.gemstone.gemfire.cache.operations.RegionOperationContext}: Implementation for the region level operation for the pre operation case. 
+<P> {@link org.apache.geode.cache.operations.RegionOperationContext}: Implementation for the region level operation for the pre operation case. 
 It provides getCallbackArg and setCallbackArg methods to get/set the optionally callback argument. 
-The operations returned as RegionOperationContext are {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CLEAR} 
-and {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.</P> 
+The operations returned as RegionOperationContext are {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CLEAR} 
+and {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_DESTROY}.</P> 
 	
 
-<P> {@link com.gemstone.gemfire.cache.operations.DestroyOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#DESTROY} operation 
+<P> {@link org.apache.geode.cache.operations.DestroyOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#DESTROY} operation 
 having the key object for both the pre-operation and post-operation updates.
 </P>	
 
-<P> {@link com.gemstone.gemfire.cache.operations.CloseCQOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CLOSE_CQ} operation
+<P> {@link org.apache.geode.cache.operations.CloseCQOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CLOSE_CQ} operation
 for the pre-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.ExecuteCQOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#EXECUTE_CQ} operation 
+<P> {@link org.apache.geode.cache.operations.ExecuteCQOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#EXECUTE_CQ} operation 
 for both the pre-operation and post-operation case.</P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.ExecuteFunctionOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#EXECUTE_FUNCTION} operation 
+<P> {@link org.apache.geode.cache.operations.ExecuteFunctionOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#EXECUTE_FUNCTION} operation 
 for the pre-operation  case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.GetOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#GET} operation 
+<P> {@link org.apache.geode.cache.operations.GetOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#GET} operation 
 having the key object for the pre-operation case and both key-value objects for the post-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.InvalidateOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#INVALIDATE} region
+<P> {@link org.apache.geode.cache.operations.InvalidateOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#INVALIDATE} region
 operation having the key object for the pre-operation case and post-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.PutOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#PUT} operation 
+<P> {@link org.apache.geode.cache.operations.PutOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#PUT} operation 
 having the key and value objects for the pre-operation case and post-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.PutAllOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#KEY_SET} operation
+<P> {@link org.apache.geode.cache.operations.PutAllOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#KEY_SET} operation
 having the key and value objects for the pre-operation case and post-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.RegionCreateOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGION_CREATE} 
+<P> {@link org.apache.geode.cache.operations.RegionCreateOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGION_CREATE} 
 operation for the pre-operation case and post-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.StopCQOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#STOP_CQ} operation
+<P> {@link org.apache.geode.cache.operations.StopCQOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#STOP_CQ} operation
 for the pre-operation case.
 </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.RegisterInterestOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#REGISTER_INTEREST} operation
-for the pre-operation case, which derives from {@link com.gemstone.gemfire.cache.operations.InterestOperationContext}
+<P> {@link org.apache.geode.cache.operations.RegisterInterestOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#REGISTER_INTEREST} operation
+for the pre-operation case, which derives from {@link org.apache.geode.cache.operations.InterestOperationContext}
  </P>
 
-<P> {@link com.gemstone.gemfire.cache.operations.UnregisterInterestOperationContext}: Implementation for {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#UNREGISTER_INTEREST} operation 
-for the pre-operation case, which derives from {@link com.gemstone.gemfire.cache.operations.InterestOperationContext} </P>
+<P> {@link org.apache.geode.cache.operations.UnregisterInterestOperationContext}: Implementation for {@link org.apache.geode.cache.operations.OperationContext.OperationCode#UNREGISTER_INTEREST} operation 
+for the pre-operation case, which derives from {@link org.apache.geode.cache.operations.InterestOperationContext} </P>
 
 
 </BODY>


[24/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/GMSMembershipManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/GMSMembershipManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/GMSMembershipManager.java
index 00d074a..46f7ec2 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/GMSMembershipManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/GMSMembershipManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.mgr;
+package org.apache.geode.distributed.internal.membership.gms.mgr;
 
 import java.io.IOException;
 import java.io.NotSerializableException;
@@ -41,62 +41,62 @@ import java.util.concurrent.locks.ReentrantReadWriteLock;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.ForcedDisconnectException;
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.ToDataException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.AdminMessageType;
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.distributed.internal.OverflowQueueWithDMStats;
-import com.gemstone.gemfire.distributed.internal.SizeableRunnable;
-import com.gemstone.gemfire.distributed.internal.StartupMessage;
-import com.gemstone.gemfire.distributed.internal.direct.DirectChannel;
-import com.gemstone.gemfire.distributed.internal.direct.DirectChannelListener;
-import com.gemstone.gemfire.distributed.internal.direct.ShunnedMemberException;
-import com.gemstone.gemfire.distributed.internal.membership.DistributedMembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipTestHook;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.SuspectMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.fd.GMSHealthMonitor;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Manager;
-import com.gemstone.gemfire.distributed.internal.membership.gms.membership.GMSJoinLeave;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messenger.GMSQuorumChecker;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessageWithDirectReply;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheServerCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.shared.StringPrintWriter;
-import com.gemstone.gemfire.internal.tcp.ConnectExceptions;
-import com.gemstone.gemfire.internal.tcp.MemberShunnedException;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
+import org.apache.geode.CancelException;
+import org.apache.geode.ForcedDisconnectException;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.ToDataException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.AdminMessageType;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.distributed.internal.OverflowQueueWithDMStats;
+import org.apache.geode.distributed.internal.SizeableRunnable;
+import org.apache.geode.distributed.internal.StartupMessage;
+import org.apache.geode.distributed.internal.direct.DirectChannel;
+import org.apache.geode.distributed.internal.direct.DirectChannelListener;
+import org.apache.geode.distributed.internal.direct.ShunnedMemberException;
+import org.apache.geode.distributed.internal.membership.DistributedMembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.distributed.internal.membership.MembershipTestHook;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.SuspectMember;
+import org.apache.geode.distributed.internal.membership.gms.fd.GMSHealthMonitor;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.Manager;
+import org.apache.geode.distributed.internal.membership.gms.membership.GMSJoinLeave;
+import org.apache.geode.distributed.internal.membership.gms.messenger.GMSQuorumChecker;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.cache.CacheServerImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.partitioned.PartitionMessageWithDirectReply;
+import org.apache.geode.internal.cache.xmlcache.CacheServerCreation;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlGenerator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.shared.StringPrintWriter;
+import org.apache.geode.internal.tcp.ConnectExceptions;
+import org.apache.geode.internal.tcp.MemberShunnedException;
+import org.apache.geode.internal.util.Breadcrumbs;
 
 public class GMSMembershipManager implements MembershipManager, Manager
 {
@@ -264,7 +264,7 @@ public class GMSMembershipManager implements MembershipManager, Manager
   /**
    * This is the listener that accepts our membership events
    */
-  private final com.gemstone.gemfire.distributed.internal.membership.DistributedMembershipListener listener;
+  private final org.apache.geode.distributed.internal.membership.DistributedMembershipListener listener;
 
   /**
    * Membership failure listeners - for testing
@@ -1752,7 +1752,7 @@ public class GMSMembershipManager implements MembershipManager, Manager
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.membership.MembershipManager#isConnected()
+   * @see org.apache.geode.distributed.internal.membership.MembershipManager#isConnected()
    */
   public boolean isConnected() {
     return (this.hasJoined && !this.shutdownInProgress); 
@@ -2199,7 +2199,7 @@ public class GMSMembershipManager implements MembershipManager, Manager
    * (non-Javadoc)
    * MembershipManager method: wait for the given member to be gone.  Throws TimeoutException if
    * the wait goes too long
-   * @see com.gemstone.gemfire.distributed.internal.membership.MembershipManager#waitForDeparture(com.gemstone.gemfire.distributed.DistributedMember)
+   * @see org.apache.geode.distributed.internal.membership.MembershipManager#waitForDeparture(org.apache.geode.distributed.DistributedMember)
    */
   public boolean waitForDeparture(DistributedMember mbr) throws TimeoutException, InterruptedException {
     if (Thread.interrupted()) throw new InterruptedException();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/LocalViewMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/LocalViewMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/LocalViewMessage.java
index 2bf6daf..330d8fb 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/LocalViewMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/mgr/LocalViewMessage.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.mgr;
+package org.apache.geode.distributed.internal.membership.gms.mgr;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/package.html b/geode-core/src/main/java/org/apache/geode/distributed/internal/package.html
index cdb755f..7d6eb36 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/package.html
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/package.html
@@ -21,15 +21,15 @@ Classes in this package implement distribution in GemFire.
 Every virtual machine working with distributed data (client
 VMs, the GemFire console) has an
 instance of {@link
-com.gemstone.gemfire.distributed.internal.DistributionManager}
+org.apache.geode.distributed.internal.DistributionManager}
 that is responsible for sending and receiving {@link
-com.gemstone.gemfire.distributed.internal.DistributionMessage}s.
+org.apache.geode.distributed.internal.DistributionMessage}s.
 A <code>DistributionManager</code> has a unique {@link
-com.gemstone.gemfire.distributed.internal.DistributionManager#getId
+org.apache.geode.distributed.internal.DistributionManager#getId
 id} and uses a JavaGroups com.gemstone.org.javagroups.Channel
 channel to discover the other members of the distributed system.  It
 also uses JavaGroups to detect when a member has left the group.  Note
-that GemStone has com.gemstone.gemfire.distributed.internal.direct.DirectChannel#patchUpAddress
+that GemStone has org.apache.geode.distributed.internal.direct.DirectChannel#patchUpAddress
 modified the implementation of the JavaGroups com.gemstone.org.jgroups.stack.IpAddress to hold the port on which
 the distribution manager's direct channel runs.  This optimization
 allows us to start a distribution manager without having to send out a
@@ -38,10 +38,10 @@ less XML parsing.  This greatly improves the performace of creating a
 JavaGroups channel.)  While some messages may be broadcast to all
 members of the group, the vast majority of messages are only intended
 for a subset of the group are sent point-to-point over a {@link
-com.gemstone.gemfire.distributed.internal.direct.DirectChannel}.
+org.apache.geode.distributed.internal.direct.DirectChannel}.
 The JGroups channel and <code>DirectChannel</code> are combined
 into a {@link
-com.gemstone.gemfire.distributed.internal.DistributionChannel}
+org.apache.geode.distributed.internal.DistributionChannel}
 that is used by the <code>DistributionManager</code>.
 
 <P>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/streaming/StreamingOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/streaming/StreamingOperation.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/streaming/StreamingOperation.java
index 69e8a94..21fd5f9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/streaming/StreamingOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/streaming/StreamingOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.streaming;
+package org.apache.geode.distributed.internal.streaming;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -29,37 +29,37 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.GemFireRethrowable;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.PRQueryTraceInfo;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.GemFireRethrowable;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.PRQueryTraceInfo;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.PartitionedRegionQueryEvaluator;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.util.BlobHelper;
 /**
  * StreamingOperation is an abstraction for sending messages to multiple (or single)
  * recipient requesting a potentially large amount of data and receiving the reply
@@ -89,7 +89,7 @@ public abstract class StreamingOperation {
    * @throws InterruptedException TODO-javadocs
    */
   public void getDataFromAll(Set recipients)
-  throws com.gemstone.gemfire.cache.TimeoutException, InterruptedException
+  throws org.apache.geode.cache.TimeoutException, InterruptedException
   {    
     if (Thread.interrupted()) throw new InterruptedException();
     if (recipients.isEmpty())
@@ -105,8 +105,8 @@ public abstract class StreamingOperation {
       }
       catch (InternalGemFireException ex) {
         Throwable cause = ex.getCause();
-        if (cause instanceof com.gemstone.gemfire.cache.TimeoutException) {
-          throw (com.gemstone.gemfire.cache.TimeoutException)cause;
+        if (cause instanceof org.apache.geode.cache.TimeoutException) {
+          throw (org.apache.geode.cache.TimeoutException)cause;
         }
         throw ex;
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoRequest.java
index eb90155..2b2271d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoRequest.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * A request to the TCP server to provide information

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoResponse.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoResponse.java
index 953fe8d..b8ceb15 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/InfoResponse.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
 
 /**
  * A response from the TCP server with information

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownRequest.java
index 7d002ac..3240334 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownRequest.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * A request to the TCP server to shutdown

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownResponse.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownResponse.java
index 1dc37bf..b9fd9c1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/ShutdownResponse.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * A response from the TCP server that it received

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpClient.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpClient.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpClient.java
index c770238..80a586c 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpClient.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpClient.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
@@ -28,13 +28,13 @@ import java.util.Map;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.UnsupportedVersionException;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedDataInputStream;
-import com.gemstone.gemfire.internal.VersionedDataOutputStream;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.UnsupportedVersionException;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedDataInputStream;
+import org.apache.geode.internal.VersionedDataOutputStream;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Client for the TcpServer. These methods were refactored out of GossipClient,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpHandler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpHandler.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpHandler.java
index aaed5fd..3e92967 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpHandler.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpHandler.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
 import java.io.IOException;
 
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.SharedConfiguration;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.SharedConfiguration;
 
 /**
  * A handler which responds to messages for the {@link TcpServer}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpServer.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpServer.java
index ceb5af8..94e005b 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpServer.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/TcpServer.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.tcpserver;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.distributed.internal.tcpserver;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import javax.net.ssl.SSLException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionRequest.java
index 2cbfd97..99edb09 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionRequest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionResponse.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionResponse.java
index 7d5e08c..bd50f03 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/tcpserver/VersionResponse.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.tcpserver;
+package org.apache.geode.distributed.internal.tcpserver;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.internal.Version;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/unsafe/RegisterSignalHandlerSupport.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/unsafe/RegisterSignalHandlerSupport.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/unsafe/RegisterSignalHandlerSupport.java
index 94ae4da..15c4aee 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/unsafe/RegisterSignalHandlerSupport.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/unsafe/RegisterSignalHandlerSupport.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.unsafe;
+package org.apache.geode.distributed.internal.unsafe;
 
 /**
  * The RegisterSignalHandlerSupport class is an ugly hack!

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/package.html b/geode-core/src/main/java/org/apache/geode/distributed/package.html
index d325f38..f51e25d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/package.html
+++ b/geode-core/src/main/java/org/apache/geode/distributed/package.html
@@ -20,14 +20,14 @@ limitations under the License.
 <P>Provides information about, access to, and common tools for GemFire
 distributed systems.  When a program wishes to access distributed dtaa
 data stored in GemFire, it first creates a {@link
-com.gemstone.gemfire.distributed.DistributedSystem} that will connect
+org.apache.geode.distributed.DistributedSystem} that will connect
 to the distributed system.  GemFire provides two means of discovering
 the other members in a distributed group.  The first uses IP multicast
 to broadcast a message to all members that listen on a given <A
 href="DistributedSystem.html#mcast-port"/>port</A> and <A
 href="DistributedSystem.html#mcast-address">address</A>.  The second
 method of discovery uses special VMs called {@linkplain
-com.gemstone.gemfire.distributed.Locator "locators"} to keep track of
+org.apache.geode.distributed.Locator "locators"} to keep track of
 the members of the distributed system.  Each locator is identified by
 a host/port pair that is <A
 href="DistributedSystem.html#locators">specified</A> when connecting

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/i18n/LogWriterI18n.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/i18n/LogWriterI18n.java b/geode-core/src/main/java/org/apache/geode/i18n/LogWriterI18n.java
index 09198cf..f499262 100644
--- a/geode-core/src/main/java/org/apache/geode/i18n/LogWriterI18n.java
+++ b/geode-core/src/main/java/org/apache/geode/i18n/LogWriterI18n.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.i18n;
+package org.apache.geode.i18n;
 
 import java.util.logging.Handler;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.distributed.DistributedSystem;
+import org.apache.geode.LogWriter;
+import org.apache.geode.distributed.DistributedSystem;
 /**
   * Defines methods available to clients that want to write a log message
   * to their GemFire distributed system log file.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/i18n/StringId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/i18n/StringId.java b/geode-core/src/main/java/org/apache/geode/i18n/StringId.java
index 221d66b..38b9414 100755
--- a/geode-core/src/main/java/org/apache/geode/i18n/StringId.java
+++ b/geode-core/src/main/java/org/apache/geode/i18n/StringId.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.i18n;
+package org.apache.geode.i18n;
 
-import com.gemstone.gemfire.internal.i18n.AbstractStringIdResourceBundle;
+import org.apache.geode.internal.i18n.AbstractStringIdResourceBundle;
 
 import java.text.MessageFormat;
 import java.util.Locale;
@@ -29,11 +29,11 @@ import java.util.Locale;
  */
 public class StringId {
   /** The root name of the ResourceBundle */
-  private static final String RESOURCE_CLASS = "com/gemstone/gemfire/internal/i18n/StringIdResourceBundle";
+  private static final String RESOURCE_CLASS = "org/apache/geode/internal/i18n/StringIdResourceBundle";
   
   /** A unique identifier that is written when this StringId is logged to 
    * allow for reverse translation.
-   * @see com.gemstone.gemfire.internal.logging.LogWriterImpl
+   * @see org.apache.geode.internal.logging.LogWriterImpl
    */
   public final int id;
   /** the English translation of text */
@@ -47,7 +47,7 @@ public class StringId {
   
   private static boolean includeMsgIDs;
   
-  /** A StringId to allow users to log a literal String using the {@link com.gemstone.gemfire.i18n.LogWriterI18n} */
+  /** A StringId to allow users to log a literal String using the {@link org.apache.geode.i18n.LogWriterI18n} */
   public static final StringId LITERAL = new StringId(1, "{0}"); 
   
   static {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/AbstractConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/AbstractConfig.java b/geode-core/src/main/java/org/apache/geode/internal/AbstractConfig.java
index 4d0c5a8..e75ebb5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/AbstractConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/AbstractConfig.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.UnmodifiableException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.FlowControlParams;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.UnmodifiableException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.FlowControlParams;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.lang.reflect.Array;
@@ -29,7 +29,7 @@ import java.net.InetAddress;
 import java.net.UnknownHostException;
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 /**
  * Provides an implementation of the {@link Config} interface
  * that implements functionality that all {@link Config} implementations

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/Assert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/Assert.java b/geode-core/src/main/java/org/apache/geode/internal/Assert.java
index b337bbd..0a38aaa 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/Assert.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/Assert.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Support for correctness assertions.
@@ -93,8 +93,8 @@ public class Assert {
       } else {
         ex = new InternalGemFireError();
       }
-//       com.gemstone.gemfire.internal.cache.GemFireCache gfc
-//         = com.gemstone.gemfire.internal.cache.GemFireCache.getInstance();
+//       org.apache.geode.internal.cache.GemFireCache gfc
+//         = org.apache.geode.internal.cache.GemFireCache.getInstance();
 //       if (gfc != null) {
 //         gfc.getLogger().info("DEBUG", ex);
 //       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/AvailablePort.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/AvailablePort.java b/geode-core/src/main/java/org/apache/geode/internal/AvailablePort.java
index 7a8dccd..d7b1567 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/AvailablePort.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/AvailablePort.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.IOException;
 import java.io.PrintStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/Banner.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/Banner.java b/geode-core/src/main/java/org/apache/geode/internal/Banner.java
index bee70a4..01cd9aa 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/Banner.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/Banner.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.internal.logging.LogService;
 
 import java.io.PrintWriter;
 import java.io.StringWriter;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ByteArrayDataInput.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ByteArrayDataInput.java b/geode-core/src/main/java/org/apache/geode/internal/ByteArrayDataInput.java
index 614bcb8..57d0b72 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ByteArrayDataInput.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ByteArrayDataInput.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataInput;
 import java.io.EOFException;
@@ -23,8 +23,8 @@ import java.io.IOException;
 import java.io.InputStream;
 import java.io.UTFDataFormatException;
 
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedDataStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedDataStream;
 
 /**
  * A reusable {@link DataInput} implementation that wraps a given byte array. It

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ByteBufferOutputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ByteBufferOutputStream.java b/geode-core/src/main/java/org/apache/geode/internal/ByteBufferOutputStream.java
index 043eb96..bbaefa9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ByteBufferOutputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ByteBufferOutputStream.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.*;
 import java.nio.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ByteBufferWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ByteBufferWriter.java b/geode-core/src/main/java/org/apache/geode/internal/ByteBufferWriter.java
index 81fd0d2..006a650 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ByteBufferWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ByteBufferWriter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.nio.ByteBuffer;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ClassLoadUtil.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ClassLoadUtil.java b/geode-core/src/main/java/org/apache/geode/internal/ClassLoadUtil.java
index 9ec015a..275227a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ClassLoadUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ClassLoadUtil.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.lang.reflect.Method;
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ClassPathLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ClassPathLoader.java b/geode-core/src/main/java/org/apache/geode/internal/ClassPathLoader.java
index 697f8c7..9050953 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/ClassPathLoader.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ClassPathLoader.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.CollectionUtils;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.util.CollectionUtils;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/Config.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/Config.java b/geode-core/src/main/java/org/apache/geode/internal/Config.java
index c70b1fa..d8e07e7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/Config.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/Config.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.File;
 import java.io.IOException;
@@ -43,15 +43,15 @@ public interface Config {
    * specify the attribute name and value and get them safely into
    * a Config instance.
    * @throws IllegalArgumentException if the specified name or value are illegal
-   * @throws com.gemstone.gemfire.UnmodifiableException if the attribute can not be modified.
+   * @throws org.apache.geode.UnmodifiableException if the attribute can not be modified.
    */
   void setAttribute(String attName, String attValue, ConfigSource source);
   /**
    * Given the attribute's name set its value to the specified Object.
    * @throws IllegalArgumentException if the specified name is unknown
-   * @throws com.gemstone.gemfire.InvalidValueException if the specified value is not compatible
+   * @throws org.apache.geode.InvalidValueException if the specified value is not compatible
    *                               with the attributes type
-   * @throws com.gemstone.gemfire.UnmodifiableException if the attribute can not be modified.
+   * @throws org.apache.geode.UnmodifiableException if the attribute can not be modified.
    */
   void setAttributeObject(String attName, Object attValue, ConfigSource source);
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ConfigSource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ConfigSource.java b/geode-core/src/main/java/org/apache/geode/internal/ConfigSource.java
index 51c2caf..fbe467b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ConfigSource.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ConfigSource.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ConnectionWatcher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ConnectionWatcher.java b/geode-core/src/main/java/org/apache/geode/internal/ConnectionWatcher.java
index 75d1aeb..4755526 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/ConnectionWatcher.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ConnectionWatcher.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.net.Socket;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/CopyOnWriteHashSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/CopyOnWriteHashSet.java b/geode-core/src/main/java/org/apache/geode/internal/CopyOnWriteHashSet.java
index 38697fc..6c5c340 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/CopyOnWriteHashSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/CopyOnWriteHashSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.IOException;
 import java.io.ObjectInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/DSCODE.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DSCODE.java b/geode-core/src/main/java/org/apache/geode/internal/DSCODE.java
index 583b2ab..e9f524c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DSCODE.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DSCODE.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializer;
 
 /**
  * An interface that contains a bunch of static final values used for the


[69/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/DataBrowser.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/DataBrowser.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/DataBrowser.java
new file mode 100644
index 0000000..de4ea1f
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/DataBrowser.java
@@ -0,0 +1,248 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.FileNotFoundException;
+import java.io.FileOutputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.text.SimpleDateFormat;
+import java.util.Iterator;
+import java.util.ResourceBundle;
+import java.util.Scanner;
+
+/**
+ * Class DataBrowser This class contains Data browser functionalities for
+ * managing queries and histories.
+ * 
+ * @since GemFire version 7.5.Beta 2013-03-25
+ */
+public class DataBrowser {
+
+  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+  private final ResourceBundle resourceBundle = Repository.get()
+      .getResourceBundle();
+
+  private SimpleDateFormat simpleDateFormat = new SimpleDateFormat(
+      PulseConstants.PULSE_QUERY_HISTORY_DATE_PATTERN);
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  /**
+   * addQueryInHistory method adds user's query into query history file
+   * 
+   * @param userId
+   *          Logged in User's Id
+   * @param queryText
+   *          Query text to execute
+   */
+  public boolean addQueryInHistory(String queryText, String userId) {
+    boolean operationStatus = false;
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryText)
+        && StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
+
+      // Fetch all queries from query log file
+      ObjectNode queries = fetchAllQueriesFromFile();
+
+      // Get user's query history list
+      ObjectNode userQueries = (ObjectNode) queries.get(userId);
+      if (userQueries == null) {
+        userQueries = mapper.createObjectNode();
+      }
+
+      // Add query in user's query history list
+      userQueries.put(Long.toString(System.currentTimeMillis()), queryText);
+      queries.put(userId, userQueries);
+
+      // Store queries in file back
+      operationStatus = storeQueriesInFile(queries);
+    }
+
+    return operationStatus;
+  }
+
+  /**
+   * deleteQueryById method deletes query from query history file
+   * 
+   * @param userId
+   *          Logged in user's Unique Id
+   * @param queryId
+   *          Unique Id of Query to be deleted
+   * @return boolean
+   */
+  public boolean deleteQueryById(String userId, String queryId) {
+
+    boolean operationStatus = false;
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryId)
+        && StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
+
+      // Fetch all queries from query log file
+      ObjectNode queries = fetchAllQueriesFromFile();
+
+      // Get user's query history list
+      ObjectNode userQueries = (ObjectNode) queries.get(userId);
+
+      if (userQueries != null) {
+        // Remove user's query
+        userQueries.remove(queryId);
+        queries.put(userId, userQueries);
+
+        // Store queries in file back
+        operationStatus = storeQueriesInFile(queries);
+      }
+    }
+    
+    return operationStatus;
+  }
+
+  /**
+   * getQueryHistoryByUserId method reads and lists out the queries from history
+   * file
+   * 
+   * @param userId
+   *          Logged in User's Id
+   */
+  public ArrayNode getQueryHistoryByUserId(String userId) {
+
+    ArrayNode queryList = mapper.createArrayNode();
+
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
+
+      // Fetch all queries from query log file
+      ObjectNode queries = fetchAllQueriesFromFile();
+      
+      // Get user's query history list
+      ObjectNode userQueries = (ObjectNode) queries.get(userId);
+
+      if (userQueries != null) {
+        Iterator<String> it = userQueries.fieldNames();
+        while (it.hasNext()) {
+          String key = it.next();
+          ObjectNode queryItem = mapper.createObjectNode();
+          queryItem.put("queryId", key);
+          queryItem.put("queryText", userQueries.get(key).toString());
+          queryItem.put("queryDateTime", simpleDateFormat.format(Long.valueOf(key)));
+          queryList.add(queryItem);
+        }
+      }
+    }
+
+    return queryList;
+  }
+
+  /**
+   * generateQueryKey method fetches queries from query history file
+   * 
+   * @return Properties A collection queries in form of key and values
+   */
+  private ObjectNode fetchAllQueriesFromFile() {
+    InputStream inputStream = null;
+    JsonNode queriesJSON = mapper.createObjectNode();
+
+    try {
+      inputStream = new FileInputStream(Repository.get().getPulseConfig().getQueryHistoryFileName());
+      String inputStreamString = new Scanner(inputStream, "UTF-8").useDelimiter("\\A").next();
+      queriesJSON = mapper.readTree(inputStreamString);
+    } catch (FileNotFoundException e) {
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine(resourceBundle
+            .getString("LOG_MSG_DATA_BROWSER_QUERY_HISTORY_FILE_NOT_FOUND")
+            + " : " + e.getMessage());
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(e.getMessage());
+      }
+    } finally {
+      // Close input stream
+      if (inputStream != null) {
+        try {
+          inputStream.close();
+        } catch (IOException e) {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(e.getMessage());
+          }
+        }
+      }
+    }
+
+    return (ObjectNode) queriesJSON;
+  }
+
+  /**
+   * generateQueryKey method stores queries in query history file.
+   * 
+   * @return Boolean true is operation is successful, false otherwise
+   */
+  private boolean storeQueriesInFile(ObjectNode queries) {
+    boolean operationStatus = false;
+    FileOutputStream fileOut = null;
+
+    File file = new File(Repository.get().getPulseConfig().getQueryHistoryFileName());
+    try {
+      fileOut = new FileOutputStream(file);
+
+      // if file does not exists, then create it
+      if (!file.exists()) {
+        file.createNewFile();
+      }
+
+      // get the content in bytes
+      byte[] contentInBytes = queries.toString().getBytes();
+
+      fileOut.write(contentInBytes);
+      fileOut.flush();
+
+      operationStatus = true;
+    } catch (FileNotFoundException e) {
+
+      if (LOGGER.fineEnabled()) {
+        LOGGER.fine(resourceBundle
+            .getString("LOG_MSG_DATA_BROWSER_QUERY_HISTORY_FILE_NOT_FOUND")
+            + " : " + e.getMessage());
+      }
+    } catch (IOException e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(e.getMessage());
+      }
+    } finally {
+      if (fileOut != null) {
+        try {
+          fileOut.close();
+        } catch (IOException e) {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(e.getMessage());
+          }
+        }
+      }
+    }
+    return operationStatus;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/IClusterUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/IClusterUpdater.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/IClusterUpdater.java
new file mode 100644
index 0000000..4ddfc1a
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/IClusterUpdater.java
@@ -0,0 +1,35 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import com.fasterxml.jackson.databind.node.ObjectNode;
+
+/**
+ * Interface having updateData() function which is getting Override by both
+ * MockDataUpdater and JMXDataUpdater
+ * 
+ * @since GemFire  version 7.0.Beta 2012-09-23
+ * 
+ */
+public interface IClusterUpdater {
+  boolean updateData();
+
+  ObjectNode executeQuery(String queryText, String members, int limit);
+}


[45/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/DistributionLocatorConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/DistributionLocatorConfig.java b/geode-core/src/main/java/org/apache/geode/admin/DistributionLocatorConfig.java
index 8c6770c..162f4f1 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/DistributionLocatorConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/DistributionLocatorConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 import java.util.Properties;
 
 /**
@@ -36,10 +36,10 @@ import java.util.Properties;
  * invoking the {@link Object#clone} method.
  *
  * @see AdminDistributedSystem#addDistributionLocator
- * @see com.gemstone.gemfire.distributed.Locator
+ * @see org.apache.geode.distributed.Locator
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface DistributionLocatorConfig
   extends ManagedEntityConfig {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/GemFireHealth.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/GemFireHealth.java b/geode-core/src/main/java/org/apache/geode/admin/GemFireHealth.java
index 7665cbf..202ce70 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/GemFireHealth.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/GemFireHealth.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides information about the aggregate health of the members of a
@@ -42,7 +42,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  *
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  * */
 public interface GemFireHealth {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/GemFireHealthConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/GemFireHealthConfig.java b/geode-core/src/main/java/org/apache/geode/admin/GemFireHealthConfig.java
index d7bc22c..638244a 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/GemFireHealthConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/GemFireHealthConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Provides configuration information relating to all of the
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.admin;
  *
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  * */
 public interface GemFireHealthConfig
   extends MemberHealthConfig, CacheHealthConfig {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/GemFireMemberStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/GemFireMemberStatus.java b/geode-core/src/main/java/org/apache/geode/admin/GemFireMemberStatus.java
index 1b544a8..24fcf09 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/GemFireMemberStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/GemFireMemberStatus.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.Locator;
-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.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.ClientHealthMonitoringRegion;
-import com.gemstone.gemfire.internal.admin.remote.ClientHealthStats;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.tier.InternalClientMembership;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+package org.apache.geode.admin;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.ClientHealthMonitoringRegion;
+import org.apache.geode.internal.admin.remote.ClientHealthStats;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.tier.InternalClientMembership;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 import java.io.IOException;
 import java.io.Serializable;
@@ -42,7 +42,7 @@ import java.util.*;
  * Class <code>GemFireMemberStatus</code> provides the status of a specific
  * GemFire member VM. This VM can be a peer, a client, a server and/or a
  * gateway.
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class GemFireMemberStatus implements Serializable {
   private static final long serialVersionUID = 3389997790525991310L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/ManagedEntity.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/ManagedEntity.java b/geode-core/src/main/java/org/apache/geode/admin/ManagedEntity.java
index d7e5d26..0b4851e 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/ManagedEntity.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/ManagedEntity.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A entity that can be managed with the GemFire administration API.
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.admin;
  * @see ManagedEntityConfig
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface ManagedEntity {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/ManagedEntityConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/ManagedEntityConfig.java b/geode-core/src/main/java/org/apache/geode/admin/ManagedEntityConfig.java
index e82acdc..9a95b44 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/ManagedEntityConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/ManagedEntityConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Common configuration for all entities that can be managed using the
@@ -26,7 +26,7 @@ package com.gemstone.gemfire.admin;
  * @see ManagedEntity
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface ManagedEntityConfig extends Cloneable {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/MemberHealthConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/MemberHealthConfig.java b/geode-core/src/main/java/org/apache/geode/admin/MemberHealthConfig.java
index f9c332d..e0a90c6 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/MemberHealthConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/MemberHealthConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Provides configuration information relating to the health of a
@@ -47,7 +47,7 @@ package com.gemstone.gemfire.admin;
  *
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  * */
 public interface MemberHealthConfig {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/OperationCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/OperationCancelledException.java b/geode-core/src/main/java/org/apache/geode/admin/OperationCancelledException.java
index 5132626..d765c21 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/OperationCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/OperationCancelledException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-//import com.gemstone.gemfire.GemFireException;
+//import org.apache.geode.GemFireException;
 
 /**
  * Thrown when an administration operation that accesses information
@@ -25,7 +25,7 @@ package com.gemstone.gemfire.admin;
  * because the system member has left the distributed system.
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class OperationCancelledException extends RuntimeAdminException {
    private static final long serialVersionUID = 5474068770227602546L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/RegionNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/RegionNotFoundException.java b/geode-core/src/main/java/org/apache/geode/admin/RegionNotFoundException.java
index 18a86f4..29dfa98 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/RegionNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/RegionNotFoundException.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-//import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+//import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheRuntimeException;
 
 /**
  * Thrown by the administration API when the region administered by a
  * {@link SystemMemberRegion} has been closed or destroyed in system
  * member. 
- * <P>Also thrown by {@link com.gemstone.gemfire.DataSerializer#readRegion(java.io.DataInput)}
+ * <P>Also thrown by {@link org.apache.geode.DataSerializer#readRegion(java.io.DataInput)}
  * if the named region no longer exists.
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class RegionNotFoundException extends CacheRuntimeException {
 private static final long serialVersionUID = 1758668137691463909L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/RegionSubRegionSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/RegionSubRegionSnapshot.java b/geode-core/src/main/java/org/apache/geode/admin/RegionSubRegionSnapshot.java
index 42ae983..1945566 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/RegionSubRegionSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/RegionSubRegionSnapshot.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,11 +23,11 @@ import java.util.HashSet;
 import java.util.Iterator;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 /**
  * Class <code>RegionSubRegionSnapshot</code> provides information about
@@ -36,7 +36,7 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
  * 
  * 
  * @since GemFire 5.7
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class RegionSubRegionSnapshot implements DataSerializable {
   private static final long serialVersionUID = -8052137675270041871L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/RuntimeAdminException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/RuntimeAdminException.java b/geode-core/src/main/java/org/apache/geode/admin/RuntimeAdminException.java
index 08f5efc..7a28867 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/RuntimeAdminException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/RuntimeAdminException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A <code>RuntimeAdminException</code> is thrown when a runtime errors occurs
@@ -23,10 +23,10 @@ package com.gemstone.gemfire.admin;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class RuntimeAdminException 
-extends com.gemstone.gemfire.GemFireException {
+extends org.apache.geode.GemFireException {
 
   private static final long serialVersionUID = -7512771113818634005L;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/Statistic.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/Statistic.java b/geode-core/src/main/java/org/apache/geode/admin/Statistic.java
index 731d024..b1f1cc8 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/Statistic.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/Statistic.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Interface to represent a single statistic of a <code>StatisticResource</code>
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface Statistic extends java.io.Serializable {
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/StatisticResource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/StatisticResource.java b/geode-core/src/main/java/org/apache/geode/admin/StatisticResource.java
index 3344b25..43c51cd 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/StatisticResource.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/StatisticResource.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Adminitrative interface for monitoring a statistic resource in a GemFire
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.admin;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface StatisticResource {
   
@@ -76,10 +76,10 @@ public interface StatisticResource {
    * Refreshes the values of every {@link Statistic} in this resource by
    * retrieving them from the member's VM.
    *
-   * @throws com.gemstone.gemfire.admin.AdminException 
+   * @throws org.apache.geode.admin.AdminException 
    *         if unable to refresh statistic values
    */
-  public void refresh() throws com.gemstone.gemfire.admin.AdminException;
+  public void refresh() throws org.apache.geode.admin.AdminException;
   
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMember.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMember.java
index 2667b3d..78cc9aa 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMember.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMember.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 import java.net.InetAddress;
 
@@ -25,7 +25,7 @@ import java.net.InetAddress;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMember {
   
@@ -43,10 +43,10 @@ public interface SystemMember {
    * Retrieves display friendly name for this member.  If this member defined 
    * an optional name for its connection to the distributed system, that name 
    * will be returned.  Otherwise the returned value will be {@link
-   * com.gemstone.gemfire.admin.SystemMember#getId}.
+   * org.apache.geode.admin.SystemMember#getId}.
    *
-   * @see com.gemstone.gemfire.distributed.DistributedSystem#connect
-   * @see com.gemstone.gemfire.distributed.DistributedSystem#getName
+   * @see org.apache.geode.distributed.DistributedSystem#connect
+   * @see org.apache.geode.distributed.DistributedSystem#getName
    */
   public String getName();
   
@@ -86,13 +86,13 @@ public interface SystemMember {
    *
    * @param parms subset of the configuration parameters to be changed
    * @return all configuration parameters including those that were changed
-   * @throws com.gemstone.gemfire.admin.AdminException
+   * @throws org.apache.geode.admin.AdminException
    *         if this fails to make the configuration changes
    */
-  public ConfigurationParameter[] setConfiguration(ConfigurationParameter[] parms) throws com.gemstone.gemfire.admin.AdminException;
+  public ConfigurationParameter[] setConfiguration(ConfigurationParameter[] parms) throws org.apache.geode.admin.AdminException;
   
   /** Refreshes this member's configuration from the member or it's properties */
-  public void refreshConfig() throws com.gemstone.gemfire.admin.AdminException;
+  public void refreshConfig() throws org.apache.geode.admin.AdminException;
   
   /** 
    * Retrieves this members statistic resources. If the member is not running 
@@ -102,7 +102,7 @@ public interface SystemMember {
    * @return array of runtime statistic resources owned by this member
    * @since GemFire 5.7
    */
-  public StatisticResource[] getStat(String statisticsTypeName) throws com.gemstone.gemfire.admin.AdminException;
+  public StatisticResource[] getStat(String statisticsTypeName) throws org.apache.geode.admin.AdminException;
   
   /** 
    * Retrieves this members statistic resources. If the member is not running 
@@ -110,22 +110,22 @@ public interface SystemMember {
    *
    * @return array of runtime statistic resources owned by this member
    */
-  public StatisticResource[] getStats() throws com.gemstone.gemfire.admin.AdminException;
+  public StatisticResource[] getStats() throws org.apache.geode.admin.AdminException;
   
   /**
    * Returns whether or not this system member hosts a GemFire {@link
-   * com.gemstone.gemfire.cache.Cache Cache}.
+   * org.apache.geode.cache.Cache Cache}.
    *
    * @see #getCache
    */
   public boolean hasCache()
-    throws com.gemstone.gemfire.admin.AdminException;
+    throws org.apache.geode.admin.AdminException;
 
   /**
    * Returns an object that provides admin access to this member's cache.
    * If the member currently has no cache then <code>null</code> is returned.
    */
-  public SystemMemberCache getCache() throws com.gemstone.gemfire.admin.AdminException;
+  public SystemMemberCache getCache() throws org.apache.geode.admin.AdminException;
   
   /**
    * Returns the names of the membership roles filled by this member.
@@ -136,7 +136,7 @@ public interface SystemMember {
   public String[] getRoles();
   
   /**
-   * Returns the {@link com.gemstone.gemfire.distributed.DistributedMember}
+   * Returns the {@link org.apache.geode.distributed.DistributedMember}
    * that represents this system member.
    *
    * @return DistributedMember instance representing this system member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberBridgeServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberBridgeServer.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberBridgeServer.java
index bc95925..71fb7e1 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberBridgeServer.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberBridgeServer.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
+import org.apache.geode.cache.server.ServerLoadProbe;
 
 /**
  * Administrative interface that represents a CacheServer that
@@ -84,7 +84,7 @@ public interface SystemMemberBridgeServer {
    * <p>Setting a specific bind address will cause the bridge server to always
    * use this address and ignore any address specified by "server-bind-address"
    * or "bind-address" in the <code>gemfire.properties</code> file
-   * (see {@link com.gemstone.gemfire.distributed.DistributedSystem}
+   * (see {@link org.apache.geode.distributed.DistributedSystem}
    * for a description of these properties).
    * <p> A <code>null</code> value will be treated the same as the default "".
    * <p> The default value does not override the gemfire.properties. If you wish to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCache.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCache.java
index 8c178dd..2c194ca 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCache.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCache.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.RegionAttributes;
+import org.apache.geode.cache.RegionAttributes;
 
 /**
  * Administrative interface that represent's the {@link SystemMember}'s view
- * of its {@link com.gemstone.gemfire.cache.Cache}.
+ * of its {@link org.apache.geode.cache.Cache}.
  *
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberCache {
   // attributes
@@ -53,7 +53,7 @@ public interface SystemMemberCache {
    *         If a problem is encountered while setting the lock
    *         timeout 
    *
-   * @see com.gemstone.gemfire.cache.Cache#setLockTimeout
+   * @see org.apache.geode.cache.Cache#setLockTimeout
    */
   public void setLockTimeout(int seconds) throws AdminException;
   
@@ -70,13 +70,13 @@ public interface SystemMemberCache {
    *         If a problem is encountered while setting the lock
    *         lease
    *
-   * @see com.gemstone.gemfire.cache.Cache#setLockLease
+   * @see org.apache.geode.cache.Cache#setLockLease
    */
   public void setLockLease(int seconds) throws AdminException;
   
   /**
    * Gets the number of seconds a cache
-   * {@link com.gemstone.gemfire.cache.Region#get(Object) get} operation
+   * {@link org.apache.geode.cache.Region#get(Object) get} operation
    * can spend searching for a value before it times out.
    * The search includes any time spent loading the object.
    * When the search times out it causes the get to fail by throwing
@@ -91,7 +91,7 @@ public interface SystemMemberCache {
    *         If a problem is encountered while setting the search
    *         timeout 
    *
-   * @see com.gemstone.gemfire.cache.Cache#setSearchTimeout
+   * @see org.apache.geode.cache.Cache#setSearchTimeout
    */
   public void setSearchTimeout(int seconds) throws AdminException;
   /**
@@ -171,7 +171,7 @@ public interface SystemMemberCache {
    * Adds a new, unstarted cache server that will serve the contents
    * of this cache to clients.
    *
-   * @see com.gemstone.gemfire.cache.Cache#addCacheServer
+   * @see org.apache.geode.cache.Cache#addCacheServer
    *
    * @since GemFire 5.7
    */
@@ -183,7 +183,7 @@ public interface SystemMemberCache {
    * that this list will not be updated until {@link #refresh} is
    * called.
    *
-   * @see com.gemstone.gemfire.cache.Cache#getCacheServers
+   * @see org.apache.geode.cache.Cache#getCacheServers
    *
    * @since GemFire 5.7
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheEvent.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheEvent.java
index 4b1454c..dee9bc1 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheEvent.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.Operation;
+import org.apache.geode.cache.Operation;
 /**
  * An event that describes an operation on a cache.
  * Instances of this are delivered to a {@link SystemMemberCacheListener} when a
  * a cache is created or closed.
  *
  * @since GemFire 5.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberCacheEvent extends SystemMembershipEvent {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheListener.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheListener.java
index b46bdf0..0d258b6 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheListener.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheListener.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  * A listener whose callback methods can be used to track the lifecycle of
@@ -26,7 +26,7 @@ import com.gemstone.gemfire.cache.*;
  * @see AdminDistributedSystem#removeCacheListener
  *
  * @since GemFire 5.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberCacheListener {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheServer.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheServer.java
index 86097bb..daf2199 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheServer.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberCacheServer.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
+import org.apache.geode.cache.server.ServerLoadProbe;
 
 /**
  * Administrative interface that represents a {@link
- * com.gemstone.gemfire.cache.server.CacheServer CacheServer} that
+ * org.apache.geode.cache.server.CacheServer CacheServer} that
  * serves the contents of a system member's cache to clients. 
  *
  * @see SystemMemberCache#addCacheServer
  *
  * @since GemFire 5.7
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberCacheServer {
 
@@ -84,7 +84,7 @@ public interface SystemMemberCacheServer {
    * <p>Setting a specific bind address will cause the cache server to always
    * use this address and ignore any address specified by "server-bind-address"
    * or "bind-address" in the <code>gemfire.properties</code> file
-   * (see {@link com.gemstone.gemfire.distributed.DistributedSystem}
+   * (see {@link org.apache.geode.distributed.DistributedSystem}
    * for a description of these properties).
    * <p> A <code>null</code> value will be treated the same as the default "".
    * <p> The default value does not override the gemfire.properties. If you wish to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegion.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegion.java
index b55c21f..22acdcc 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegion.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 import java.io.File;
 
 /**
  * Administrative interface that represent's the {@link
  * SystemMember}'s view of one of its cache's {@link
- * com.gemstone.gemfire.cache.Region}s.  If the region in the remote
+ * org.apache.geode.cache.Region}s.  If the region in the remote
  * system member is closed or destroyed, the methods of
  * <code>SystemMemberRegion</code> will throw {@link
  * RegionNotFoundException}.
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberRegion {
   // attributes
   /**
    * Returns the name that identifies this region in its cache.
    *
-   * @see com.gemstone.gemfire.cache.Region#getName
+   * @see org.apache.geode.cache.Region#getName
    */
   public String getName();
   
@@ -43,7 +43,7 @@ public interface SystemMemberRegion {
    * Returns the full path name that identifies this region in its
    * cache.
    *
-   * @see com.gemstone.gemfire.cache.Region#getFullPath
+   * @see org.apache.geode.cache.Region#getFullPath
    */
   public String getFullPath();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegionEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegionEvent.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegionEvent.java
index c391263..2dd1ffd 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegionEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberRegionEvent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * An event that describes an operation on a region.
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.admin;
  * a region comes or goes.
  *
  * @since GemFire 5.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMemberRegionEvent extends SystemMemberCacheEvent {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
index 1e3e1aa..7ba99fb 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMemberType.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 //import java.io.*;
 
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.admin;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class SystemMemberType implements java.io.Serializable {
   private static final long serialVersionUID = 3284366994485749302L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipEvent.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipEvent.java
index c428043..9319de5 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipEvent.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 /**
  * An event that describes the distributed member originated this event.
  * Instances of this are delivered to a {@link SystemMembershipListener} when a
  * member has joined or left the distributed system.
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMembershipEvent {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipListener.java b/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipListener.java
index a8b8b3d..b1d6afe 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/SystemMembershipListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A listener whose callback methods are invoked when members join or
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.admin;
  * @see AdminDistributedSystem#addMembershipListener
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface SystemMembershipListener {
 
@@ -52,7 +52,7 @@ public interface SystemMembershipListener {
 //   /**
 //    * Invoked when a member broadcasts an informational message.
 //    *
-//    * @see com.gemstone.gemfire.distributed.DistributedSystem#fireInfoEvent
+//    * @see org.apache.geode.distributed.DistributedSystem#fireInfoEvent
 //    *
 //    * @since GemFire 4.0
 //    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/UnmodifiableConfigurationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/UnmodifiableConfigurationException.java b/geode-core/src/main/java/org/apache/geode/admin/UnmodifiableConfigurationException.java
index a73b0bf..e89fc96 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/UnmodifiableConfigurationException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/UnmodifiableConfigurationException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * An <code>UnmodifiableConfigurationException</code> is thrown when an attempt
@@ -24,7 +24,7 @@ package com.gemstone.gemfire.admin;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class UnmodifiableConfigurationException extends AdminException {
 private static final long serialVersionUID = -7653547392992060646L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/AbstractHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/AbstractHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/AbstractHealthEvaluator.java
index 4b6505f..1a98c99 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/AbstractHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/AbstractHealthEvaluator.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * The abstract superclass of all GemFire health evaluators.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
index 25dce1d..aba79d2 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/AdminDistributedSystemImpl.java
@@ -14,32 +14,32 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.admin.Alert;
-import com.gemstone.gemfire.admin.AlertListener;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.FutureCancelledException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.Banner;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.admin.remote.*;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
-import com.gemstone.gemfire.internal.util.concurrent.FutureResult;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.*;
+import org.apache.geode.admin.Alert;
+import org.apache.geode.admin.AlertListener;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.FutureCancelledException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.Banner;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.admin.remote.*;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterFactory;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.logging.log4j.LogWriterAppender;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.internal.util.concurrent.FutureResult;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
@@ -49,7 +49,7 @@ import java.text.SimpleDateFormat;
 import java.util.*;
 import java.util.concurrent.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Represents a GemFire distributed system for remote administration/management.
@@ -57,10 +57,10 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
  * @since GemFire     3.5
  */
 public class AdminDistributedSystemImpl
-implements com.gemstone.gemfire.admin.AdminDistributedSystem,
-           com.gemstone.gemfire.internal.admin.JoinLeaveListener,
-           com.gemstone.gemfire.internal.admin.AlertListener,
-           com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DisconnectListener {
+implements org.apache.geode.admin.AdminDistributedSystem,
+           org.apache.geode.internal.admin.JoinLeaveListener,
+           org.apache.geode.internal.admin.AlertListener,
+           org.apache.geode.distributed.internal.InternalDistributedSystem.DisconnectListener {
 
   private static final Logger logger = LogService.getLogger();
   
@@ -200,7 +200,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
   
   /**
    * Creates DistributionLocator instances for every locator entry in the
-   * {@link com.gemstone.gemfire.admin.DistributedSystemConfig}
+   * {@link org.apache.geode.admin.DistributedSystemConfig}
    */
   private void initializeDistributionLocators() {
     DistributionLocatorConfig[] configs =
@@ -224,7 +224,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
   /**
    * Creates <code>CacheServer</code> instances for every cache server
    * entry in the {@link
-   * com.gemstone.gemfire.admin.DistributedSystemConfig}
+   * org.apache.geode.admin.DistributedSystemConfig}
    */
   private void initializeCacheServers() {
     CacheServerConfig[] cacheServerConfigs =
@@ -616,7 +616,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    * @return array of system members for each non-manager member
    */
   public SystemMember[] getSystemMemberApplications()
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     synchronized(this.applicationSet) {
       Collection coll = new ArrayList(this.applicationSet.size());
       APPS: for (Iterator iter = this.applicationSet.iterator();
@@ -682,7 +682,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    * <p>
    *
    * See {@link
-   * com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
+   * org.apache.geode.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
    *
    * @param logWriter the InternalLogWriter to use for any logging
@@ -864,7 +864,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
   /** 
    * Closes all connections and resources to the connected distributed system.
    *
-   * @see com.gemstone.gemfire.distributed.DistributedSystem#disconnect()
+   * @see org.apache.geode.distributed.DistributedSystem#disconnect()
    */
   public void disconnect() {
     synchronized (CONNECTION_SYNC) {
@@ -1035,7 +1035,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
   /** sync to prevent bug 33341 Admin API can double-represent system members */
   private final Object membershipListenerLock = new Object();
   
-  // --------- com.gemstone.gemfire.internal.admin.JoinLeaveListener ---------
+  // --------- org.apache.geode.internal.admin.JoinLeaveListener ---------
   /** 
    * Listener callback for when a member has joined this DistributedSystem.
    * <p>
@@ -1046,7 +1046,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    *
    * @param source  the distributed system that fired nodeJoined
    * @param vm  the VM that joined
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeJoined
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeJoined
    */
   public void nodeJoined(GfManagerAgent source, final GemFireVM vm) {
     // sync to prevent bug 33341 Admin API can double-represent system members
@@ -1151,7 +1151,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    *
    * @param source  the distributed system that fired nodeCrashed
    * @param vm    the VM that left
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeLeft
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeLeft
    */
   public void nodeLeft(GfManagerAgent source, GemFireVM vm) {
     // sync to prevent bug 33341 Admin API can double-represent system members
@@ -1182,7 +1182,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    *
    * @param source  the distributed system that fired nodeCrashed
    * @param vm the VM that crashed
-   * @see com.gemstone.gemfire.internal.admin.JoinLeaveListener#nodeCrashed
+   * @see org.apache.geode.internal.admin.JoinLeaveListener#nodeCrashed
    */
   public void nodeCrashed(GfManagerAgent source, GemFireVM vm) {
     // sync to prevent bug 33341 Admin API can double-represent system members
@@ -1207,15 +1207,15 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
     }
   }
 
-  // ----------- com.gemstone.gemfire.internal.admin.AlertListener -----------
+  // ----------- org.apache.geode.internal.admin.AlertListener -----------
   /** 
    * Listener callback for when a SystemMember of this DistributedSystem has 
    * crashed. 
    *
    * @param alert   the latest alert from the system
-   * @see com.gemstone.gemfire.internal.admin.AlertListener#alert
+   * @see org.apache.geode.internal.admin.AlertListener#alert
    */
-  public void alert(com.gemstone.gemfire.internal.admin.Alert alert) {
+  public void alert(org.apache.geode.internal.admin.Alert alert) {
     if (AlertLevel.forSeverity(alert.getLevel()).ordinal < alertLevel.ordinal) {
       return;
     }
@@ -1255,7 +1255,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    *  @throws AdminException TODO-javadocs
    */
   protected SystemMember createSystemMember(ApplicationVM app)
-  throws com.gemstone.gemfire.admin.AdminException {
+  throws org.apache.geode.admin.AdminException {
     return new SystemMemberImpl(this, app);
   }
 
@@ -1267,12 +1267,12 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    *          InternalDistributedMember instance for which a SystemMember
    *          instance is to be constructed.
    * @return constructed SystemMember instance
-   * @throws com.gemstone.gemfire.admin.AdminException
+   * @throws org.apache.geode.admin.AdminException
    *           if construction of SystemMember instance fails
    * @since GemFire 6.5
    */
   protected SystemMember createSystemMember(InternalDistributedMember member)
-    throws com.gemstone.gemfire.admin.AdminException {
+    throws org.apache.geode.admin.AdminException {
     return new SystemMemberImpl(this, member);
   }
 
@@ -2099,7 +2099,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
    */
   public class AlertImpl implements Alert {
     /** The Alert to which most behavior is delegated */
-    private final com.gemstone.gemfire.internal.admin.Alert alert;
+    private final org.apache.geode.internal.admin.Alert alert;
     private SystemMember systemMember;
 
     ///////////////////////  Constructors  ///////////////////////
@@ -2108,7 +2108,7 @@ implements com.gemstone.gemfire.admin.AdminDistributedSystem,
      * Creates a new <code>Alert</code> that delegates to the given
      * object. 
      */
-    AlertImpl(com.gemstone.gemfire.internal.admin.Alert alert) {
+    AlertImpl(org.apache.geode.internal.admin.Alert alert) {
       this.alert   = alert;
       GemFireVM vm = alert.getGemFireVM();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
index 58a66bc..0d68f02 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.File;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.Assert;
 
 public class BackupDataStoreHelper {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
index b939f75..b2a201d 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
 
 public class BackupDataStoreResult {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
index 33faed0..074ecb3 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.io.Serializable;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.admin.BackupStatus;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.admin.BackupStatus;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Holds the result of a backup operation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
index 59be648..fd82b24 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
+import org.apache.geode.admin.*;
 
 /**
  * The implementation of <code>CacheHealthConfig</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
index 67f39f7..6ab9f34 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.admin.CacheHealthConfig;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.cache.CacheLifecycleListener;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.admin.CacheHealthConfig;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.cache.CacheLifecycleListener;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Contains the logic for evaluating the health of a GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
index eb5b646..e34a476 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.CacheServerConfig;
-import com.gemstone.gemfire.admin.CacheVmConfig;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
+import org.apache.geode.admin.CacheServerConfig;
+import org.apache.geode.admin.CacheVmConfig;
+import org.apache.geode.internal.admin.GemFireVM;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * An implementation of <code>CacheVmConfig</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
index 325c943..f13c9ba 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.remote.RemoteApplicationVM;
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.remote.RemoteApplicationVM;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Implements the administrative interface to a cache server.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterImpl.java
index a6f86c5..e556b04 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterImpl.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.admin.UnmodifiableConfigurationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.ConfigurationParameter;
+import org.apache.geode.admin.UnmodifiableConfigurationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.File;
 //import java.net.InetAddress;
@@ -34,7 +34,7 @@ import java.util.List;
  *
  */
 public class ConfigurationParameterImpl
-implements com.gemstone.gemfire.admin.ConfigurationParameter {
+implements org.apache.geode.admin.ConfigurationParameter {
   
   /** Identifying name of this configuration parameter */
   protected String name;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
index c2f23e4..b9102d6 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.ConfigurationParameter;
+import org.apache.geode.admin.ConfigurationParameter;
 
 /**
  * Listens to value changes of a 
- * {@link com.gemstone.gemfire.admin.ConfigurationParameter}.  This is for 
+ * {@link org.apache.geode.admin.ConfigurationParameter}.  This is for 
  * internal use only to allow a {@link SystemMemberImpl} to keep track of 
  * configuration changes made through 
  * {@link ConfigurationParameterImpl#setValue}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DisabledManagedEntityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DisabledManagedEntityController.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DisabledManagedEntityController.java
index 709af32..8450991 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DisabledManagedEntityController.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DisabledManagedEntityController.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This is a disabled implementation of ManagedEntityController for bug #47909.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
index 517f5a6..f3e31a5 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemConfigImpl.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogConfig;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.admin.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogConfig;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterImpl;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
@@ -32,7 +32,7 @@ import java.io.IOException;
 import java.io.InputStream;
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * An implementation of the configuration object for an

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthConfigImpl.java
index 25ee3e3..b7a2057 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthConfigImpl.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.*;
+import org.apache.geode.admin.*;
 
 /**
  * The implementation of <code>DistributedSystemHealthConfig</code>.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
index 33989a8..287de7f 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthEvaluator.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.DistributedSystemHealthConfig;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.admin.DistributedSystemHealthConfig;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.List;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthMonitor.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthMonitor.java
index 54e7de7..c091157 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributedSystemHealthMonitor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -23,37 +23,37 @@ import java.util.Properties;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.GemFireMemberStatus;
-import com.gemstone.gemfire.admin.RegionSubRegionSnapshot;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.Config;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.admin.CacheInfo;
-import com.gemstone.gemfire.internal.admin.DLockInfo;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.admin.GfManagerAgent;
-import com.gemstone.gemfire.internal.admin.HealthListener;
-import com.gemstone.gemfire.internal.admin.Stat;
-import com.gemstone.gemfire.internal.admin.StatAlertDefinition;
-import com.gemstone.gemfire.internal.admin.StatListener;
-import com.gemstone.gemfire.internal.admin.StatResource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.GemFireMemberStatus;
+import org.apache.geode.admin.RegionSubRegionSnapshot;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.Config;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.AdminBridgeServer;
+import org.apache.geode.internal.admin.CacheInfo;
+import org.apache.geode.internal.admin.DLockInfo;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.admin.GfManagerAgent;
+import org.apache.geode.internal.admin.HealthListener;
+import org.apache.geode.internal.admin.Stat;
+import org.apache.geode.internal.admin.StatAlertDefinition;
+import org.apache.geode.internal.admin.StatListener;
+import org.apache.geode.internal.admin.StatResource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A thread that monitors the health of the distributed system.  It is
  * kind of like a {@link
- * com.gemstone.gemfire.distributed.internal.HealthMonitorImpl}.  In
+ * org.apache.geode.distributed.internal.HealthMonitorImpl}.  In
  * order to get it to place nice with the rest of the health
  * monitoring APIs, this class pretends that it is a
  * <code>GemFireVM</code>.  Kind of hokey, but it beats a bunch of
@@ -218,7 +218,7 @@ class DistributedSystemHealthMonitor implements Runnable, GemFireVM {
       return SocketCreator.getLocalHost();
 
     } catch (Exception ex) {
-      throw new com.gemstone.gemfire.InternalGemFireException(LocalizedStrings.DistributedSystemHealthMonitor_COULD_NOT_GET_LOCALHOST.toLocalizedString());
+      throw new org.apache.geode.InternalGemFireException(LocalizedStrings.DistributedSystemHealthMonitor_COULD_NOT_GET_LOCALHOST.toLocalizedString());
     }
   }
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorConfigImpl.java
index 88d939a..71cd0af 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorConfigImpl.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
+package org.apache.geode.admin.internal;
 
-import com.gemstone.gemfire.admin.DistributionLocator;
-import com.gemstone.gemfire.admin.DistributionLocatorConfig;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.DistributionLocator;
+import org.apache.geode.admin.DistributionLocatorConfig;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.net.InetAddress;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_PORT;
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
 
 /**
  * Provides an implementation of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
index bda1b59..d8ad205 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/DistributionLocatorImpl.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.DistributionLocator;
-import com.gemstone.gemfire.admin.DistributionLocatorConfig;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.DistributionLocator;
+import org.apache.geode.admin.DistributionLocatorConfig;
+import org.apache.geode.admin.ManagedEntityConfig;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java b/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
index ff139c5..3216793 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/EnabledManagedEntityController.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.DistributedSystemConfig;
-import com.gemstone.gemfire.admin.ManagedEntity;
-import com.gemstone.gemfire.admin.ManagedEntityConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.ProcessOutputReader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.admin.internal;
+
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.admin.DistributedSystemConfig;
+import org.apache.geode.admin.ManagedEntity;
+import org.apache.geode.admin.ManagedEntityConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.ProcessOutputReader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
 import java.util.Iterator;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Implements the actual administration (starting, stopping, etc.) of



[35/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
index a14dda8..6eab0e0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
@@ -18,15 +18,15 @@
  * Abstract Super class of the Group or Range Junction. The common functionality
  * of Group or Range Junction is present in this class.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
index 7b64af7..eae4796 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
@@ -17,18 +17,18 @@
 /*
  * Created on Oct 25, 2005
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
 
 /**
  * An object of this class gets created during the organization of operands in a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
index 7016075..80b01b9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.lang.reflect.AccessibleObject;
 import java.lang.reflect.Field;
@@ -30,17 +30,17 @@ import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
 
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.query.NameNotFoundException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializationException;
-import com.gemstone.gemfire.pdx.internal.FieldNotFoundInPdxVersion;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
-import com.gemstone.gemfire.pdx.JSONFormatter;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.query.NameNotFoundException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializationException;
+import org.apache.geode.pdx.internal.FieldNotFoundInPdxVersion;
+import org.apache.geode.pdx.internal.PdxInstanceImpl;
+import org.apache.geode.pdx.JSONFormatter;
 
 /**
  * Utility for managing an attribute
@@ -91,7 +91,7 @@ public class AttributeDescriptor {
     Support.Assert(target != null);
     Support.Assert(target != QueryService.UNDEFINED);
     Member m;
-    if (target.getClass().getName().startsWith("com.gemstone.gemfire.internal.cache.Token$")) {
+    if (target.getClass().getName().startsWith("org.apache.geode.internal.cache.Token$")) {
       return QueryService.UNDEFINED;
     } else {
       m = getReadMember(resolutionClass);
@@ -99,7 +99,7 @@ public class AttributeDescriptor {
     try {
       if (m instanceof Method) {
         try {
-          if (target.getClass().getName().startsWith("com.gemstone.gemfire.internal.cache.Token$")) {
+          if (target.getClass().getName().startsWith("org.apache.geode.internal.cache.Token$")) {
             return QueryService.UNDEFINED;
           } else {            
             return ((Method)m).invoke(target, (Object[])null);
@@ -123,7 +123,7 @@ public class AttributeDescriptor {
         }
       } else {
         try {
-          if (target.getClass().getName().startsWith("com.gemstone.gemfire.internal.cache.Token$")) {
+          if (target.getClass().getName().startsWith("org.apache.geode.internal.cache.Token$")) {
             return QueryService.UNDEFINED;
           } else {
             return ((Field)m).get(target);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
index 15ca6bb..f4baa03 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -29,18 +29,18 @@ import java.util.List;
 import java.util.NoSuchElementException;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.CqResults;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.internal.ObjectIntHashMap.Entry;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.CqResults;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.internal.ObjectIntHashMap.Entry;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 // @todo probably should assert element type when elements added
 // @todo support generics when no longer support Java 1.4

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
index 87f29fa..f49ef52 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
-
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.aggregate.AvgBucketNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.AvgDistinct;
-import com.gemstone.gemfire.cache.query.internal.aggregate.AvgDistinctPRQueryNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.AvgPRQueryNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.Count;
-import com.gemstone.gemfire.cache.query.internal.aggregate.CountDistinct;
-import com.gemstone.gemfire.cache.query.internal.aggregate.CountDistinctPRQueryNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.SumDistinctPRQueryNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.CountPRQueryNode;
-import com.gemstone.gemfire.cache.query.internal.aggregate.DistinctAggregator;
-import com.gemstone.gemfire.cache.query.internal.aggregate.MaxMin;
-import com.gemstone.gemfire.cache.query.internal.aggregate.Avg;
-import com.gemstone.gemfire.cache.query.internal.aggregate.Sum;
-import com.gemstone.gemfire.cache.query.internal.aggregate.SumDistinct;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
+package org.apache.geode.cache.query.internal;
+
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.aggregate.AvgBucketNode;
+import org.apache.geode.cache.query.internal.aggregate.AvgDistinct;
+import org.apache.geode.cache.query.internal.aggregate.AvgDistinctPRQueryNode;
+import org.apache.geode.cache.query.internal.aggregate.AvgPRQueryNode;
+import org.apache.geode.cache.query.internal.aggregate.Count;
+import org.apache.geode.cache.query.internal.aggregate.CountDistinct;
+import org.apache.geode.cache.query.internal.aggregate.CountDistinctPRQueryNode;
+import org.apache.geode.cache.query.internal.aggregate.SumDistinctPRQueryNode;
+import org.apache.geode.cache.query.internal.aggregate.CountPRQueryNode;
+import org.apache.geode.cache.query.internal.aggregate.DistinctAggregator;
+import org.apache.geode.cache.query.internal.aggregate.MaxMin;
+import org.apache.geode.cache.query.internal.aggregate.Avg;
+import org.apache.geode.cache.query.internal.aggregate.Sum;
+import org.apache.geode.cache.query.internal.aggregate.SumDistinct;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledBindArgument.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledBindArgument.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledBindArgument.java
index 3308cea..37d39a5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledBindArgument.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledBindArgument.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.TypeMismatchException;
 
 /**
  * Class Description

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
index 5c764e3..d8324d6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
@@ -14,33 +14,33 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.IndexData;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * Comparison value: <, >, <=, >=, <>, =

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledConstruction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledConstruction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledConstruction.java
index f2bdab7..3ec8df1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledConstruction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledConstruction.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.internal.Assert;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledFunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledFunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledFunction.java
index 1d76d86..dec4a26 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledFunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledFunction.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
index 59e228f..d287350 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Arrays;
 import java.util.BitSet;
@@ -25,22 +25,22 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.Aggregator;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.internal.utils.PDXUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.Aggregator;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.internal.utils.PDXUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledID.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledID.java
index 2f12c20..57b3df0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledID.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledID.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
index 42824df..e7c731e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.lang.reflect.Array;
 import java.util.ArrayList;
@@ -29,28 +29,28 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.IndexData;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * Class Description

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
index fca7e83..b789060 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.lang.reflect.Array;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIteratorDef.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIteratorDef.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIteratorDef.java
index 9f2d06d..b0b3efb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIteratorDef.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIteratorDef.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.parse.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.parse.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
index e238ca2..2612ba5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -27,23 +27,23 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Conjunctions and Disjunctions (LITERAL_and LITERAL_or) As a part of feature

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLike.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLike.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLike.java
index 241170f..25087d9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLike.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLike.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.regex.Pattern;
 
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.PrimaryKeyIndex;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.PrimaryKeyIndex;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLiteral.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLiteral.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLiteral.java
index f29d9d1..0705f53 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLiteral.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledLiteral.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 //import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.pdx.internal.PdxString;
-//import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.pdx.internal.PdxString;
+//import org.apache.geode.internal.Assert;
 
 /**
  * Class Description

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledNegation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledNegation.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledNegation.java
index 6d7e9b9..2a69f26 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledNegation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledNegation.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledOperation.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledOperation.java
index 99126ea..12fa01d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -25,21 +25,21 @@ import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
 
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializationException;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializationException;
+import org.apache.geode.pdx.internal.PdxInstanceImpl;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * Class Description
@@ -263,7 +263,7 @@ public class CompiledOperation extends AbstractCompiledValue {
       try {
         methodDispatch = new MethodDispatch(resolutionType, this.methodName, argTypes);
       } catch(NameResolutionException nre) {         
-        if (!com.gemstone.gemfire.cache.query.Struct.class.isAssignableFrom(resolutionType) &&
+        if (!org.apache.geode.cache.query.Struct.class.isAssignableFrom(resolutionType) &&
             (DefaultQueryService.QUERY_HETEROGENEOUS_OBJECTS ||
              DefaultQueryService.TEST_QUERY_HETEROGENEOUS_OBJECTS)) {
           return QueryService.UNDEFINED;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledPath.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledPath.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledPath.java
index eb29d7c..7266094 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledPath.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledPath.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledRegion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledRegion.java
index aa51b5e..2299282 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledRegion.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.LocalDataSet;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.LocalDataSet;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
index f01a6cb..9c80930 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -22,34 +22,34 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.NameNotFoundException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex;
-import com.gemstone.gemfire.cache.query.internal.index.PartitionedIndex;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.NameNotFoundException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.AbstractIndex;
+import org.apache.geode.cache.query.internal.index.PartitionedIndex;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * Class Description

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSortCriterion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSortCriterion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSortCriterion.java
index 473e65b..f6b23c0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSortCriterion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSortCriterion.java
@@ -15,24 +15,24 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.GemFireCacheException;
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexInvalidException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.GemFireCacheException;
+import org.apache.geode.GemFireException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexInvalidException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This class represents a compiled form of sort criterian present in order by

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
index 8d27418..f920848 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
index 98f301c..7b7242a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.IndexInfo;
-import com.gemstone.gemfire.cache.query.internal.index.IndexData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.IndexInfo;
+import org.apache.geode.cache.query.internal.index.IndexData;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
 
 /**
  * Predefined function for identity of the UNDEFINED literal

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledValue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledValue.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledValue.java
index b31a4f6..5fe341b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledValue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledValue.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.util.List;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompositeGroupJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompositeGroupJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompositeGroupJunction.java
index d2f9469..9877d78 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompositeGroupJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompositeGroupJunction.java
@@ -18,7 +18,7 @@
  * Created on Nov 18, 2005
  *
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -27,16 +27,16 @@ import java.util.LinkedList;
 import java.util.List;
 import java.util.SortedSet;
 import java.util.TreeSet;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.SelectResultsComparator;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.SelectResultsComparator;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
 
 /**
  * An object of this class gets created during the organization of operands in a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqEntry.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqEntry.java
index bba284b..48f04de 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqEntry.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqQueryVsdStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqQueryVsdStats.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqQueryVsdStats.java
index e65af17..c94091a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqQueryVsdStats.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqQueryVsdStats.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.cache.query.CqEvent;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.cache.query.CqEvent;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.tier.MessageType;
 
 /**
- * This class tracks GemFire statistics related to a {@link com.gemstone.gemfire.cache.query.CqQuery}.
+ * This class tracks GemFire statistics related to a {@link org.apache.geode.cache.query.CqQuery}.
  * 
  * @since GemFire 5.5
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
index 17c7099..25d858f 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.query.CqState;
+import org.apache.geode.cache.query.CqState;
 
 /**
  * Offers methods to get CQ state.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/CumulativeNonDistinctResults.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CumulativeNonDistinctResults.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CumulativeNonDistinctResults.java
index c7be13e..7401bfa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CumulativeNonDistinctResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CumulativeNonDistinctResults.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,21 +27,21 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.utils.LimitIterator;
-import com.gemstone.gemfire.cache.query.internal.utils.PDXUtils;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.HeapDataOutputStream.LongUpdater;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.utils.LimitIterator;
+import org.apache.geode.cache.query.internal.utils.PDXUtils;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.HeapDataOutputStream.LongUpdater;
+import org.apache.geode.internal.Version;
 
 /**
  * This is used as a wrapper over all the results of PR which are of non

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQuery.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQuery.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQuery.java
index 665c5a4..58df390 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQuery.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQuery.java
@@ -15,31 +15,31 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.ServerProxy;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.cache.query.internal;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.ServerProxy;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 import java.util.concurrent.atomic.AtomicLong;
 
 
 /**
- * Thread-safe implementation of com.gemstone.persistence.query.Query
+ * Thread-safe implementation of org.apache.persistence.query.Query
  *
  */
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
index cbfc051..7a43a79 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
@@ -14,31 +14,31 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
-
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.client.internal.InternalPool;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.ServerProxy;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.cq.ClientCQ;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.cache.query.internal.index.*;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.InternalCache;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.cache.query.internal;
+
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.client.internal.InternalPool;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.ServerProxy;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.cq.ClientCQ;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.cache.query.internal.index.*;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.InternalCache;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;
@@ -82,7 +82,7 @@ public class DefaultQueryService implements QueryService {
    * 
    * @return The new <code>Query</code> object.
    * @throws IllegalArgumentException if the query syntax is invalid.
-   * @see com.gemstone.gemfire.cache.query.Query
+   * @see org.apache.geode.cache.query.Query
    */
   public Query newQuery(String queryString) {
     if (QueryMonitor.isLowMemory()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/DerivedInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DerivedInfo.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DerivedInfo.java
index a934524..f7c9453 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DerivedInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DerivedInfo.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.HashMap;
@@ -26,19 +26,19 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.PartitionedIndex;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.AbstractIndex;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.PartitionedIndex;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
 
 public class DerivedInfo {
   public Map<String, SelectResults> derivedResults;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
index 391c028..32679a5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * This is used to carry the state of a query or index update operation. A state
@@ -94,7 +94,7 @@ public class ExecutionContext {
    * current iteration element. Used to implement the "this" var in the query
    * shortcut methods
    * 
-   * @see com.gemstone.gemfire.cache.Region#query
+   * @see org.apache.geode.cache.Region#query
    */
   public ExecutionContext(Object[] bindArguments, Cache cache) {
     this.bindArguments = bindArguments;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
index d6d5000..7e90e0c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.List;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.cache.query.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
 
 /**
  * Class Description

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Functions.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Functions.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Functions.java
index 45f0902..8e7d55a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Functions.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Functions.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 import java.text.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/GroupJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/GroupJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/GroupJunction.java
index 353d48e..09b4846 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/GroupJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/GroupJunction.java
@@ -17,14 +17,14 @@
 /*
  * Created on Oct 25, 2005
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.List;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
 
 /**
  * This structure contains the filter evaluable and iter evaluable

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
index 18514a1..021c31e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexInfo.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexInfo.java
index 35be578..9681657 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexInfo.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.AbstractIndex;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
 
 public class IndexInfo
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
index e92e7ca..1650269 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
@@ -18,7 +18,7 @@
 //  IndexTrackingQueryObserver.java
 //  gemfire
 //
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenHashMap;
 
@@ -29,10 +29,10 @@ import java.util.Map;
 import java.util.Map.Entry;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.internal.index.CompactMapRangeIndex;
-import com.gemstone.gemfire.cache.query.internal.index.MapRangeIndex;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionQueryEvaluator.TestHook;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.internal.index.CompactMapRangeIndex;
+import org.apache.geode.cache.query.internal.index.MapRangeIndex;
+import org.apache.geode.internal.cache.PartitionedRegionQueryEvaluator.TestHook;
 
 /**
  * Verbose Index information

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
index 8405b86..6ee76bd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.TypeMismatchException;
 
 /**
  * Interface implemented by CompiledComparision and CompiledUndefibed to



[41/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/Region.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Region.java b/geode-core/src/main/java/org/apache/geode/cache/Region.java
index f70e5de..72333a1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Region.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Region.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -27,17 +27,17 @@ import java.util.Set;
 import java.util.concurrent.ConcurrentMap;
 import java.util.concurrent.locks.Lock;
 
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.SubscriptionNotEnabledException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.SubscriptionNotEnabledException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.snapshot.RegionSnapshotService;
 
 /** Manages subregions and cached data. Each region
  * can contain multiple subregions and entries for data.
@@ -49,10 +49,10 @@ import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
  * The Region interface basically contains two set of APIs: Region management
  * APIs; and (potentially) distributed operations on entries. Non-distributed
  * operations on entries
- * are provided by the inner interface, {@link com.gemstone.gemfire.cache.Region.Entry}.
+ * are provided by the inner interface, {@link org.apache.geode.cache.Region.Entry}.
  * <p>
  *
- * Each {@link com.gemstone.gemfire.cache.Cache} defines a single top region called the root region.
+ * Each {@link org.apache.geode.cache.Cache} defines a single top region called the root region.
  * User applications can use the root region to create subregions
  * for isolated name space and object grouping.
  * <p>
@@ -241,7 +241,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * <p>
    * Does not update any <code>CacheStatistics</code>.
    *
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @see CacheListener#afterRegionInvalidate
    */
@@ -257,7 +257,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * Does not update any <code>CacheStatistics</code>.
    * @param aCallbackArgument a user-defined parameter to pass to callback events
    *        triggered by this method. Can be null. Should be serializable.
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for <code>Scope.GLOBAL</code>
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for <code>Scope.GLOBAL</code>
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @throws IllegalArgumentException if aCallbackArgument is not serializable
    * @see CacheListener#afterRegionInvalidate
@@ -313,7 +313,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    *
    * @throws CacheWriterException if a CacheWriter aborts the operation; if this
    *         occurs some subregions may have already been successfully destroyed.
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @see CacheListener#afterRegionDestroy
    * @see CacheWriter#beforeRegionDestroy
@@ -334,7 +334,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    *        triggered by this method. Can be null. Should be serializable.
    * @throws CacheWriterException if a CacheWriter aborts the operation; if this
    *         occurs some subregions may have already been successfully destroyed.
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws IllegalArgumentException if aCallbackArgument is not serializable
    * @see CacheListener#afterRegionDestroy
@@ -455,7 +455,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws CacheWriterException if a CacheWriter aborts the destroyRegion
    *         operation; if this occurs some subregions may have already been
    *         successfully destroyed.
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws UnsupportedOperationException If the region is a partitioned region
    *
@@ -499,7 +499,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    *         <a href="AttributesFactory.html#creationConstraints">region creation constraints</a>
    *         with a region of the same name in another cache in the distributed system
    *         or with this (parent) region.
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws RegionExistsException if a subregion by the specified name already exists
    * @throws UnsupportedOperationException If the region is a partitioned region
@@ -580,7 +580,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if the key is null
    * @throws IllegalArgumentException if the key does not meet
    *         the serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out doing a {@link Cache#getSearchTimeout search} for distributed or getting a distributed lock for Scope.GLOBAL
    * @throws CacheLoaderException if a cache loader throws an exception, or if
    *         the cache loader returns an object that is not serializable and this
@@ -642,7 +642,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * is not found and can't be loaded
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if aCallbackArgument is not serializable
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out doing a {@link Cache#getSearchTimeout search} for distributed or getting a distributed lock for Scope.GLOBAL
    * @throws CacheLoaderException if a cache loader throws an exception, or if
    *         the cache loader returns an object that is not serializable and this
@@ -682,7 +682,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    *         is null (use invalidate instead), or if the key or value do not
    *         meet serializability requirements
    * @throws ClassCastException if key does not satisfy the keyConstraint
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.
@@ -727,7 +727,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws IllegalArgumentException if key, value, or
    *         aCallbackArgument do not meet serializability requirements
    * @throws ClassCastException if key does not satisfy the keyConstraint
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.
@@ -762,7 +762,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws IllegalArgumentException if the key or value
    *         is not serializable and this is a distributed region
    * @throws ClassCastException if key does not satisfy the keyConstraint
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @throws EntryExistsException if an entry with this key already exists
    * @throws CacheWriterException if a CacheWriter aborts the operation
@@ -799,7 +799,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws IllegalArgumentException if the key, value, or
    *         aCallbackArgument do not meet serializability requirements
    * @throws ClassCastException if key does not satisfy the keyConstraint
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @throws EntryExistsException if an entry with this key already exists
    * @throws CacheWriterException if a CacheWriter aborts the operation
@@ -826,7 +826,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if the key does not
    *         meet serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @throws EntryNotFoundException if the entry does not exist in this region
    * @see CacheListener#afterInvalidate
@@ -848,7 +848,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if the key or the
    *         aCallbackArgument do not meet serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for <code>Scope.GLOBAL</code>
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for <code>Scope.GLOBAL</code>
    * @throws TimeoutException if timed out getting distributed lock for <code>Scope.GLOBAL</code>
    * @throws EntryNotFoundException if this entry does not exist in this region
    * @see CacheListener#afterInvalidate
@@ -923,7 +923,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if key does not meet
    *         serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws EntryNotFoundException if the entry does not exist in this region
    * @throws CacheWriterException if a CacheWriter aborts the operation
@@ -959,7 +959,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if the key or aCallbackArgument
    *         do not meet serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws EntryNotFoundException if the entry does not exist in this region
    * @throws CacheWriterException if a CacheWriter aborts the operation
@@ -1574,7 +1574,7 @@ public interface Region<K,V>  extends ConcurrentMap<K, V> {
    * @throws NullPointerException if key is null
    * @throws IllegalArgumentException if key does not meet
    *         serializability requirements
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @see Region#destroy(Object)
@@ -2193,7 +2193,7 @@ public boolean containsKeyOnServer(Object key);
   *         and this map does not permit null keys or values
   * @throws IllegalArgumentException if some property of the specified key
   *         or value prevents it from being stored in this map
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.
@@ -2227,7 +2227,7 @@ public boolean containsKeyOnServer(Object key);
   *         type for this map (optional)
   * @throws NullPointerException if the specified key or value is null,
   *         and this map does not permit null keys or values (optional)
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.
@@ -2263,7 +2263,7 @@ public boolean containsKeyOnServer(Object key);
   *         and this map does not permit null keys
   * @throws IllegalArgumentException if some property of a specified key
   *         or value prevents it from being stored in this map
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.
@@ -2299,7 +2299,7 @@ public boolean containsKeyOnServer(Object key);
   *         and this map does not permit null keys or values
   * @throws IllegalArgumentException if some property of the specified key
   *         or value prevents it from being stored in this map
-   * @throws com.gemstone.gemfire.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheWriterException if a CacheWriter aborts the operation
    * @throws PartitionedRegionStorageException if the operation could not be completed on a partitioned region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionAccessException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionAccessException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionAccessException.java
index 9d9ebd8..017f2d7 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionAccessException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionAccessException.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.membership.InternalRole;
 
 /**
  * Indicates that an attempt to access the region has failed.  Failure is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/RegionAttributes.java
index b0d09fa..8435842 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionAttributes.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.File;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.compression.Compressor;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.compression.Compressor;
 
 /** Defines attributes for configuring a region.
  * These are <code>EvictionAttributes</code>,
@@ -39,7 +39,7 @@ import com.gemstone.gemfire.compression.Compressor;
  * @see AttributesFactory
  * @see AttributesMutator
  * @see Region#getAttributes
- * @see com.gemstone.gemfire.cache.EvictionAttributes
+ * @see org.apache.geode.cache.EvictionAttributes
  * @since GemFire 2.0
  */
 public interface RegionAttributes<K,V> {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionDestroyedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionDestroyedException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionDestroyedException.java
index e518444..5c173eb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionDestroyedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionDestroyedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that the region has been destroyed. Further operations

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionDistributionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionDistributionException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionDistributionException.java
index 81ee2b7..d5ab10c 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionDistributionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionDistributionException.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.membership.InternalRole;
 
 /**
  * Indicates that an attempt to send a distributed cache event to one or more
  * {@link MembershipAttributes#getRequiredRoles required roles} may have
  * failed.  Failure may be caused by departure of one or more required roles
  * while sending the message to them.  If the region scope is {@linkplain 
- * com.gemstone.gemfire.cache.Scope#DISTRIBUTED_NO_ACK DISTRIBUTED_NO_ACK} or
- * {@linkplain com.gemstone.gemfire.cache.Scope#GLOBAL GLOBAL} then failure
+ * org.apache.geode.cache.Scope#DISTRIBUTED_NO_ACK DISTRIBUTED_NO_ACK} or
+ * {@linkplain org.apache.geode.cache.Scope#GLOBAL GLOBAL} then failure
  * may be caused by one or more required roles not acknowledging receipt of
  * the message.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionEvent.java b/geode-core/src/main/java/org/apache/geode/cache/RegionEvent.java
index 08365d5..8cb0488 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionEvent.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Contains information about an event affecting a region, including
  * its identity and the circumstances of the event.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionExistsException.java
index 91225ec..288dfe3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionExistsException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that the requested region already exists when a region is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/RegionFactory.java
index 4fe8ee2..e4fb914 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionFactory.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.File;
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.distributed.LeaseExpiredException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.distributed.LeaseExpiredException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * <code>RegionFactory</code> is used to create {@link Region regions}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionMembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionMembershipListener.java b/geode-core/src/main/java/org/apache/geode/cache/RegionMembershipListener.java
index c4bd33e..beef65f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionMembershipListener.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * A listener that can be implemented to handle region membership events.
  * 
  * <p>
  * Instead of implementing this interface it is recommended that you extend
- * the {@link com.gemstone.gemfire.cache.util.RegionMembershipListenerAdapter} class.
+ * the {@link org.apache.geode.cache.util.RegionMembershipListenerAdapter} class.
  * 
  * 
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionReinitializedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionReinitializedException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionReinitializedException.java
index 48079ea..d4f2841 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionReinitializedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionReinitializedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that the region has been reinitialized. Further operations

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionRoleException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionRoleException.java b/geode-core/src/main/java/org/apache/geode/cache/RegionRoleException.java
index 6e1c8db..4d12507 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionRoleException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionRoleException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that a {@link Region} reliability failure has occurred.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionRoleListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionRoleListener.java b/geode-core/src/main/java/org/apache/geode/cache/RegionRoleListener.java
index 96df589..589d1b3 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionRoleListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionRoleListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * A listener that can be implemented to handle region reliability membership 
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.cache;
  * required roles as defined by the region's {@link MembershipAttributes}.
  * <p>
  * Instead of implementing this interface it is recommended that you extend
- * the {@link com.gemstone.gemfire.cache.util.RegionRoleListenerAdapter} 
+ * the {@link org.apache.geode.cache.util.RegionRoleListenerAdapter} 
  * class.
  * 
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionService.java b/geode-core/src/main/java/org/apache/geode/cache/RegionService.java
index 186c41d..594e8b9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionService.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Properties;
 import java.util.Set;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxInstanceFactory;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxInstanceFactory;
 
 /**
  * A RegionService provides access to existing {@link Region regions} that exist

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RegionShortcut.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RegionShortcut.java b/geode-core/src/main/java/org/apache/geode/cache/RegionShortcut.java
index e9c5bb4..f61bcf1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/RegionShortcut.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RegionShortcut.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Each enum represents a predefined {@link RegionAttributes} in a {@link Cache}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RemoteTransactionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RemoteTransactionException.java b/geode-core/src/main/java/org/apache/geode/cache/RemoteTransactionException.java
index 060ffa5..0ce0398 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RemoteTransactionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RemoteTransactionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that an unexpected runtime exception occurred

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RequiredRoles.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RequiredRoles.java b/geode-core/src/main/java/org/apache/geode/cache/RequiredRoles.java
index a56a749..0f32716 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RequiredRoles.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RequiredRoles.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
@@ -29,7 +29,7 @@ import java.util.*;
  * required roles. Configuration of required roles is accomplished using the
  * <code>Region</code>'s {@link MembershipAttributes}. 
  *
- * A {@link com.gemstone.gemfire.distributed.Role Role} may be present in the
+ * A {@link org.apache.geode.distributed.Role Role} may be present in the
  * distributed system even if it the <code>Role</code> is not present in the
  * <code>Region</code> membership. This would occur if none of the members
  * filling that <code>Role</code> currently have a <code>Cache</code> or the
@@ -37,7 +37,7 @@ import java.util.*;
  * considered to be absent for that <code>Region</code>.
  *
  * @deprecated this feature is scheduled to be removed
- * @see com.gemstone.gemfire.distributed.Role
+ * @see org.apache.geode.distributed.Role
  */
 public class RequiredRoles {
   
@@ -93,7 +93,7 @@ public class RequiredRoles {
   }
   
   /**
-   * Returns true if the {@link com.gemstone.gemfire.distributed.Role Role}
+   * Returns true if the {@link org.apache.geode.distributed.Role Role}
    * is currently present in the {@link Region} membership. This returns true
    * only if one or more members filling this role actually have the region
    * currently created. The role may be present in the distributed system even

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/ResourceException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ResourceException.java b/geode-core/src/main/java/org/apache/geode/cache/ResourceException.java
index 8670f0d..e5cc0c5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/ResourceException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ResourceException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * A Generic exception to indicate that a resource exception has occurred.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/ResumptionAction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ResumptionAction.java b/geode-core/src/main/java/org/apache/geode/cache/ResumptionAction.java
index 4201dce..164348b 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/ResumptionAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ResumptionAction.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.util.*;
@@ -25,7 +25,7 @@ import java.util.*;
  * Specifies how the region is affected by resumption of reliability when
  * one or more missing required roles return to the distributed membership.  
  * The <code>ResumptionAction</code> is specified when configuring a region's 
- * {@link com.gemstone.gemfire.cache.MembershipAttributes}.
+ * {@link org.apache.geode.cache.MembershipAttributes}.
  * 
  * @deprecated this API is scheduled to be removed
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RoleEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RoleEvent.java b/geode-core/src/main/java/org/apache/geode/cache/RoleEvent.java
index 734843d..88b9a2b 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RoleEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RoleEvent.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/RoleException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/RoleException.java b/geode-core/src/main/java/org/apache/geode/cache/RoleException.java
index 467469a..524e556 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/RoleException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/RoleException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * <code>RoleException</code> is the superclass of those exceptions

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/Scope.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Scope.java b/geode-core/src/main/java/org/apache/geode/cache/Scope.java
index 0ea7fa5..dcf79ef 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Scope.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Scope.java
@@ -16,9 +16,9 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/SerializedCacheValue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/SerializedCacheValue.java b/geode-core/src/main/java/org/apache/geode/cache/SerializedCacheValue.java
index 3976693..4ba30e2 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/SerializedCacheValue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/SerializedCacheValue.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Class <code>SerializedCacheValue</code> represents a serialized cache value.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/StatisticsDisabledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/StatisticsDisabledException.java b/geode-core/src/main/java/org/apache/geode/cache/StatisticsDisabledException.java
index d2d4d35..bb31ca4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/StatisticsDisabledException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/StatisticsDisabledException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Thrown if statistics are requested when statistics are disabled on the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
index 2e10da8..c7e1e46 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/SubscriptionAttributes.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 import java.io.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/SynchronizationCommitConflictException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/SynchronizationCommitConflictException.java b/geode-core/src/main/java/org/apache/geode/cache/SynchronizationCommitConflictException.java
index aea1f8f..721ee2a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/SynchronizationCommitConflictException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/SynchronizationCommitConflictException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown when a commit operation of a JTA enlisted cache transaction fails
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TimeoutException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TimeoutException.java b/geode-core/src/main/java/org/apache/geode/cache/TimeoutException.java
index f04f3d8..4cb21ca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TimeoutException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TimeoutException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown if a <code>netSearch</code> times out without getting a response back from a cache,
  * or when attempting to acquire a distributed lock.
@@ -23,15 +23,15 @@ package com.gemstone.gemfire.cache;
  *
  *
  * @see LoaderHelper#netSearch
- * @see com.gemstone.gemfire.cache.Region#invalidateRegion()
- * @see com.gemstone.gemfire.cache.Region#destroyRegion()
+ * @see org.apache.geode.cache.Region#invalidateRegion()
+ * @see org.apache.geode.cache.Region#destroyRegion()
  * @see Region#createSubregion
- * @see com.gemstone.gemfire.cache.Region#get(Object)
- * @see com.gemstone.gemfire.cache.Region#put(Object, Object)
- * @see com.gemstone.gemfire.cache.Region#create(Object, Object)
- * @see com.gemstone.gemfire.cache.Region#invalidate(Object)
- * @see com.gemstone.gemfire.cache.Region#destroy(Object)
- * @see com.gemstone.gemfire.distributed.DistributedLockService
+ * @see org.apache.geode.cache.Region#get(Object)
+ * @see org.apache.geode.cache.Region#put(Object, Object)
+ * @see org.apache.geode.cache.Region#create(Object, Object)
+ * @see org.apache.geode.cache.Region#invalidate(Object)
+ * @see org.apache.geode.cache.Region#destroy(Object)
+ * @see org.apache.geode.distributed.DistributedLockService
  * @since GemFire 3.0
  */
 public class TimeoutException extends OperationAbortedException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNodeHasDepartedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNodeHasDepartedException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNodeHasDepartedException.java
index 40465f6..cfe9e02 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNodeHasDepartedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNodeHasDepartedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Thrown when the transactional data host has shutdown or no longer has the data

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNotColocatedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNotColocatedException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNotColocatedException.java
index 09428af..50dafe6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNotColocatedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataNotColocatedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that an attempt was made to transactionally modify multiple keys that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionDataRebalancedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataRebalancedException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataRebalancedException.java
index 1d61b74..f82fdae 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionDataRebalancedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionDataRebalancedException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.cache.control.RebalanceOperation;
+import org.apache.geode.cache.control.RebalanceOperation;
 
 /**
  * Thrown when a {@link RebalanceOperation} occurs concurrently with a transaction.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionEvent.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionEvent.java
index 5bf0c56..856e8be 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionEvent.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 import java.util.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionException.java
index ef0999d..7c022aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * This is the superclass for all Exceptions that may be thrown

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionId.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionId.java
index 230a649..87cee7c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionId.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionId.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.Externalizable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionInDoubtException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionInDoubtException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionInDoubtException.java
index 7718b0c..e67d3a7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionInDoubtException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionInDoubtException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * This Exception is thrown in presence of node failures, when GemFire cannot

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionListener.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionListener.java
index 9cbc5f8..1555357 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionListener.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * <p>A listener that can be implemented to handle transaction related

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriter.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriter.java
index 848b39b..f071d24 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
index 0a0b182..f59eb38 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/UnsupportedOperationInTransactionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/UnsupportedOperationInTransactionException.java b/geode-core/src/main/java/org/apache/geode/cache/UnsupportedOperationInTransactionException.java
index d460d12..1afa16f 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/UnsupportedOperationInTransactionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/UnsupportedOperationInTransactionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates that an attempt was mode to invoke an operation that is not

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/UnsupportedVersionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/UnsupportedVersionException.java b/geode-core/src/main/java/org/apache/geode/cache/UnsupportedVersionException.java
index 29cde1b..28bb032 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/UnsupportedVersionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/UnsupportedVersionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * An <code>UnsupportedVersionException</code> indicates an unsupported version.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/VersionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/VersionException.java b/geode-core/src/main/java/org/apache/geode/cache/VersionException.java
index 59208cc..d497a68 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/VersionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/VersionException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * An <code>VersionException</code> is an exception that indicates

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEvent.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEvent.java
index 9e05334..6d20fb2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEvent.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue;
+package org.apache.geode.cache.asyncqueue;
 
-import com.gemstone.gemfire.cache.wan.EventSequenceID;
-import com.gemstone.gemfire.cache.wan.GatewayQueueEvent;
+import org.apache.geode.cache.wan.EventSequenceID;
+import org.apache.geode.cache.wan.GatewayQueueEvent;
 
 /**
  * Represents <code>Cache</code> events delivered to <code>AsyncEventListener</code>.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventListener.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventListener.java
index b8661b5..7b0811c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventListener.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.asyncqueue;
+package org.apache.geode.cache.asyncqueue;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 /**
  * A callback for events passing through the <code>AsyncEventQueue</code> to which this

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
index 85ca392..b0658e4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue;
+package org.apache.geode.cache.asyncqueue;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
-import com.gemstone.gemfire.cache.wan.GatewayEventSubstitutionFilter;
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.cache.wan.GatewayEventFilter;
+import org.apache.geode.cache.wan.GatewayEventSubstitutionFilter;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
 
 /**
  * Interface of AsyncEventQueue. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
index 3540ce3..3087b12 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue;
+package org.apache.geode.cache.asyncqueue;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
-import com.gemstone.gemfire.cache.wan.GatewayEventSubstitutionFilter;
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
-import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
+import org.apache.geode.cache.wan.GatewayEventFilter;
+import org.apache.geode.cache.wan.GatewayEventSubstitutionFilter;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.cache.wan.GatewaySenderFactory;
 
 /**
  * Factory to create the <code>AsyncEventQueue</code>. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java
index f658621..663a565 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueFactoryImpl.java
@@ -14,31 +14,31 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue.internal;
+package org.apache.geode.cache.asyncqueue.internal;
 
-import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueConfigurationException;
+import org.apache.geode.internal.cache.wan.AsyncEventQueueConfigurationException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueueFactory;
-import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
-import com.gemstone.gemfire.cache.wan.GatewayEventSubstitutionFilter;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
-import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAttributes;
-import com.gemstone.gemfire.internal.cache.xmlcache.AsyncEventQueueCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.ParallelAsyncEventQueueCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.ParallelGatewaySenderCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.SerialAsyncEventQueueCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.SerialGatewaySenderCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.asyncqueue.AsyncEventListener;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueueFactory;
+import org.apache.geode.cache.wan.GatewayEventFilter;
+import org.apache.geode.cache.wan.GatewayEventSubstitutionFilter;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.cache.wan.GatewaySenderFactory;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.wan.GatewaySenderAttributes;
+import org.apache.geode.internal.cache.xmlcache.AsyncEventQueueCreation;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.internal.cache.xmlcache.ParallelAsyncEventQueueCreation;
+import org.apache.geode.internal.cache.xmlcache.ParallelGatewaySenderCreation;
+import org.apache.geode.internal.cache.xmlcache.SerialAsyncEventQueueCreation;
+import org.apache.geode.internal.cache.xmlcache.SerialGatewaySenderCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 public class AsyncEventQueueFactoryImpl implements AsyncEventQueueFactory {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueImpl.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueImpl.java
index 994bbfc..1a9e893 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueImpl.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue.internal;
+package org.apache.geode.cache.asyncqueue.internal;
 
 import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.wan.GatewayEventFilter;
-import com.gemstone.gemfire.cache.wan.GatewayEventSubstitutionFilter;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
-import com.gemstone.gemfire.internal.cache.RegionQueue;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.serial.ConcurrentSerialGatewaySenderEventProcessor;
+import org.apache.geode.cache.asyncqueue.AsyncEventListener;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.wan.GatewayEventFilter;
+import org.apache.geode.cache.wan.GatewayEventSubstitutionFilter;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.internal.cache.RegionQueue;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.serial.ConcurrentSerialGatewaySenderEventProcessor;
 
 public class AsyncEventQueueImpl implements AsyncEventQueue {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueStats.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueStats.java
index e9e1e0b..61eeca9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueStats.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/AsyncEventQueueStats.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue.internal;
+package org.apache.geode.cache.asyncqueue.internal;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderStats;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.wan.GatewaySenderStats;
 
 public class AsyncEventQueueStats extends GatewaySenderStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/ParallelAsyncEventQueueImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/ParallelAsyncEventQueueImpl.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/ParallelAsyncEventQueueImpl.java
index 4b708b8..e24a070 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/ParallelAsyncEventQueueImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/ParallelAsyncEventQueueImpl.java
@@ -14,35 +14,35 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue.internal;
+package org.apache.geode.cache.asyncqueue.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.EntryOperation;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
-import com.gemstone.gemfire.cache.wan.GatewayTransportFilter;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ResourceEvent;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.cache.UpdateAttributesProcessor;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAttributes;
-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.GatewaySenderAdvisor.GatewaySenderProfile;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.EntryOperation;
+import org.apache.geode.cache.asyncqueue.AsyncEventListener;
+import org.apache.geode.cache.wan.GatewayTransportFilter;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.cache.UpdateAttributesProcessor;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderAttributes;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
+import org.apache.geode.internal.cache.wan.GatewaySenderAdvisor.GatewaySenderProfile;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class ParallelAsyncEventQueueImpl extends AbstractGatewaySender {
   
@@ -190,7 +190,7 @@ public class ParallelAsyncEventQueueImpl extends AbstractGatewaySender {
     pf.manualStart = isManualStart();
     pf.dispatcherThreads = getDispatcherThreads();
     pf.orderPolicy = getOrderPolicy();
-    for (com.gemstone.gemfire.cache.wan.GatewayEventFilter filter : getGatewayEventFilters()) {
+    for (org.apache.geode.cache.wan.GatewayEventFilter filter : getGatewayEventFilters()) {
       pf.eventFiltersClassNames.add(filter.getClass().getName());
     }
     for (GatewayTransportFilter filter : getGatewayTransportFilters()) {
@@ -203,7 +203,7 @@ public class ParallelAsyncEventQueueImpl extends AbstractGatewaySender {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender#setModifiedEventId(com.gemstone.gemfire.internal.cache.EntryEventImpl)
+   * @see org.apache.geode.internal.cache.wan.AbstractGatewaySender#setModifiedEventId(org.apache.geode.internal.cache.EntryEventImpl)
    */
   @Override
   protected void setModifiedEventId(EntryEventImpl clonedEvent) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/SerialAsyncEventQueueImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/SerialAsyncEventQueueImpl.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/SerialAsyncEventQueueImpl.java
index 16ffbde..fe3581f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/SerialAsyncEventQueueImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/internal/SerialAsyncEventQueueImpl.java
@@ -14,37 +14,37 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.asyncqueue.internal;
+package org.apache.geode.cache.asyncqueue.internal;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
-import com.gemstone.gemfire.cache.wan.GatewayTransportFilter;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ResourceEvent;
-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.RegionQueue;
-import com.gemstone.gemfire.internal.cache.UpdateAttributesProcessor;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAdvisor.GatewaySenderProfile;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAttributes;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderConfigurationException;
-import com.gemstone.gemfire.internal.cache.wan.serial.ConcurrentSerialGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.serial.SerialGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.serial.SerialGatewaySenderQueue;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.asyncqueue.AsyncEventListener;
+import org.apache.geode.cache.wan.GatewayTransportFilter;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.RegionQueue;
+import org.apache.geode.internal.cache.UpdateAttributesProcessor;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderAdvisor.GatewaySenderProfile;
+import org.apache.geode.internal.cache.wan.GatewaySenderAttributes;
+import org.apache.geode.internal.cache.wan.GatewaySenderConfigurationException;
+import org.apache.geode.internal.cache.wan.serial.ConcurrentSerialGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.serial.SerialGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.serial.SerialGatewaySenderQueue;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class SerialAsyncEventQueueImpl extends AbstractGatewaySender {
 
@@ -219,7 +219,7 @@ public class SerialAsyncEventQueueImpl extends AbstractGatewaySender {
     pf.isPersistenceEnabled = isPersistenceEnabled();
     pf.alertThreshold = getAlertThreshold();
     pf.manualStart = isManualStart();
-    for (com.gemstone.gemfire.cache.wan.GatewayEventFilter filter : getGatewayEventFilters()) {
+    for (org.apache.geode.cache.wan.GatewayEventFilter filter : getGatewayEventFilters()) {
       pf.eventFiltersClassNames.add(filter.getClass().getName());
     }
     for (GatewayTransportFilter filter : getGatewayTransportFilters()) {
@@ -235,7 +235,7 @@ public class SerialAsyncEventQueueImpl extends AbstractGatewaySender {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender#setModifiedEventId(com.gemstone.gemfire.internal.cache.EntryEventImpl)
+   * @see org.apache.geode.internal.cache.wan.AbstractGatewaySender#setModifiedEventId(org.apache.geode.internal.cache.EntryEventImpl)
    */
   @Override
   protected void setModifiedEventId(EntryEventImpl clonedEvent) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/AllConnectionsInUseException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/AllConnectionsInUseException.java b/geode-core/src/main/java/org/apache/geode/cache/client/AllConnectionsInUseException.java
index d294ba0..22c7824 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/AllConnectionsInUseException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/AllConnectionsInUseException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ClientCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientCache.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientCache.java
index b00d1a2..bdc945e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientCache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientCache.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client;
+package org.apache.geode.cache.client;
 
 import java.net.InetSocketAddress;
 import java.util.Properties;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * A ClientCache instance controls the life cycle of the local singleton cache in a client. 
@@ -160,7 +160,7 @@ public interface ClientCache extends GemFireCache {
    * Returns the default server pool. If one or more non-default pools were
    * configured, this may return null.
    * @since GemFire 7.0
-   * @see com.gemstone.gemfire.cache.client.Pool
+   * @see org.apache.geode.cache.client.Pool
    */
   public Pool getDefaultPool();
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/ClientCacheFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientCacheFactory.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientCacheFactory.java
index 96dcde3..0a6ecb0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientCacheFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientCacheFactory.java
@@ -15,28 +15,28 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client;
-
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.cache.CacheConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+package org.apache.geode.cache.client;
+
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.cache.CacheConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializer;
 
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_PORT;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
 
 /**
- * Factory class used to create the singleton {@link ClientCache client cache} and connect to one or more GemFire Cache Servers. If the application wants to connect to GemFire as a peer it should use {@link com.gemstone.gemfire.cache.CacheFactory} instead.
+ * Factory class used to create the singleton {@link ClientCache client cache} and connect to one or more GemFire Cache Servers. If the application wants to connect to GemFire as a peer it should use {@link org.apache.geode.cache.CacheFactory} instead.
  * <p> Once the factory has been configured using its set* methods you produce a {@link ClientCache} by calling the {@link #create} method.
- * The {@link com.gemstone.gemfire.distributed.ConfigurationProperties#CACHE_XML_FILE}
+ * The {@link org.apache.geode.distributed.ConfigurationProperties#CACHE_XML_FILE}
  * property can be used to specify a cache.xml file to initialize the cache with.
  * The contents of this file must comply with the
  * <code>"doc-files/cache8_0.dtd"</code> file and the top level element must be a <code>client-cache</code> element.
@@ -138,7 +138,7 @@ public class ClientCacheFactory {
    *
    * @param props The initial gemfire properties to be used.
    *              These properties can be overridden using the {@link #set} method
-   *              For a full list of valid gemfire properties see {@link com.gemstone.gemfire.distributed.ConfigurationProperties}.
+   *              For a full list of valid gemfire properties see {@link org.apache.geode.distributed.ConfigurationProperties}.
    */
   public ClientCacheFactory(Properties props) {
     if (props == null) {
@@ -149,7 +149,7 @@ public class ClientCacheFactory {
 
   /**
    * Sets a gemfire property that will be used when creating the ClientCache.
-   * For a full list of valid gemfire properties see {@link com.gemstone.gemfire.distributed.ConfigurationProperties}.
+   * For a full list of valid gemfire properties see {@link org.apache.geode.distributed.ConfigurationProperties}.
    *
    * @param name  the name of the gemfire property
    * @param value the value of the gemfire property
@@ -559,7 +559,7 @@ public class ClientCacheFactory {
    * By default setPRSingleHopEnabled is <code>true</code>
    * in which case the client is aware of the location of partitions on servers hosting
    * {@link Region regions} with
-   * {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}.
+   * {@link org.apache.geode.cache.DataPolicy#PARTITION}.
    * Using this information, the client routes the client cache operations
    * directly to the server which is hosting the required partition for the
    * cache operation using a single network hop.
@@ -572,9 +572,9 @@ public class ClientCacheFactory {
    * to go to the required partition for that cache operation.
    * The client will use fewer network connections to the servers.
    * <p>
-   * Caution: for {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION partition} regions
+   * Caution: for {@link org.apache.geode.cache.DataPolicy#PARTITION partition} regions
    * with
-   * {@link com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int) local-max-memory}
+   * {@link org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int) local-max-memory}
    * equal to zero, no cache operations mentioned above will be routed to those
    * servers as they do not host any partitions.
    *
@@ -646,7 +646,7 @@ public class ClientCacheFactory {
    *  @param pdxReadSerialized true to prefer PdxInstance
    *  @return this ClientCacheFactory
    *  @since GemFire 6.6
-   *  @see com.gemstone.gemfire.pdx.PdxInstance 
+   *  @see org.apache.geode.pdx.PdxInstance 
    */
   public ClientCacheFactory setPdxReadSerialized(boolean pdxReadSerialized) {
     this.cacheConfig.setPdxReadSerialized(pdxReadSerialized);



[33/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
index 50eb07b..abed999 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.Aggregator;
+import org.apache.geode.cache.query.Aggregator;
 
 /**
  * Computes the count of the rows on the PR query node

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/DistinctAggregator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/DistinctAggregator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/DistinctAggregator.java
index 2720897..8cd84b5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/DistinctAggregator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/DistinctAggregator.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * The class used to hold the distinct values. This will get instantiated on the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/MaxMin.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/MaxMin.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/MaxMin.java
index b643c9c..ee98649 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/MaxMin.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/MaxMin.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.Aggregator;
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.Aggregator;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Computes the Max or Min

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Sum.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Sum.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Sum.java
index 96f80b8..387929a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Sum.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Sum.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Computes the sum for replicated & PR based queries.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinct.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinct.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinct.java
index 57c2a9a..b166170 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinct.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinct.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 /**
  * Computes the sum of distinct values for replicated region based queries.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinctPRQueryNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinctPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinctPRQueryNode.java
index bee5df2..174c0e6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinctPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/SumDistinctPRQueryNode.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
index 44d6ed9..50a1729 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
-import com.gemstone.gemfire.cache.client.internal.Connection;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.query.CqClosedException;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.CqQuery;
+import org.apache.geode.cache.client.internal.Connection;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.query.CqClosedException;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.CqQuery;
 
 public interface ClientCQ extends InternalCqQuery  {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
index cab855e..4e176aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
 import java.io.Serializable;
 import java.util.ArrayList;
@@ -22,14 +22,14 @@ import java.util.Arrays;
 import java.util.Iterator;
 import java.util.List;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheCallback;
-import com.gemstone.gemfire.cache.query.CqAttributes;
-import com.gemstone.gemfire.cache.query.CqAttributesMutator;
-import com.gemstone.gemfire.cache.query.CqListener;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheCallback;
+import org.apache.geode.cache.query.CqAttributes;
+import org.apache.geode.cache.query.CqAttributesMutator;
+import org.apache.geode.cache.query.CqListener;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 import org.apache.logging.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
index d6fba13..0faa845 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
@@ -14,31 +14,31 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
 import java.util.Collection;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.internal.InternalPool;
-import com.gemstone.gemfire.cache.client.internal.QueueManager;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.query.CqAttributes;
-import com.gemstone.gemfire.cache.query.CqClosedException;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.CqExistsException;
-import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.cache.query.CqServiceStatistics;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.internal.InternalPool;
+import org.apache.geode.cache.client.internal.QueueManager;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.query.CqAttributes;
+import org.apache.geode.cache.query.CqClosedException;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.CqExistsException;
+import org.apache.geode.cache.query.CqQuery;
+import org.apache.geode.cache.query.CqServiceStatistics;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.FilterRoutingInfo;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 public interface CqService {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqServiceProvider.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqServiceProvider.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqServiceProvider.java
index d31ec8a..1f1c0e9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqServiceProvider.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqServiceProvider.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
-import com.gemstone.gemfire.cache.query.internal.cq.spi.CqServiceFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.cache.query.internal.cq.spi.CqServiceFactory;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 import java.io.DataInput;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
index eea22ab..310da6d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
-import com.gemstone.gemfire.cache.query.CqClosedException;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.cache.query.CqState;
-import com.gemstone.gemfire.cache.query.internal.CqQueryVsdStats;
-import com.gemstone.gemfire.cache.query.internal.CqStateImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
+import org.apache.geode.cache.query.CqClosedException;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.CqQuery;
+import org.apache.geode.cache.query.CqState;
+import org.apache.geode.cache.query.internal.CqQueryVsdStats;
+import org.apache.geode.cache.query.internal.CqStateImpl;
+import org.apache.geode.internal.cache.LocalRegion;
 
 public interface InternalCqQuery extends CqQuery {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqService.java
index 3299947..bade4af 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqService.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -22,24 +22,24 @@ import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.internal.InternalPool;
-import com.gemstone.gemfire.cache.client.internal.QueueManager;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.query.CqAttributes;
-import com.gemstone.gemfire.cache.query.CqClosedException;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.CqExistsException;
-import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.cache.query.CqServiceStatistics;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.internal.InternalPool;
+import org.apache.geode.cache.client.internal.QueueManager;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.query.CqAttributes;
+import org.apache.geode.cache.query.CqClosedException;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.CqExistsException;
+import org.apache.geode.cache.query.CqQuery;
+import org.apache.geode.cache.query.CqServiceStatistics;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.FilterRoutingInfo;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 public class MissingCqService implements CqService {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqServiceStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqServiceStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqServiceStatistics.java
index da69d3a..cf98d0b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqServiceStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/MissingCqServiceStatistics.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
-import com.gemstone.gemfire.cache.query.CqServiceStatistics;
+import org.apache.geode.cache.query.CqServiceStatistics;
 
 public class MissingCqServiceStatistics implements CqServiceStatistics {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
index e956bd5..ad8e8b1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq;
+package org.apache.geode.cache.query.internal.cq;
 
-import com.gemstone.gemfire.cache.query.CqClosedException;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.cache.query.CqClosedException;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 public interface ServerCQ extends InternalCqQuery {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/spi/CqServiceFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/spi/CqServiceFactory.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/spi/CqServiceFactory.java
index 4df0b77..16781c6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/spi/CqServiceFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/spi/CqServiceFactory.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.cq.spi;
+package org.apache.geode.cache.query.internal.cq.spi;
 
 import java.io.DataInput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.ServerCQ;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.ServerCQ;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 public interface CqServiceFactory {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractIndex.java
index 6c0d509..32a6d19 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractIndex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -30,56 +30,56 @@ import java.util.concurrent.locks.ReentrantReadWriteLock;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.Bag;
-import com.gemstone.gemfire.cache.query.internal.CompiledID;
-import com.gemstone.gemfire.cache.query.internal.CompiledIndexOperation;
-import com.gemstone.gemfire.cache.query.internal.CompiledIteratorDef;
-import com.gemstone.gemfire.cache.query.internal.CompiledOperation;
-import com.gemstone.gemfire.cache.query.internal.CompiledPath;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.CqEntry;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.IndexInfo;
-import com.gemstone.gemfire.cache.query.internal.QRegion;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.QueryUtils;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.StructFields;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.cache.query.internal.Support;
-import com.gemstone.gemfire.cache.query.internal.index.IndexStore.IndexStoreEntry;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-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.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.Bag;
+import org.apache.geode.cache.query.internal.CompiledID;
+import org.apache.geode.cache.query.internal.CompiledIndexOperation;
+import org.apache.geode.cache.query.internal.CompiledIteratorDef;
+import org.apache.geode.cache.query.internal.CompiledOperation;
+import org.apache.geode.cache.query.internal.CompiledPath;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.CqEntry;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.IndexInfo;
+import org.apache.geode.cache.query.internal.QRegion;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.QueryUtils;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.StructFields;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.index.IndexStore.IndexStoreEntry;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * This class implements abstract algorithms common to all indexes, such as

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
index 355bb6d..bfd5551 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -24,25 +24,25 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.MapIndexable;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.MapIndexable;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.RegionEntry;
 
 public abstract class AbstractMapIndex extends AbstractIndex
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactMapRangeIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactMapRangeIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactMapRangeIndex.java
index c374a10..850b13d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactMapRangeIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactMapRangeIndex.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.Map;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.RegionEntry;
 
 public class CompactMapRangeIndex extends AbstractMapIndex
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
index ecfafb1..d5dd5a6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashSet;
@@ -25,51 +25,51 @@ import java.util.Map;
 import java.util.NoSuchElementException;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledBindArgument;
-import com.gemstone.gemfire.cache.query.internal.CompiledIteratorDef;
-import com.gemstone.gemfire.cache.query.internal.CompiledLiteral;
-import com.gemstone.gemfire.cache.query.internal.CompiledPath;
-import com.gemstone.gemfire.cache.query.internal.CompiledSortCriterion;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.CqEntry;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.IndexInfo;
-import com.gemstone.gemfire.cache.query.internal.QRegion;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.QueryObserver;
-import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
-import com.gemstone.gemfire.cache.query.internal.QueryUtils;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.cache.query.internal.Support;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
-import com.gemstone.gemfire.cache.query.internal.index.IndexStore.IndexStoreEntry;
-import com.gemstone.gemfire.cache.query.internal.index.MemoryIndexStore.MemoryIndexStoreEntry;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.RegionEntryContext;
-import com.gemstone.gemfire.internal.cache.VMThinRegionEntryHeap;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledBindArgument;
+import org.apache.geode.cache.query.internal.CompiledIteratorDef;
+import org.apache.geode.cache.query.internal.CompiledLiteral;
+import org.apache.geode.cache.query.internal.CompiledPath;
+import org.apache.geode.cache.query.internal.CompiledSortCriterion;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.CqEntry;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.IndexInfo;
+import org.apache.geode.cache.query.internal.QRegion;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.QueryObserver;
+import org.apache.geode.cache.query.internal.QueryObserverHolder;
+import org.apache.geode.cache.query.internal.QueryUtils;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.index.IndexManager.TestHook;
+import org.apache.geode.cache.query.internal.index.IndexStore.IndexStoreEntry;
+import org.apache.geode.cache.query.internal.index.MemoryIndexStore.MemoryIndexStoreEntry;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.RegionEntryContext;
+import org.apache.geode.internal.cache.VMThinRegionEntryHeap;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 //@todo Extend to support the keys or entries of a region.
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/DummyQRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/DummyQRegion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/DummyQRegion.java
index aae26fd..79cf0cb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/DummyQRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/DummyQRegion.java
@@ -20,7 +20,7 @@
  * Created on March 15, 2005, 6:40 PM
  */
 
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -28,22 +28,22 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.internal.QRegion;
-import com.gemstone.gemfire.cache.query.internal.ResultsBag;
-import com.gemstone.gemfire.cache.query.internal.ResultsSet;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.RegionEntryContext;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.internal.QRegion;
+import org.apache.geode.cache.query.internal.ResultsBag;
+import org.apache.geode.cache.query.internal.ResultsSet;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.RegionEntryContext;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
index 60f1954..9cb43c9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
@@ -19,7 +19,7 @@
  *
  * Created on March 16, 2005, 6:20 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -27,34 +27,34 @@ import java.util.Collections;
 import java.util.List;
 
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.IndexInvalidException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledBindArgument;
-import com.gemstone.gemfire.cache.query.internal.CompiledComparison;
-import com.gemstone.gemfire.cache.query.internal.CompiledFunction;
-import com.gemstone.gemfire.cache.query.internal.CompiledID;
-import com.gemstone.gemfire.cache.query.internal.CompiledIndexOperation;
-import com.gemstone.gemfire.cache.query.internal.CompiledIteratorDef;
-import com.gemstone.gemfire.cache.query.internal.CompiledLiteral;
-import com.gemstone.gemfire.cache.query.internal.CompiledNegation;
-import com.gemstone.gemfire.cache.query.internal.CompiledOperation;
-import com.gemstone.gemfire.cache.query.internal.CompiledPath;
-import com.gemstone.gemfire.cache.query.internal.CompiledRegion;
-import com.gemstone.gemfire.cache.query.internal.CompiledUndefined;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.MapIndexable;
-import com.gemstone.gemfire.cache.query.internal.QRegion;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.IndexInvalidException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledBindArgument;
+import org.apache.geode.cache.query.internal.CompiledComparison;
+import org.apache.geode.cache.query.internal.CompiledFunction;
+import org.apache.geode.cache.query.internal.CompiledID;
+import org.apache.geode.cache.query.internal.CompiledIndexOperation;
+import org.apache.geode.cache.query.internal.CompiledIteratorDef;
+import org.apache.geode.cache.query.internal.CompiledLiteral;
+import org.apache.geode.cache.query.internal.CompiledNegation;
+import org.apache.geode.cache.query.internal.CompiledOperation;
+import org.apache.geode.cache.query.internal.CompiledPath;
+import org.apache.geode.cache.query.internal.CompiledRegion;
+import org.apache.geode.cache.query.internal.CompiledUndefined;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.MapIndexable;
+import org.apache.geode.cache.query.internal.QRegion;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
index d28b166..775daec 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenHashMap;
 
@@ -33,56 +33,56 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.AttributeDescriptor;
-import com.gemstone.gemfire.cache.query.internal.CompiledComparison;
-import com.gemstone.gemfire.cache.query.internal.CompiledIteratorDef;
-import com.gemstone.gemfire.cache.query.internal.CompiledPath;
-import com.gemstone.gemfire.cache.query.internal.CompiledSortCriterion;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.CqEntry;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.IndexInfo;
-import com.gemstone.gemfire.cache.query.internal.QRegion;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.QueryObserver;
-import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
-import com.gemstone.gemfire.cache.query.internal.QueryUtils;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.Support;
-import com.gemstone.gemfire.cache.query.internal.index.HashIndex.IMQEvaluator.HashIndexComparator;
-import com.gemstone.gemfire.cache.query.internal.index.IndexStore.IndexStoreEntry;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.AttributeDescriptor;
+import org.apache.geode.cache.query.internal.CompiledComparison;
+import org.apache.geode.cache.query.internal.CompiledIteratorDef;
+import org.apache.geode.cache.query.internal.CompiledPath;
+import org.apache.geode.cache.query.internal.CompiledSortCriterion;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.CqEntry;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.IndexInfo;
+import org.apache.geode.cache.query.internal.QRegion;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.QueryObserver;
+import org.apache.geode.cache.query.internal.QueryObserverHolder;
+import org.apache.geode.cache.query.internal.QueryUtils;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.index.HashIndex.IMQEvaluator.HashIndexComparator;
+import org.apache.geode.cache.query.internal.index.IndexStore.IndexStoreEntry;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * A HashIndex is an index that can be used for equal and not equals queries It

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
index 55cbac1..a5e9873 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
@@ -20,7 +20,7 @@
  * They are based from add(), contains() and other methods from ObjectOpenHashSet
  * We have used the traversing mechanism and the HashCommon.mix()
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import static it.unimi.dsi.fastutil.HashCommon.arraySize;
 import it.unimi.dsi.fastutil.HashCommon;
@@ -31,11 +31,11 @@ import java.util.Iterator;
 import java.util.NoSuchElementException;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * An implementation of the <tt>Set</tt> interface for the HashIndex

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
index e716668..e82d7eb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
@@ -20,9 +20,9 @@
  * Created on March 8, 2005, 6:11 PM
  */
 
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
-import com.gemstone.gemfire.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryException;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
index 95a2613..8b209c2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
@@ -17,11 +17,11 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 
-import com.gemstone.gemfire.internal.concurrent.CompactConcurrentHashSet2;
+import org.apache.geode.internal.concurrent.CompactConcurrentHashSet2;
 
 /**
  * This class overrides the size method to make it non-blocking for our query

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationData.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationData.java
index 87d945a..a6e2f17 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationData.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationData.java
@@ -19,16 +19,16 @@
  *
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.List;
 
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationHelper.java
index 0ca43b5..c9e2951 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexCreationHelper.java
@@ -19,15 +19,15 @@
  *
  * Created on March 20, 2005, 8:26 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
index 85b39ab..c2bef60 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
index 3cf4cbf..5b31312 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Arrays;
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
index 8ef82f1..4dcd1c3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
@@ -19,20 +19,20 @@
  *
  * Created on February 15, 2005, 11:49 AM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
+package org.apache.geode.cache.query.internal.index;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;
@@ -948,7 +948,7 @@ public class IndexManager  {
    * @param action action to be taken (IndexManager.ADD_ENTRY,
    *          IndexManager.UPDATE_ENTRY, IndexManager.REMOVE_ENTRY)
    * @param opCode one of IndexProtocol.OTHER_OP, BEFORE_UPDATE_OP, AFTER_UPDATE_OP.
-   * @throws com.gemstone.gemfire.cache.query.IndexMaintenanceException
+   * @throws org.apache.geode.cache.query.IndexMaintenanceException
    */
   public void updateIndexes(RegionEntry entry, int action, int opCode, boolean isDiskRecoveryInProgress)
       throws QueryException {
@@ -1415,7 +1415,7 @@ public class IndexManager  {
     public void run() {
       // async writers main loop
       // logger.debug("DiskRegion writer started (writer=" + this + ")");
-      com.gemstone.gemfire.CancelCriterion stopper = ((LocalRegion)region).getCancelCriterion();
+      org.apache.geode.CancelCriterion stopper = ((LocalRegion)region).getCancelCriterion();
       try {
         while (!this.shutdownRequested) {
           // Termination checks

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
index bcbdaac..bb96cfe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
-//import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+//import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.RegionEntry;
 import java.util.*;
 
 public interface IndexProtocol extends Index {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStats.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStats.java
index 84d9b61..3351e3c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStats.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStats.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
+import org.apache.geode.*;
+//import org.apache.geode.cache.query.*;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.CachePerfStats;
 
 /**
  * IndexStats tracks statistics about query index use.
@@ -193,7 +193,7 @@ public class IndexStats {
   /**
    * Closes these stats so that they can not longer be used.  The
    * stats are closed when the {@linkplain
-   * com.gemstone.gemfire.internal.cache.GemFireCacheImpl#close cache} 
+   * org.apache.geode.internal.cache.GemFireCacheImpl#close cache} 
    * is closed.
    *
    * @since GemFire 3.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
index 795939a..c26ec48 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexUtils.java
index ee1fb6b..c56488a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexUtils.java
@@ -19,19 +19,19 @@
  *
  * Created on March 4, 2005, 5:39 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-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.cache.query.internal.*;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.cache.query.internal.index.IndexManager.TestHook;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
index a8e9ee4..8e70979 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
@@ -19,13 +19,13 @@
  *
  * Created on February 11, 2005, 4:25 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.RegionEntry;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapIndexStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapIndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapIndexStore.java
index 92b0632..fb27c0e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapIndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapIndexStore.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 import java.util.Iterator;
 
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.RegionEntryContext;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.LocalRegion.NonTXEntry;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.internal.cache.persistence.query.IndexMap;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.RegionEntryContext;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.cache.LocalRegion.NonTXEntry;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.cache.persistence.query.IndexMap;
 
 /**
  * Implementation of IndexStorage that is backed by an IndexMap

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapRangeIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapRangeIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapRangeIndex.java
index 13620f5..57a4d39 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapRangeIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MapRangeIndex.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 import java.util.Iterator;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.RegionEntry;
 
 public class MapRangeIndex extends AbstractMapIndex
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
index 59e7d21..2a58e2c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.AbstractMap.SimpleImmutableEntry;
 import java.util.Collection;
@@ -28,24 +28,24 @@ 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;
-import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledComparison;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.IndexMaintenanceException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledComparison;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.index.AbstractIndex.InternalIndexStatistics;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
 
 /**
  * The in-memory index storage

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
index da25ee3..e2de661 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -25,26 +25,26 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.IndexExistsException;
-import com.gemstone.gemfire.cache.query.IndexNameConflictException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.IndexExistsException;
+import org.apache.geode.cache.query.IndexNameConflictException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This class implements a Partitioned index over a group of partitioned region


[53/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseBaseTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseBaseTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseBaseTest.java
new file mode 100644
index 0000000..47b4e7e
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseBaseTest.java
@@ -0,0 +1,693 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import static org.apache.geode.tools.pulse.tests.PulseAbstractTest.*;
+import static org.junit.Assert.*;
+
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.TreeMap;
+import java.util.concurrent.TimeUnit;
+
+import org.openqa.selenium.By;
+import org.openqa.selenium.WebElement;
+import org.openqa.selenium.interactions.Actions;
+import org.openqa.selenium.support.ui.ExpectedConditions;
+import org.openqa.selenium.support.ui.WebDriverWait;
+
+public class PulseBaseTest {
+
+  public static int maxWaitTime = 20;
+
+  WebElement element = null;
+
+	public WebElement findElementUsingId(String id) {
+		return driver.findElement(By.id(id));
+	}
+	public WebElement findElementUsingXpath(String xpath) {
+		return driver.findElement(By.xpath(xpath));
+	}
+
+	public void clickElementUsingId(String id) {
+		findElementUsingId(id).click();
+	}
+
+	public void clickElementUsingXpath(String xpath) {
+		findElementUsingXpath(xpath).click();
+	}
+
+	public void enterTextUsingId(String id, String textToEnter) {
+		findElementUsingId(id).sendKeys(textToEnter);
+
+	}
+
+	public void enterTextUsingXpath(String xpath, String textToEnter) {
+		findElementUsingXpath(xpath).sendKeys(textToEnter);
+	}
+
+	public String getValueFromPropertiesFile(String key) {
+		return JMXProperties.getInstance().getProperty(key);
+	}
+
+	public void sendKeysUsingId(String Id, String textToEnter){
+		findElementById(Id).sendKeys(textToEnter);
+	}
+
+	public void waitForElement(WebElement element) {
+		driver.manage().timeouts().implicitlyWait(0, TimeUnit.SECONDS);
+		WebDriverWait wait = new WebDriverWait(driver, 20);
+		wait.until(ExpectedConditions.visibilityOf(element));
+	}
+
+	public WebElement findElementById(String id) {
+		return driver.findElement(By.id(id));
+	}
+
+	public WebElement findElementByXpath(String xpath) {
+		return driver.findElement(By.xpath(xpath));
+	}
+
+	public String getTextUsingXpath(String xpath) {
+		return findElementByXpath(xpath).getText();
+	}
+
+	public String getTextUsingId(String id) {
+		return findElementById(id).getText();
+	}
+
+	public String getPersistanceEnabled(Region r) {
+		String persitance = null;
+
+		if (r.getPersistentEnabled()) {
+			persitance = "ON";
+		} else if (!r.getPersistentEnabled()) {
+			persitance = "OFF";
+		}
+		return persitance;
+	}
+
+	public String getPersistanceEnabled(String trueOrFalse) {
+		String persitance = null;
+
+		if (trueOrFalse.contains("true")) {
+			persitance = "ON";
+		} else if (trueOrFalse.contains("false")) {
+			persitance = "OFF";
+		}
+		return persitance;
+	}
+
+	public String HeapUsage(String valueInKB) {
+
+		return null;
+	}
+
+	// WIP - need to work on this --
+	public HashMap<String, HashMap<String, Region>> getRegionDetailsFromUI(String regionName) {
+
+		String[] regionNames = JMXProperties.getInstance().getProperty("regions").split(" ");
+		HashMap<String, HashMap<String, Region>> regionUiMap = new HashMap<String, HashMap<String, Region>>();
+
+		for (String region : regionNames) {
+			HashMap<String, Region> regionMap = regionUiMap.get(region);
+		}
+
+		return regionUiMap;
+	}
+
+	public void validateServerGroupGridData() {
+		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='memberListSG']/tbody/tr"));
+		int rowsCount = serverGridRows.size();
+		String[][] gridDataFromUI = new String[rowsCount][7];
+
+		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
+			for (int i = 0; i <= 6; i++) {
+				gridDataFromUI[x][i] = driver.findElement(
+						By.xpath("//table[@id='memberListSG']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
+			}
+		}
+
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
+
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			String[] sgs = thisMember.getGroups();
+
+			for (String sgName : sgs) {
+				HashMap<String, Member> sgMembers = sgMap.get(sgName);
+				if (sgMembers == null) {
+					sgMembers = new HashMap<String, Member>();
+					sgMap.put(sgName, sgMembers);
+				}
+				sgMembers.put(thisMember.getMember(), thisMember);
+			}
+		}
+
+		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
+			String sgName = gridDataFromUI[i][0];
+			String memName = gridDataFromUI[i][1];
+			Member m = sgMap.get(sgName).get(memName);
+
+			assertEquals(sgName, gridDataFromUI[i][0]);
+			assertEquals(memName, gridDataFromUI[i][1]);
+			assertEquals(m.getMember(), gridDataFromUI[i][2]);
+			assertEquals(m.getHost(), gridDataFromUI[i][3]);
+			String cupUsage = String.valueOf(m.getCpuUsage());
+			assertEquals(cupUsage, gridDataFromUI[i][5]);
+		}
+
+	}
+
+	public void validateRedundancyZonesGridData() {
+		List<WebElement> rzGridRows = driver.findElements(By.xpath("//table[@id='memberListRZ']/tbody/tr"));
+		int rowsCount = rzGridRows.size();
+		String[][] gridDataFromUI = new String[rowsCount][7];
+
+		for (int j = 2, x = 0; j <= rzGridRows.size(); j++, x++) {
+			for (int i = 0; i <= 6; i++) {
+				gridDataFromUI[x][i] = driver.findElement(
+						By.xpath("//table[@id='memberListRZ']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
+			}
+		}
+
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
+
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			//String[] rz = thisMember.getRedundancyZone();
+			String sgName = thisMember.getRedundancyZone();
+
+			//for (String sgName : rz) {
+				HashMap<String, Member> rzMembers = rzMap.get(sgName);
+
+				if (rzMembers == null) {
+					rzMembers = new HashMap<String, Member>();
+					rzMap.put(sgName, rzMembers);
+				}
+
+				rzMembers.put(thisMember.getMember(), thisMember);
+			//}
+		}
+
+		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
+			String sgName = gridDataFromUI[i][0];
+			String memName = gridDataFromUI[i][1];
+			Member m = rzMap.get(sgName).get(memName);
+
+			assertEquals(sgName, gridDataFromUI[i][0]);
+			assertEquals(memName, gridDataFromUI[i][1]);
+			assertEquals(m.getMember(), gridDataFromUI[i][2]);
+			assertEquals(m.getHost(), gridDataFromUI[i][3]);
+			String cupUsage = String.valueOf(m.getCpuUsage());
+			assertEquals(cupUsage, gridDataFromUI[i][5]);
+		}
+
+	}
+
+	public void validateTopologyGridData() {
+		List<WebElement> rzGridRows = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
+		int rowsCount = rzGridRows.size();
+		String[][] gridDataFromUI = new String[rowsCount][8];
+
+		for (int j = 2, x = 0; j <= rzGridRows.size(); j++, x++) {
+			for (int i = 0; i <= 7; i++) {
+				gridDataFromUI[x][i] = driver.findElement(
+						By.xpath("//table[@id='memberList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
+			}
+		}
+
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, Member> tpMap = new HashMap<String, Member>();
+
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			tpMap.put(thisMember.getMember(), thisMember);
+
+		}
+
+		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
+
+			String memName = gridDataFromUI[i][0];
+			Member m = tpMap.get(memName);
+
+			assertEquals(m.getMember(), gridDataFromUI[i][0]);
+			assertEquals(m.getMember(), gridDataFromUI[i][1]);
+			assertEquals(m.getHost(), gridDataFromUI[i][2]);
+			String cupUsage = String.valueOf(m.getCpuUsage());
+			assertEquals(cupUsage, gridDataFromUI[i][5]);
+		}
+	}
+
+	public void validateDataPrespectiveGridData() {
+		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='regionsList']/tbody/tr"));
+		int rowsCount = serverGridRows.size();
+		String[][] gridDataFromUI = new String[rowsCount][7];
+
+		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
+			for (int i = 0; i <= 6; i++) {
+				if (i < 5) {
+					gridDataFromUI[x][i] = driver.findElement(
+							By.xpath("//table[@id='regionsList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
+				} else if (i == 5) {
+					gridDataFromUI[x][i] = driver.findElement(
+							By.xpath("//table[@id='regionsList']/tbody/tr[" + j + "]/td[" + (i + 4) + "]")).getText();
+				}
+			}
+		}
+
+		String[] regionNames = JMXProperties.getInstance().getProperty("regions").split(" ");
+		HashMap<String, Region> dataMap = new HashMap<String, Region>();
+
+		for (String region : regionNames) {
+			Region thisRegion = new Region(region);
+			dataMap.put(thisRegion.getName(), thisRegion);
+
+		}
+
+		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
+			String memName = gridDataFromUI[i][0];
+			Region r = dataMap.get(memName);
+
+			assertEquals(r.getName(), gridDataFromUI[i][0]);
+			assertEquals(r.getRegionType(), gridDataFromUI[i][1]);
+
+			assertEquals(String.valueOf(r.getSystemRegionEntryCount()), gridDataFromUI[i][2]);
+			assertEquals(r.getFullPath(), gridDataFromUI[i][4]);
+			assertEquals(getPersistanceEnabled(r), gridDataFromUI[i][5]);
+		}
+	}
+
+	public void validateRegionDetailsGridData() {
+		List<WebElement> serverGridRows = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
+		int rowsCount = serverGridRows.size();
+		String[][] gridDataFromUI = new String[rowsCount][7];
+
+		for (int j = 2, x = 0; j <= serverGridRows.size(); j++, x++) {
+			for (int i = 0; i < 2; i++) {
+				gridDataFromUI[x][i] = driver.findElement(
+						By.xpath("//table[@id='memberList']/tbody/tr[" + j + "]/td[" + (i + 1) + "]")).getText();
+			}
+		}
+
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, Member> tpMap = new HashMap<String, Member>();
+
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			tpMap.put(thisMember.getMember(), thisMember);
+		}
+
+		for (int i = 0; i < gridDataFromUI.length - 1; i++) {
+
+			String memName = gridDataFromUI[i][0];
+			Member m = tpMap.get(memName);
+			assertEquals(m.getMember(), gridDataFromUI[i][0]);
+		}
+
+	}
+
+	public void navigateToToplogyView(){
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.radioButtonXpath);
+	}
+
+	public void navigateToServerGroupGView(){
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
+	}
+
+	public void navigateToRedundancyZoneView(){
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
+	}
+
+	//  ------ 	Topology / Server Group / Redundancy Group - Tree View
+
+	public void navigateToTopologyTreeView(){
+		navigateToToplogyView();
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+	}
+
+	public void navigateToServerGroupTreeView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
+	}
+
+	public void navigateToRedundancyZonesTreeView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
+	}
+
+	//  ------ 	Topology / Server Group / Redundancy Group - Grid View
+
+	public void navigateToTopologyGridView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.radioButtonXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+	}
+
+	public void navigateToServerGroupGridView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.radioButtonXpath);
+		clickElementUsingId(PulseTestLocators.ServerGroups.gridButtonId);
+	}
+
+	public void navigateToRedundancyZonesGridView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.radioButtonXpath);
+		clickElementUsingId(PulseTestLocators.RedundancyZone.gridButtonId);
+	}
+
+	// ----- Data perspective / region details
+
+	public void navigateToDataPrespectiveGridView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.downarrowButtonXpath);
+		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.dataViewButtonXpath);
+		clickElementUsingId(PulseTestLocators.DataPerspectiveView.gridButtonId);
+	}
+
+	public void navigateToRegionDetailsView() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.downarrowButtonXpath);
+		clickElementUsingXpath(PulseTestLocators.DataPerspectiveView.dataViewButtonXpath);
+		// clickElementUsingXpath(PulseTestLocators.RegionDetailsView.regionNameXpath);
+		// // WIP - region navigation defect needs to fixed
+		clickElementUsingXpath(PulseTestLocators.RegionDetailsView.treeMapCanvasXpath);
+	}
+
+	public void navigateToRegionDetailsGridView() {
+		navigateToRegionDetailsView();
+		clickElementUsingXpath(PulseTestLocators.RegionDetailsView.gridButtonXpath);
+	}
+
+	public String getPropertyValue(String propertyKey) {
+		String propertyValue = JMXProperties.getInstance().getProperty(propertyKey);
+		return propertyValue;
+	}
+
+	public void verifyElementPresentById(String id) {
+		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
+		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.id(id)));
+	}
+
+	public void verifyElementPresentByLinkText(String lnkText) {
+		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
+		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.linkText(lnkText)));
+	}
+
+	public void verifyElementPresentByXpath(String xpath) {
+		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
+		wait.until(ExpectedConditions.presenceOfAllElementsLocatedBy(By.xpath(xpath)));
+	}
+
+	public void verifyTextPresrntById(String id, String text) {
+		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
+		wait.until(ExpectedConditions.textToBePresentInElementLocated(By.id(id), text));
+	}
+
+	public void verifyTextPresrntByXpath(String xpath, String text) {
+		WebDriverWait wait = new WebDriverWait(driver, maxWaitTime, 500);
+		wait.until(ExpectedConditions.textToBePresentInElementLocated(By.xpath(xpath), text));
+	}
+
+	public void verifyElementAttributeById(String id, String attribute, String value) {
+		String actualValue = findElementById(id).getAttribute(attribute);
+		assertTrue(actualValue.equals(value) || actualValue.contains(value));
+	}
+
+
+	public void mouseReleaseById(String id){
+		verifyElementPresentById(id);
+		Actions action = new Actions(driver);
+		WebElement we = driver.findElement(By.id(id));
+		action.moveToElement(we).release().perform();
+	}
+	public void mouseClickAndHoldOverElementById(String id) {
+		verifyElementPresentById(id);
+		Actions action = new Actions(driver);
+		WebElement we = driver.findElement(By.id(id));
+		action.moveToElement(we).clickAndHold().perform();
+	}
+
+	public void mouseOverElementByXpath(String xpath) {
+		Actions action = new Actions(driver);
+		WebElement we = driver.findElement(By.xpath(xpath));
+		action.moveToElement(we).build().perform();
+	}
+
+
+	public float stringToFloat(String stringValue){
+		float floatNum = Float.parseFloat(stringValue);
+		return floatNum;
+	}
+
+	public String floatToString(float floatValue){
+		String stringValue = Float.toString(floatValue);
+		return stringValue;
+	}
+
+
+	public String[] splitString(String stringToSplit, String splitDelimiter){
+		String [] stringArray = stringToSplit.split(splitDelimiter);
+		return stringArray;
+	}
+
+	public void assertMemberSortingByCpuUsage(){
+		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
+		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
+		for (String member : membersNames) {
+			Member thisMember = new Member(member);
+			memberMap.put(thisMember.getCpuUsage(), thisMember.getMember());
+		}
+		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberCPUUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM2;
+			}else{
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM3;
+			}
+			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
+	    }
+	}
+
+	public void assertMemberSortingByHeapUsage(){
+		Map<Long, String> memberMap = new TreeMap<Long,String>(Collections.reverseOrder());
+		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
+		for (String member : membersNames) {
+			Member thisMember = new Member(member);
+			memberMap.put(thisMember.getCurrentHeapSize(), thisMember.getMember());
+		}
+		for(Map.Entry<Long, String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberHeapUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM2;
+			}else{
+				refMemberHeapUsage = PulseTestData.Topology.heapUsagePaintStyleM3;
+			}
+			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberHeapUsage));
+	    }
+	}
+
+	public void assertMemberSortingBySGCpuUsage(){
+		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
+		String [] membersNames = splitString(JMXProperties.getInstance().getProperty("members"), " ");
+		for (String member : membersNames) {
+			Member thisMember = new Member(member);
+			memberMap.put(thisMember.getCpuUsage(), thisMember.getMember());
+		}
+		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberCPUUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM2;
+			}else{
+				refMemberCPUUsage = PulseTestData.Topology.cpuUsagePaintStyleM3;
+			}
+			assertTrue(findElementById(entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
+	    }
+	}
+
+
+	public void assertMemberSortingBySgHeapUsage(){
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			String[] sgs = thisMember.getGroups();
+
+			for (String sgName : sgs) {
+				HashMap<String, Member> sgMembers = sgMap.get(sgName);
+				if (sgMembers == null) {
+					sgMembers = new HashMap<String, Member>();
+					sgMap.put(sgName, sgMembers);
+				}
+				sgMembers.put(thisMember.getMember(), thisMember);
+			}
+		}
+		Map<Float, String> memberMap = new TreeMap<Float,String>(Collections.reverseOrder());
+
+		for(int sgId=1; sgId<=3; sgId++){
+			String sgName = "SG1";
+			String memName = "M" + sgId;
+			Member m = sgMap.get(sgName).get(memName);
+			memberMap.put((float) m.getCurrentHeapSize(), m.getMember());
+		}
+
+		for(Map.Entry<Float,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberCPUUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M2;
+			}else{
+				refMemberCPUUsage = PulseTestData.ServerGroups.heapUsagePaintStyleSG1M3;
+			}
+			assertTrue(findElementById("SG1(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
+	    }
+	}
+
+
+
+	public void assertMemberSortingBySgCpuUsage(){
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> sgMap = new HashMap<String, HashMap<String, Member>>();
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			String[] sgs = thisMember.getGroups();
+
+			for (String sgName : sgs) {
+				HashMap<String, Member> sgMembers = sgMap.get(sgName);
+				if (sgMembers == null) {
+					sgMembers = new HashMap<String, Member>();
+					sgMap.put(sgName, sgMembers);
+				}
+				sgMembers.put(thisMember.getMember(), thisMember);
+			}
+		}
+		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
+		//SG3(!)M3
+		for(int sgId=1; sgId<=3; sgId++){
+			String sgName = "SG1";
+			String memName = "M" + sgId;
+			Member m = sgMap.get(sgName).get(memName);
+			memberMap.put(m.getCpuUsage(), m.getMember());
+		}
+
+		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberCPUUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M2;
+			}else{
+				refMemberCPUUsage = PulseTestData.ServerGroups.cpuUsagePaintStyleSG1M3;
+			}
+			assertTrue(findElementById("SG1(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
+	    }
+	}
+
+	public void assertMemberSortingByRzHeapUsage(){
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			String sgName = thisMember.getRedundancyZone();
+				HashMap<String, Member> rzMembers = rzMap.get(sgName);
+
+				if (rzMembers == null) {
+					rzMembers = new HashMap<String, Member>();
+					rzMap.put(sgName, rzMembers);
+				}
+
+				rzMembers.put(thisMember.getMember(), thisMember);
+		}
+		Map<Float, String> memberMap = new TreeMap<Float,String>(Collections.reverseOrder());
+		String rzName = "RZ1 RZ2";
+		String memName = "M1" ;
+		Member m = rzMap.get(rzName).get(memName);
+		memberMap.put((float) m.getCurrentHeapSize(), m.getMember());
+
+		for(Map.Entry<Float,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberHeapUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ1RZ2M1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ1RZ2M2;
+			}else{
+				refMemberHeapUsage = PulseTestData.RedundancyZone.heapUsagePaintStyleRZ3M3;
+			}
+			assertTrue(findElementById("RZ1 RZ2(!)"+entry.getValue()).getAttribute("style").contains(refMemberHeapUsage));
+	    }
+	}
+
+	public void assertMemeberSortingByRzCpuUsage(){
+		String[] memberNames = JMXProperties.getInstance().getProperty("members").split(" ");
+		HashMap<String, HashMap<String, Member>> rzMap = new HashMap<String, HashMap<String, Member>>();
+		for (String member : memberNames) {
+			Member thisMember = new Member(member);
+			String sgName = thisMember.getRedundancyZone();
+				HashMap<String, Member> rzMembers = rzMap.get(sgName);
+
+				if (rzMembers == null) {
+					rzMembers = new HashMap<String, Member>();
+					rzMap.put(sgName, rzMembers);
+				}
+
+				rzMembers.put(thisMember.getMember(), thisMember);
+		}
+		Map<Double, String> memberMap = new TreeMap<>(Collections.reverseOrder());
+		String rzName = "RZ1 RZ2";
+		String memName = "M1" ;
+		Member m = rzMap.get(rzName).get(memName);
+		memberMap.put(m.getCpuUsage(), m.getMember());
+
+		for(Map.Entry<Double,String> entry : memberMap.entrySet()) {
+			//here matching painting style to validation that the members are painted according to their cpu usage
+			String refMemberCPUUsage = null;
+			if(entry.getValue().equalsIgnoreCase("M1")){
+				refMemberCPUUsage = PulseTestData.RedundancyZone.cpuUsagePaintStyleRZ1RZ2M1;
+			}else if(entry.getValue().equalsIgnoreCase("M2")){
+				refMemberCPUUsage = PulseTestData.RedundancyZone.cpuUsagePaintStyleRZ1RZ2M2;
+			}
+			assertTrue(findElementById("RZ1 RZ2(!)"+entry.getValue()).getAttribute("style").contains(refMemberCPUUsage));
+	    }
+	}
+
+	public List<WebElement> getRegionsFromDataBrowser(){
+		List<WebElement> regionList = driver.findElements(By.xpath("//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]"));
+		return regionList;
+	}
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseNoAuthTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseNoAuthTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseNoAuthTest.java
new file mode 100644
index 0000000..e1021df
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseNoAuthTest.java
@@ -0,0 +1,33 @@
+/*
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import org.apache.geode.test.junit.categories.UITest;
+import org.junit.BeforeClass;
+import org.junit.FixMethodOrder;
+import org.junit.experimental.categories.Category;
+import org.junit.runners.MethodSorters;
+
+@Category(UITest.class)
+@FixMethodOrder(MethodSorters.JVM)
+public class PulseNoAuthTest extends PulseAbstractTest {
+
+  @BeforeClass
+  public static void beforeClassSetup() throws Exception {
+    setUpServer("admin", "admin", null);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestData.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestData.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestData.java
new file mode 100644
index 0000000..e299786
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestData.java
@@ -0,0 +1,106 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public class PulseTestData {
+	
+	public static class TopNavigation{
+
+	}
+	
+	public static class ClusterStatus {
+
+		public static final String membersProperty = "members";
+	}
+	public static class Topology{
+		public static final String hotSpotHeapLbl = "Heap Usage";
+		public static final String hotSpotCPULbl = "CPU Usage";		
+		
+		public static final String cpuUsagePaintStyleM1 = "left: 497px; top: 0px;";
+		public static final String cpuUsagePaintStyleM2 = "left: 0px; top: 0px;";
+		public static final String cpuUsagePaintStyleM3 = "left: 265px; top: 0px;";		
+		
+		public static final String heapUsagePaintStyleM1 = "left: 0px; top: 0px;";
+		public static final String heapUsagePaintStyleM2 = "left: 559px; top: 0px;";
+		public static final String heapUsagePaintStyleM3 = "left: 280px; top: 0px;";
+	}
+	
+	public static class ServerGroups{
+		public static final String hotSpotHeapLbl = "Heap Usage";
+		public static final String hotSpotCPULbl = "CPU Usage";
+		
+		//Cpu Usage sorting
+//		public static final String cpuUsagePaintStyleM1 = "left: 497px; top: 0px;";
+//		public static final String cpuUsagePaintStyleM2 = "left: 0px; top: 0px;";
+//		public static final String cpuUsagePaintStyleM3 = "left: 265px; top: 0px;";		
+		
+		public static final String cpuUsagePaintStyleSG1M1 = "left: 0px; top: 295px;";
+		public static final String cpuUsagePaintStyleSG1M2 = "left: 0px; top: 30px;";
+		public static final String cpuUsagePaintStyleSG1M3 = "left: 0px; top: 171px;";
+		
+		public static final String cpuUsagePaintStyleSG2M1 = "left: 240px; top: 239px;";
+		public static final String cpuUsagePaintStyleSG2M2 = "left: 240px; top: 30px;";	
+		
+		public static final String cpuUsagePaintStyleSG3M3 = "left: 479px; top: 30px;"; 
+		
+		//heap usage sorting
+		public static final String heapUsagePaintStyleSG1M1 = "left: 0px; top: 30px;";
+		public static final String heapUsagePaintStyleSG1M2 = "left: 152px; top: 179px;";
+		public static final String heapUsagePaintStyleSG1M3 = "left: 0px; top: 179px;";
+		
+		public static final String heapUsagePaintStyleSG2M1 = "left: 240px; top: 30px;";
+		public static final String heapUsagePaintStyleSG2M2 = "left: 240px; top: 274px;";	
+		
+		public static final String heapUsagePaintStyleSG3M3 = "left: 479px; top: 30px;"; 
+	}
+	
+	public static class RedundancyZone{
+		
+		public static final String hotSpotHeapLbl = "Heap Usage";
+		public static final String hotSpotCPULbl = "CPU Usage";
+		
+		public static final String heapUsagePaintStyleRZ1RZ2M1 = "left: 0px; top: 30px;";
+		public static final String heapUsagePaintStyleRZ1RZ2M2 = "left: 0px; top: 274px;";
+		
+		public static final String heapUsagePaintStyleRZ3M3 = "left: 360px; top: 30px;";	
+		
+		public static final String cpuUsagePaintStyleRZ1RZ2M1 ="left: 0px; top: 239px;";
+		public static final String cpuUsagePaintStyleRZ1RZ2M2 ="left: 0px; top: 30px;";
+
+		
+	}
+	
+	public static class DataPerspectiveView {
+		
+	}
+
+	public static class DataBrowser {
+		public static final String partialRgnName = "R";
+		public static final String chkRgnClassName = "bttn chk checkbox_true_full";
+		public static final String notChkRgnClassName = "bttn chk checkbox_false_full";
+		
+		public static final String regName = "R1";
+		public static final String query1Text = "select * from /R1";
+		
+		public static final String datePattern = "EEE, MMM dd yyyy, HH:mm:ss z";		
+
+	}
+
+	
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestLocators.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestLocators.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestLocators.java
new file mode 100644
index 0000000..6e76218
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseTestLocators.java
@@ -0,0 +1,225 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public class PulseTestLocators {
+	public static class HtmlAttributes{
+		public static final String classAttribute = "class";
+		public static final String typeAttribute = "type";
+		public static final String idAttribute = "id";
+		public static final String nameAttribute = "name";
+		public static final String placeholderAttribute = "placeholder";
+		public static final String valueAttribute = "value";	
+		public static final String styleAttribute ="style";
+	}
+	
+	public static class TopNavigation {
+		public static final String clusterViewLinkXpath = "//a[text()='Cluster View']";
+	}
+
+	public static class ClusterStatus {
+
+	}
+
+	public static class MemberDetailsView {
+    public static final String gridButtonXpath = "//a[@id='btngridIcon']";
+  }
+
+  public static class TopologyView {
+
+		public static final String radioButtonId = "radio-default";
+		public static final String radioButtonXpath = "//label[text()='Topology']";
+		public static final String gridButtonId = "default_grid_button";
+		public static final String nodeH1Id = "h1";
+		public static final String nodeH2Id = "h2";
+		public static final String nodeH3Id = "h3";
+		public static final String memberM1Id = "M1";
+		public static final String memberM2Id = "M2";
+		public static final String memberM3Id = "M3";
+		public static final String treeMapButtonId = "default_treemap_button";
+		
+		// Host tootips
+		public static final String hostNameTTXpath = ".//*[@id='_tooltip']/div/div/div[1]";
+		public static final String cpuUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[1]/div[2]/div";
+		public static final String memoryUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div";
+		public static final String loadAvgTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div";
+		public static final String soketsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[4]/div[2]/div";
+		
+		// Member tooltips
+		public static final String memNameTTXpath = ".//*[@id='_tooltip']/div/div/div[1]";
+		public static final String memCpuUsageTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[1]/div[2]/div";
+		public static final String threadsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div/text()";
+		public static final String jvmPausesTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div";
+		public static final String regionsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[4]/div[2]/div";
+		public static final String clientsTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[5]/div[2]/div";
+		public static final String gatewaySenderTtXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[6]/div[2]/div";
+		public static final String portTTXpath = ".//*[@id='_tooltip']/div/div/div[2]/div[7]/div[2]/div";
+
+		// Grid view
+		public static final String idM1Xpath = ".//*[@id='M1&M1']/td[1]";
+		public static final String nameM1Xpath = ".//*[@id='M1&M1']/td[2]";
+		public static final String hostH1Xpath = ".//*[@id='M1&M1']/td[3]";
+		public static final String idM2Xpath = ".//*[@id='M2&M2']/td[1]";
+		public static final String nameM2Xpath = ".//*[@id='M2&M2']/td[2]";
+		public static final String hostH2Xpath = ".//*[@id='M2&M2']/td[3]";
+		public static final String idM3Xpath = ".//*[@id='M3&M3']/td[1]";
+		public static final String nameM3Xpath = ".//*[@id='M3&M3']/td[2]";
+		public static final String hostH3Xpath = ".//*[@id='M3&M3']/td[3]";
+
+		// HotSpot locators 
+		public static final String hotSpotId = "currentHotSpot";
+		public static final String hotspotListDivId = "hotspotList";
+		public static final String heapUsageXpath = "//a[text()='Heap Usage']";
+		public static final String cpuUsageXpath = "//a[text()='CPU Usage']";
+		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";
+
+    }
+
+	public static class ServerGroups {
+
+		public static final String radioButtonId = "radio-servergroups";
+		public static final String radioButtonXpath = "//label[text()='Server Groups']";
+		public static final String gridButtonId = "servergroups_grid_button";
+		public static final String gridBlockId = "servergroups_grid_block";
+
+		public static final String serverGrpsRadioId = "member_view_option_servergroups";
+		
+		public static final String serverGrpsRadioXpath = "//label[@for='radio-servergroups']";
+
+		public static final String serverGrp1Id = "SG1";
+		public static final String serverGrp2Id = "SG2";
+		public static final String serverGrp3Id = "SG3";
+
+		public static final String serverGrp1Xpath = ".//*[@id='SG1']/div";
+		public static final String serverGrp2Xpath = ".//*[@id='SG2']/div";
+		public static final String serverGrp3Xpath = ".//*[@id='SG3']/div";
+
+		public static final String sg1M1Id = "SG1(!)M1";
+		public static final String sg1M2Id = "SG1(!)M2";
+		public static final String sg1M3Id = "SG1(!)M3";
+		public static final String sg2M1Id = "SG2(!)M1";
+		public static final String sg2M2Id = "SG2(!)M2";
+		public static final String sg3M3Id = "SG3(!)M3";
+
+		// Grid view
+		public static final String idSG1M3Xpath = ".//*[@id='M3&M3']/td[2]";
+		public static final String idSG1M2Xpath = ".//*[@id='M2&M2']/td[2]";
+		public static final String idSG1M1Xpath = ".//*[@id='M1&M1']/td[2]";
+		public static final String nameM3Xpath = ".//*[@id='M3&M3']/td[3]";
+		public static final String nameM2Xpath = ".//*[@id='M2&M2']/td[3]";
+		public static final String nameM1Xpath = ".//*[@id='M1&M1']/td[3]";
+		
+		//HotSpot locators
+		public static final String hotSpotId = "currentHotSpot";
+		public static final String hotspotListDivId= "hotspotList";
+		public static final String heapUsageXpath= "//a[text()='Heap Usage']";
+		public static final String cpuUsageXpath= "//a[text()='CPU Usage']";
+		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";		
+		
+	}
+
+	public static class RedundancyZone {
+
+		public static final String radioButtonId = "radio-redundancyzones";
+		public static final String radioButtonXpathAlt = "//label[text()='Redundancy Zones']";		
+		public static final String radioButtonXpath = "//label[@for='radio-redundancyzones']";
+		
+		public static final String gridButtonId = "redundancyzones_grid_button";
+
+		public static final String zoneRZ1Id = "RZ1 RZ2";
+		public static final String zoneRZ2Id = "RZ2";
+		
+
+		public static final String zoneRZ1RZ2Xpath = ".//*[@id='RZ1 RZ2']/div";
+		public static final String zoneRZ2Xpath = ".//*[@id='RZ2']/div";
+
+		public static final String m1RZ1RZ2Id = "RZ1 RZ2(!)M1";
+		public static final String m2RZ1Id = "RZ1 RZ2(!)M2";
+		public static final String m3RZ2Id = "RZ2(!)M3";
+//		public static final String m3RZ2Id = "RZ2(!)M3";
+//		public static final String m2RZ2Id = "RZ2(!)M2";
+		// Grid
+		public static final String idM2Xpath = ".//*[@id='M2&M2']/td[2]";
+		public static final String idM1Xpath = ".//*[@id='M1&M1']/td[2]";
+		public static final String idM3Xpath = ".//*[@id='M3&M3']/td[2]";
+		
+		//HotSpot locators
+		public static final String hotSpotId = "currentHotSpot";
+		public static final String hotspotListDivId= "hotspotList";
+		public static final String heapUsageXpath= "//a[text()='Heap Usage']";
+		public static final String cpuUsageXpath= "//a[text()='CPU Usage']";
+		public static final String graphTreeMapLblId = "//div[@id='GraphTreeMap-label']/child::node()";
+	}
+
+	public static class DataPerspectiveView {
+		public static final String downarrowButtonXpath = "//a[text()='Members']";
+		public static final String dataViewButtonXpath = "//a[text()='Data']";
+		public static final String gridButtonId = "data_grid_button";
+	}
+
+	public static class RegionDetailsView {
+
+		public static final String regionNameDivId = "regionNameText";
+		public static final String regionPathId = "regionPath";
+		public static final String treeMapCanvasXpath = "//canvas[@id='GraphTreeMapClusterData-canvas']";
+		public static final String regionTypeId = "regionType";
+		public static final String regionMembersTextId = "regionMembersText";
+		public static final String regionEmptyNodesId = "regionEmptyNodes";
+		public static final String regionEntryCountTextId = "regionEntryCountText";
+		public static final String regionDiskUsageId = "regionDiskUsage";
+		public static final String regionPersistenceId = "regionPersistence";
+
+		public static final String gridButtonXpath = "//a[@id='btngridIcon']";
+		public static final String memoryUsedId = "memoryUsed";
+		public static final String totalMemoryId = "totalMemory";
+
+		public static final String inMemoryReadsId = "currentReadsPerSec";
+		public static final String inMemoryWritesId = "currentWritesPerSec";
+		public static final String diskReadsId = "currentDiskReadsPerSec";
+		public static final String diskWritesId = "currentDiskWritesPerSec";
+
+		public static final String memberNameId = "memberName";
+
+	}
+
+	public static class DataBrowser {
+		public static final String rgnFilterTxtBoxId = "filterTextRegion";
+		public static final String rgnNameSpanXpath = "//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]";
+		public static final String rgnNameTxtBoxXpath = "//span[starts-with(@ID,'treeDemo_')][contains(@id,'_span')]";
+		public static final String rgnSpanFirstPart = "//span[@id='treeDemo_";
+		public static final String rgnSpanSecondPart = "_span']";
+		public static final String rgn1ChkBoxId = "treeDemo_1_check";
+		public static final String queryEditorTxtBoxId = "dataBrowserQueryText";
+		public static final String btnExecuteQueryId = "btnExecuteQuery";
+		
+		public static final String divDataRegions = "//div/ul[@id='treeDemo']/li";
+		
+		// History section		
+		public static final String historyIcon = "historyIcon";
+		public static final String historyLst = "//div[@id='detailsHistoryList']/div/div";
+		public static final String queryText = ".wrapHistoryContent";
+		public static final String historyDateTime = ".dateTimeHistory";
+		
+		//Clear button 
+		
+		public static final String btnClearXpath = "//input[@value='Clear']";
+
+	}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Region.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Region.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Region.java
new file mode 100644
index 0000000..1c1ef9f
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Region.java
@@ -0,0 +1,187 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import java.util.HashMap;
+import java.util.Map;
+
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.CompositeDataSupport;
+import javax.management.openmbean.CompositeType;
+import javax.management.openmbean.OpenDataException;
+import javax.management.openmbean.OpenType;
+import javax.management.openmbean.SimpleType;
+
+public class Region extends JMXBaseBean implements RegionMBean {
+  private String name = null;
+
+  private static String[] regAttItemNames = { "compressionCodec",
+    "enableOffHeapMemory", "scope", "diskStoreName",
+    "diskSynchronous" };
+  private static String[] regAttItemDescriptions = { "compressionCodec",
+    "enableOffHeapMemory", "scope", "diskStoreName",
+    "diskSynchronous" };
+  private static OpenType[] regAttItemTypes = { SimpleType.STRING,
+    SimpleType.BOOLEAN, SimpleType.STRING,
+    SimpleType.STRING, SimpleType.BOOLEAN };
+  private static CompositeType listRegionAttributesCompData = null;
+
+  static {
+    try {
+      listRegionAttributesCompData = new CompositeType("listRegionAttributes",
+          "Regions attributes", regAttItemNames, regAttItemDescriptions,
+          regAttItemTypes);
+
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+    }
+  }
+
+  public Region(String name) {
+    this.name = name;
+  }
+
+  protected String getKey(String propName) {
+    return "region." + name + "." + propName;
+  }
+
+  @Override
+  public String[] getMembers() {
+    return getStringArray("members");
+  }
+
+  @Override
+  public String getFullPath() {
+    return getString("fullPath");
+  }
+
+  @Override
+  public double getDiskReadsRate() {
+    return getDouble("diskReadsRate");
+  }
+
+  @Override
+  public double getDiskWritesRate() {
+    return getDouble("diskWritesRate");
+  }
+
+  @Override
+  public int getEmptyNodes() {
+    return getInt("emptyNodes");
+  }
+
+  @Override
+  public double getGetsRate() {
+    return getDouble("getsRate");
+  }
+
+  @Override
+  public double getLruEvictionRate() {
+    return getDouble("lruEvictionRate");
+  }
+
+  @Override
+  public double getPutsRate() {
+    return getDouble("putsRate");
+  }
+
+  @Override
+  public String getRegionType() {
+    return getString("regionType");
+  }
+
+  @Override
+  public long getEntrySize() {
+    return getLong("entrySize");
+  }
+
+  @Override
+  public long getSystemRegionEntryCount() {
+    return getLong("systemRegionEntryCount");
+  }
+
+  @Override
+  public int getMemberCount() {
+    return getInt("memberCount");
+  }
+
+  @Override
+  public boolean getPersistentEnabled() {
+    return getBoolean("persistentEnabled");
+  }
+
+  @Override
+  public String getName() {
+    return getString("name");
+  }
+
+  @Override
+  public boolean getGatewayEnabled() {
+    return getBoolean("gatewayEnabled");
+  }
+
+  @Override
+  public long getDiskUsage() {
+    return getLong("diskUsage");
+  }
+
+  @Override
+  public CompositeData listRegionAttributes() {
+    String value = JMXProperties.getInstance().getProperty(
+        getKey("listRegionAttributes"), "");
+    String[] itemValues = value.split(",");
+    Map<String, Object> itemValuesHM = new HashMap<String, Object>();
+    
+    // compressionCodec
+    if (null != itemValues[0]) {
+      itemValuesHM.put(regAttItemNames[0], itemValues[0]);
+    }
+
+    // enableOffHeapMemory
+    if (null != itemValues[1]) {
+      itemValuesHM.put(regAttItemNames[1], Boolean.parseBoolean(itemValues[1]));
+    }
+
+    // scope
+    if (null != itemValues[3]) {
+      itemValuesHM.put(regAttItemNames[3], itemValues[3]);
+    }
+
+    // diskStoreName
+    if (null != itemValues[4]) {
+      itemValuesHM.put(regAttItemNames[4], itemValues[4]);
+    }
+
+    // diskSynchronous
+    if (null != itemValues[5]) {
+      itemValuesHM.put(regAttItemNames[5], Boolean.parseBoolean(itemValues[5]));
+    }
+
+    CompositeData lraCompData;
+    try {
+      lraCompData = new CompositeDataSupport(listRegionAttributesCompData,
+          itemValuesHM);
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+      lraCompData = null;
+    }
+    return lraCompData;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionMBean.java
new file mode 100644
index 0000000..c0a32e6
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionMBean.java
@@ -0,0 +1,59 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.openmbean.CompositeData;
+
+public interface RegionMBean {
+  String OBJECT_NAME = "GemFire:service=Region,type=Distributed";
+
+  String[] getMembers();
+
+  String getFullPath();
+
+  double getDiskReadsRate();
+
+  double getDiskWritesRate();
+
+  int getEmptyNodes();
+
+  double getGetsRate();
+
+  double getLruEvictionRate();
+
+  double getPutsRate();
+
+  String getRegionType();
+
+  long getEntrySize();
+
+  long getSystemRegionEntryCount();
+
+  int getMemberCount();
+
+  boolean getPersistentEnabled();
+
+  String getName();
+
+  boolean getGatewayEnabled();
+
+  long getDiskUsage();
+
+  CompositeData listRegionAttributes();
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMember.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMember.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMember.java
new file mode 100644
index 0000000..18259f1
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMember.java
@@ -0,0 +1,95 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+/**
+ * Region on member mbean
+ *
+ *
+ *
+ */
+public class RegionOnMember extends JMXBaseBean implements RegionOnMemberMBean {
+  private String fullPath = null;
+  private String member = null;
+
+  public RegionOnMember(String fullPath, String member) {
+    this.fullPath = fullPath;
+    this.member = member;
+  }
+
+  @Override
+  protected String getKey(String propName) {
+    return "regionOnMember." + fullPath + "." + member + "." + propName;
+  }
+
+  @Override
+  public String getFullPath(){
+    return this.fullPath;
+  }
+
+  @Override
+  public String getMember(){
+    return this.member;
+  }
+
+  @Override
+  public String getName(){
+    return getString("name");
+  }
+
+  @Override
+  public String getRegionType(){
+    return getString("regionType");
+  }
+
+  @Override
+  public long getEntrySize(){
+    return getLong("entrySize");
+  }
+
+  @Override
+  public long getEntryCount(){
+    return getLong("entryCount");
+  }
+
+  @Override
+  public double getGetsRate(){
+    return getDouble("getsRate");
+  }
+
+  @Override
+  public double getPutsRate(){
+    return getDouble("putsRate");
+  }
+
+  @Override
+  public double getDiskReadsRate(){
+    return getDouble("diskGetsRate");
+  }
+
+  @Override
+  public double getDiskWritesRate(){
+    return getDouble("diskPutsRate");
+  }
+
+  @Override
+  public int getLocalMaxMemory(){
+    return getInt("localMaxMemory");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMemberMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMemberMBean.java
new file mode 100644
index 0000000..c63eb33
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/RegionOnMemberMBean.java
@@ -0,0 +1,49 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+/**
+ * Region on members mbean
+ *
+ *
+ */
+public interface RegionOnMemberMBean {
+
+  String getName();
+
+  String getRegionType(); // Ideally should be an Enum
+
+  String getFullPath();
+
+  String getMember();
+
+  long getEntrySize();
+
+  long getEntryCount();
+
+  double getGetsRate();
+
+  double getPutsRate();
+
+  double getDiskReadsRate();
+
+  double getDiskWritesRate();
+
+  int getLocalMaxMemory();
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Server.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Server.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Server.java
new file mode 100644
index 0000000..ecf15eb
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Server.java
@@ -0,0 +1,247 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import java.io.IOException;
+import java.lang.management.ManagementFactory;
+import java.net.Inet4Address;
+import java.net.Inet6Address;
+import java.net.InetAddress;
+import java.net.UnknownHostException;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Properties;
+
+import javax.management.InstanceAlreadyExistsException;
+import javax.management.MBeanRegistrationException;
+import javax.management.MBeanServer;
+import javax.management.MalformedObjectNameException;
+import javax.management.NotCompliantMBeanException;
+import javax.management.ObjectName;
+import javax.management.remote.JMXConnectorServer;
+import javax.management.remote.JMXConnectorServerFactory;
+import javax.management.remote.JMXServiceURL;
+
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.security.templates.SampleSecurityManager;
+import org.apache.shiro.SecurityUtils;
+import org.apache.shiro.mgt.DefaultSecurityManager;
+import org.apache.shiro.mgt.SecurityManager;
+import org.apache.shiro.realm.Realm;
+
+import org.apache.geode.internal.security.shiro.CustomAuthRealm;
+import org.apache.geode.internal.security.shiro.JMXShiroAuthenticator;
+import org.apache.geode.management.internal.security.AccessControlMBean;
+import org.apache.geode.management.internal.security.MBeanServerWrapper;
+import org.apache.geode.management.internal.security.ResourceConstants;
+
+public class Server {
+
+  private static final String DEFAULT_HOST = "127.0.0.1"; //"localhost"
+  private static final int DEFAULT_PORT = 9999;
+  private final JMXServiceURL url;
+  private MBeanServer mbs;
+  private JMXConnectorServer cs;
+  private String propFile = null;
+
+  public Server(int port, String properties, String jsonAuthFile) throws Exception {
+    this.propFile = properties;
+    mbs = ManagementFactory.getPlatformMBeanServer();
+    url = new JMXServiceURL(formJMXServiceURLString(DEFAULT_HOST, port));
+
+    // Load the beans first, otherwise we get access denied
+    loadMBeans();
+
+    if (jsonAuthFile != null) {
+      System.setProperty("spring.profiles.active", "pulse.authentication.gemfire");
+
+      Map<String, Object> env = new HashMap<String, Object>();
+
+      // set up Shiro Security Manager
+      Properties securityProperties = new Properties();
+      securityProperties.setProperty(SampleSecurityManager.SECURITY_JSON, jsonAuthFile);
+      Realm realm = new CustomAuthRealm(SampleSecurityManager.class.getName(), securityProperties);
+      SecurityManager securityManager = new DefaultSecurityManager(realm);
+      SecurityUtils.setSecurityManager(securityManager);
+
+      // register the AccessControll bean
+      AccessControlMBean acc = new AccessControlMBean();
+      ObjectName accessControlMBeanON = new ObjectName(ResourceConstants.OBJECT_NAME_ACCESSCONTROL);
+      MBeanServer platformMBeanServer = ManagementFactory.getPlatformMBeanServer();
+      platformMBeanServer.registerMBean(acc, accessControlMBeanON);
+
+      // wire in the authenticator and authorizaton
+      JMXShiroAuthenticator interceptor = new JMXShiroAuthenticator();
+      env.put(JMXConnectorServer.AUTHENTICATOR, interceptor);
+      cs = JMXConnectorServerFactory.newJMXConnectorServer(url, env, mbs);
+      cs.setMBeanServerForwarder(new MBeanServerWrapper());
+
+      //set up the AccessControlMXBean
+
+    } else {
+      System.setProperty("spring.profiles.active", "pulse.authentication.default");
+      cs = JMXConnectorServerFactory.newJMXConnectorServer(url, null, mbs);
+    }
+
+    try {
+      java.rmi.registry.LocateRegistry.createRegistry(port);
+      System.out.println("RMI registry ready.");
+    } catch (Exception e) {
+      System.out.println("Exception starting RMI registry:");
+      e.printStackTrace();
+    }
+
+    cs.start();
+  }
+
+  private String formJMXServiceURLString(String host, int port) throws UnknownHostException {
+    String jmxSerURL = "";
+
+    InetAddress inetAddr = InetAddress.getByName(host);
+    if (inetAddr instanceof Inet4Address) {
+      // Create jmx service url for IPv4 address
+      jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":" + port + "/jmxrmi";
+    } else if (inetAddr instanceof Inet6Address) {
+      // Create jmx service url for IPv6 address
+      jmxSerURL = "service:jmx:rmi://[" + host + "]/jndi/rmi://[" + host + "]:" + port + "/jmxrmi";
+    }
+
+    return jmxSerURL;
+  }
+
+  public void stop() {
+    try {
+      cs.stop();
+    } catch (IOException e) {
+      e.printStackTrace();
+    }
+  }
+
+  private synchronized void loadMBeans() {
+    JMXProperties props = JMXProperties.getInstance();
+    try {
+      props.load(propFile);
+    } catch (IOException e) {
+      e.printStackTrace();
+    }
+
+    // Add servers
+    String[] servers = getArrayProperty(props, "servers");
+    for (String server : servers) {
+      try {
+        addServerMBean(server);
+      } catch (InstanceAlreadyExistsException e) {
+        e.printStackTrace();
+      } catch (MBeanRegistrationException e) {
+        e.printStackTrace();
+      } catch (NotCompliantMBeanException e) {
+        e.printStackTrace();
+      } catch (MalformedObjectNameException e) {
+        e.printStackTrace();
+      } catch (NullPointerException e) {
+        e.printStackTrace();
+      }
+    }
+
+    // Add members
+    String[] members = getArrayProperty(props, "members");
+    for (String m : members) {
+      try {
+        addMemberMBean(m);
+      } catch (InstanceAlreadyExistsException e) {
+        e.printStackTrace();
+      } catch (MBeanRegistrationException e) {
+        e.printStackTrace();
+      } catch (NotCompliantMBeanException e) {
+        e.printStackTrace();
+      } catch (MalformedObjectNameException e) {
+        e.printStackTrace();
+      } catch (NullPointerException e) {
+        e.printStackTrace();
+      }
+    }
+
+    // Add regions
+    String[] regions = getArrayProperty(props, "regions");
+    for (String reg : regions) {
+      try {
+        addRegionMBean(reg);
+      } catch (InstanceAlreadyExistsException e) {
+        e.printStackTrace();
+      } catch (MBeanRegistrationException e) {
+        e.printStackTrace();
+      } catch (NotCompliantMBeanException e) {
+        e.printStackTrace();
+      } catch (MalformedObjectNameException e) {
+        e.printStackTrace();
+      } catch (NullPointerException e) {
+        e.printStackTrace();
+      }
+    }
+  }
+
+  private void addMemberMBean(
+      String m) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
+    Member m1 = new Member(m);
+    mbs.registerMBean(m1, new ObjectName(Member.OBJECT_NAME + ",member=" + m));
+  }
+
+  // For GemFire XD
+  private void addGemFireXDMemberMBean(
+      String xdm) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
+    GemFireXDMember xdmo = new GemFireXDMember(xdm);
+    mbs.registerMBean(xdmo, new ObjectName(GemFireXDMember.OBJECT_NAME + ",member=" + xdm));
+  }
+
+  private void addRegionMBean(
+      String reg) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
+    Region regionObject = new Region(reg);
+    mbs.registerMBean(regionObject, new ObjectName(Region.OBJECT_NAME + ",name=/" + reg));
+
+    for (String member : regionObject.getMembers()) {
+      RegionOnMember regionOnMemberObject = new RegionOnMember(regionObject.getFullPath(), member);
+      mbs.registerMBean(regionOnMemberObject, new ObjectName(
+          PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObject.getFullPath() + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + member));
+    }
+  }
+
+  private void addServerMBean(
+      String server) throws InstanceAlreadyExistsException, MBeanRegistrationException, NotCompliantMBeanException, MalformedObjectNameException, NullPointerException {
+    ServerObject so = new ServerObject(server);
+    mbs.registerMBean(so, new ObjectName(ServerObject.OBJECT_NAME));
+  }
+
+  private String[] getArrayProperty(JMXProperties props, String propName) {
+    String propVal = props.getProperty(propName, "");
+    return propVal.split(" ");
+  }
+
+  public static Server createServer(int port, String properties, String jsonAuthFile)
+      throws MalformedObjectNameException {
+    Server s = null;
+    try {
+      s = new Server(port, properties, jsonAuthFile);
+    } catch (Exception e) {
+      e.printStackTrace();
+      return null;
+    }
+
+    return s;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObject.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObject.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObject.java
new file mode 100644
index 0000000..11afb70
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObject.java
@@ -0,0 +1,267 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import java.io.IOException;
+
+import javax.management.NotificationBroadcasterSupport;
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.CompositeDataSupport;
+import javax.management.openmbean.CompositeType;
+import javax.management.openmbean.OpenDataException;
+import javax.management.openmbean.OpenType;
+import javax.management.openmbean.SimpleType;
+import javax.management.openmbean.TabularData;
+import javax.management.openmbean.TabularDataSupport;
+import javax.management.openmbean.TabularType;
+
+public class ServerObject extends NotificationBroadcasterSupport implements
+    ServerObjectMBean {
+  private String name = null;
+
+  private TabularDataSupport wanInfo;
+  private static String[] itemNames = { "key", "value" };
+  private static String[] itemDescriptions = { "Key", "Value" };
+  private static OpenType[] itemTypes = { SimpleType.STRING, SimpleType.BOOLEAN };
+  private static CompositeType wanInfoType = null;
+
+  private static String[] indexNames = { "key" };
+  private static TabularType wanType = null;
+
+  static {
+    try {
+      wanInfoType = new CompositeType("wanInfo", "WAN Information", itemNames,
+          itemDescriptions, itemTypes);
+
+      wanType = new TabularType("wanInfo", "WAN Information", wanInfoType,
+          indexNames);
+
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+    }
+  }
+
+  public ServerObject(String name) {
+    this.name = name;
+    this.wanInfo = new TabularDataSupport(wanType);
+  }
+
+  private String getKey(String propName) {
+    return "server." + name + "." + propName;
+  }
+
+  @Override
+  public String[] listCacheServers() {
+    return JMXProperties.getInstance()
+        .getProperty(getKey("listCacheServers"), "").split(" ");
+  }
+
+  @Override
+  public String[] listServers() {
+    return JMXProperties.getInstance()
+            .getProperty(getKey("listServers"), "").split(" ");
+  }
+
+  @Override
+  public TabularData viewRemoteClusterStatus() {
+    wanInfo.clear();
+    String[] wan = JMXProperties.getInstance()
+        .getProperty(getKey("wanInfo"), "").split(" ");
+    int cnt = 0;
+    while (wan.length >= (cnt + 2)) {
+      try {
+        wanInfo.put(buildWanInfoType(new String(wan[cnt]),
+            Boolean.parseBoolean(wan[cnt + 1])));
+      } catch (OpenDataException e) {
+        e.printStackTrace();
+      }
+      cnt += 2;
+    }
+
+    return (TabularData) wanInfo.clone();
+  }
+
+  @Override
+  public int getMemberCount() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("memberCount")));
+  }
+
+  @Override
+  public int getNumClients() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("numClients")));
+  }
+
+  @Override
+  public int getDistributedSystemId() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("distributedSystemId")));
+  }
+
+  @Override
+  public int getLocatorCount() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("locatorCount")));
+  }
+
+  @Override
+  public int getTotalRegionCount() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("totalRegionCount")));
+  }
+
+  @Override
+  public int getNumRunningFunctions() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("numRunningFunctions")));
+  }
+
+  @Override
+  public long getRegisteredCQCount() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("registeredCQCount")));
+  }
+
+  @Override
+  public int getNumSubscriptions() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("numSubscriptions")));
+  }
+
+  // For SQLFire/GemFireXD
+  @Override
+  public int getTransactionCommitted() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("TransactionCommitted")));
+  }
+
+  // For SQLFire/GemFireXD
+  @Override
+  public int getTransactionRolledBack() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("TransactionRolledBack")));
+  }
+
+  @Override
+  public long getTotalHeapSize() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("totalHeapSize")));
+  }
+
+  @Override
+  public long getUsedHeapSize() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("usedHeapSize")));
+  }
+
+  @Override
+  public long getMaxMemory() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("MaxMemory")));
+  }
+
+  @Override
+  public long getUsedMemory() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("UsedMemory")));
+  }
+
+  @Override
+  public long getTotalRegionEntryCount() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("totalRegionEntryCount")));
+  }
+
+  @Override
+  public int getCurrentQueryCount() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("currentQueryCount")));
+  }
+
+  @Override
+  public long getTotalDiskUsage() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("totalDiskUsage")));
+  }
+
+  @Override
+  public double getDiskWritesRate() {
+    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+        getKey("diskWritesRate")));
+  }
+
+  @Override
+  public double getAverageWrites() {
+    String val = JMXProperties.getInstance().getProperty(getKey("averageWrites"), "");
+    double ret = Double.parseDouble(val);
+    return ret;
+//    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+//        getKey("averageWrites"), ""));
+  }
+
+  @Override
+  public double getAverageReads() {
+    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+        getKey("averageReads"), ""));
+  }
+
+  @Override
+  public double getQueryRequestRate() {
+    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+        getKey("queryRequestRate"), ""));
+  }
+
+  @Override
+  public double getDiskReadsRate() {
+    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+        getKey("diskReadsRate"), ""));
+  }
+
+  @Override
+  public long getJVMPauses() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("jvmPauses"), ""));
+  }
+
+  private CompositeData buildWanInfoType(String key, Boolean state)
+      throws OpenDataException {
+    Object[] itemValues = { key, state };
+    CompositeData result = new CompositeDataSupport(wanInfoType, itemNames,
+        itemValues);
+
+    return result;
+  }
+
+  @Override
+  public String queryData(String p0, String p1, int p2) {
+    // p0 : query
+    // p1 : comma separated members
+    // p2 : limit
+    
+    DataBrowserResultLoader dbrLoader = DataBrowserResultLoader.getInstance();
+    
+    try {
+      return dbrLoader.load(p0);
+    } catch (IOException e) {
+      e.printStackTrace();
+      return e.getMessage();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObjectMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObjectMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObjectMBean.java
new file mode 100644
index 0000000..46ad620
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/ServerObjectMBean.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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.openmbean.TabularData;
+
+public interface ServerObjectMBean {
+  String OBJECT_NAME = "GemFire:service=System,type=Distributed";
+
+  TabularData viewRemoteClusterStatus();
+
+  int getMemberCount();
+
+  int getNumClients();
+
+  int getDistributedSystemId();
+
+  int getLocatorCount();
+
+  int getTotalRegionCount();
+
+  int getNumRunningFunctions();
+
+  long getRegisteredCQCount();
+
+  int getNumSubscriptions();
+
+  int getTransactionCommitted();
+
+  int getTransactionRolledBack();
+
+  long getTotalHeapSize();
+
+  long getUsedHeapSize();
+
+  long getMaxMemory();
+
+  long getUsedMemory();
+
+  long getTotalRegionEntryCount();
+
+  int getCurrentQueryCount();
+
+  long getTotalDiskUsage();
+
+  double getDiskWritesRate();
+
+  double getAverageWrites();
+
+  double getAverageReads();
+
+  double getQueryRequestRate();
+
+  double getDiskReadsRate();
+
+  long getJVMPauses();
+
+  String[] listCacheServers();
+
+  String[] listServers();
+
+  String queryData(String p0, String p1, int p2);
+}


[80/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Cluster.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Cluster.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Cluster.java
deleted file mode 100644
index e15d282..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Cluster.java
+++ /dev/null
@@ -1,3815 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.apache.commons.collections.buffer.CircularFifoBuffer;
-
-import javax.management.remote.JMXConnector;
-import java.io.BufferedReader;
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.lang.reflect.Constructor;
-import java.lang.reflect.InvocationTargetException;
-import java.net.ConnectException;
-import java.net.URL;
-import java.text.DateFormat;
-import java.text.SimpleDateFormat;
-import java.util.ArrayList;
-import java.util.Date;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-import java.util.Random;
-import java.util.ResourceBundle;
-import java.util.Set;
-import java.util.TimeZone;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.atomic.AtomicInteger;
-/**
- * Class Cluster This class is the Data Model for the data used for the Pulse
- * Web UI.
- *
- * @since GemFire version 7.0.Beta 2012-09-23
- */
-public class Cluster extends Thread {
-  private static final int POLL_INTERVAL = 5000;
-  public static final int MAX_SAMPLE_SIZE = 180;
-  public static final int ALERTS_MAX_SIZE = 1000;
-  public static final int PAGE_ALERTS_MAX_SIZE = 100;
-
-  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-  private final ResourceBundle resourceBundle = Repository.get()
-      .getResourceBundle();
-
-  private String jmxUserName;
-  private String jmxUserPassword;
-  private String serverName;
-  private String port;
-  private int stale = 0;
-  private double loadPerSec;
-
-  // start: fields defined in System MBean
-  private IClusterUpdater updater = null;
-  private DataBrowser dataBrowser = null;
-  private int memberCount;
-  private long clientConnectionCount;
-  private int locatorCount;
-  private int totalRegionCount;
-  private long totalHeapSize = 0L;
-  private long totalRegionEntryCount;
-  private int currentQueryCount;
-  private long totalBytesOnDisk;
-  private double diskReadsRate;
-  private double diskWritesRate;
-  private double writePerSec;
-  private double readPerSec;
-  private double queriesPerSec;
-  private int avgDiskStorage;
-  private int avgDiskWritesRate;
-  private int runningFunctionCount;
-  private long registeredCQCount;
-  private int subscriptionCount;
-  private int serverCount;
-  private int txnCommittedCount;
-  private int txnRollbackCount;
-  private long usedHeapSize = 0L;
-  private long garbageCollectionCount = 0L;
-  private int clusterId;
-  private int notificationPageNumber = 1;
-  private boolean connectedFlag;
-  private String connectionErrorMsg = "";
-
-  private Set<String> deletedMembers = new HashSet<String>();
-
-  private Map<String, List<Cluster.Member>> physicalToMember = new HashMap<String, List<Cluster.Member>>();
-
-  private Map<String, Cluster.Member> membersHMap = new HashMap<String, Cluster.Member>();
-
-  private Set<String> deletedRegions = new HashSet<String>();
-
-  private Map<String, Cluster.Region> clusterRegionMap = new ConcurrentHashMap<String, Cluster.Region>();
-  private List<Cluster.Alert> alertsList = new ArrayList<Cluster.Alert>();
-
-  private CircularFifoBuffer totalBytesOnDiskTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer throughoutWritesTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer throughoutReadsTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer writePerSecTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer readPerSecTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer queriesPerSecTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer memoryUsageTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private CircularFifoBuffer garbageCollectionTrend = new CircularFifoBuffer(
-      MAX_SAMPLE_SIZE);
-  private long previousJVMPauseCount = 0L;
-
-  private HashMap<String, Boolean> wanInformation = new HashMap<String, Boolean>();
-  private Map<String, Cluster.Statement> clusterStatementMap = new ConcurrentHashMap<String, Cluster.Statement>();
-
-  public static final int CLUSTER_STAT_TOTAL_BYTES_ON_DISK = 0;
-  public static final int CLUSTER_STAT_THROUGHPUT_WRITES = 1;
-  public static final int CLUSTER_STAT_THROUGHPUT_READS = 2;
-  public static final int CLUSTER_STAT_WRITES_PER_SECOND = 3;
-  public static final int CLUSTER_STAT_READ_PER_SECOND = 4;
-  public static final int CLUSTER_STAT_QUERIES_PER_SECOND = 5;
-  public static final int CLUSTER_STAT_MEMORY_USAGE = 6;
-  public static final int CLUSTER_STAT_GARBAGE_COLLECTION = 7;
-
-  // end: fields defined in System MBean
-
-  // used for updating member's client data
-  public static long LAST_UPDATE_TIME = 0;
-
-  public int getStaleStatus() {
-    return this.stale;
-  }
-
-  private boolean stopUpdates = false;
-
-  private static final int MAX_HOSTS = 40;
-
-  private final List<String> hostNames = new ArrayList<String>();
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public Object[] getStatisticTrend(int trendId) {
-
-    Object[] returnArray = null;
-    switch (trendId) {
-    case CLUSTER_STAT_TOTAL_BYTES_ON_DISK:
-      synchronized (this.totalBytesOnDiskTrend) {
-        returnArray = this.totalBytesOnDiskTrend.toArray();
-      }
-
-      break;
-
-    case CLUSTER_STAT_THROUGHPUT_READS:
-      synchronized (this.throughoutReadsTrend) {
-        returnArray = this.throughoutReadsTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_THROUGHPUT_WRITES:
-      synchronized (this.throughoutWritesTrend) {
-        returnArray = this.throughoutWritesTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_WRITES_PER_SECOND:
-      synchronized (this.writePerSecTrend) {
-        returnArray = this.writePerSecTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_READ_PER_SECOND:
-      synchronized (this.readPerSecTrend) {
-        returnArray = this.readPerSecTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_QUERIES_PER_SECOND:
-      synchronized (this.queriesPerSecTrend) {
-        returnArray = this.queriesPerSecTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_MEMORY_USAGE:
-      synchronized (this.memoryUsageTrend) {
-        returnArray = this.memoryUsageTrend.toArray();
-      }
-      break;
-
-    case CLUSTER_STAT_GARBAGE_COLLECTION:
-      synchronized (this.garbageCollectionTrend) {
-        returnArray = this.garbageCollectionTrend.toArray();
-      }
-      break;
-    }
-
-    return returnArray;
-  }
-
-  /**
-   * Member Inner Class
-   *
-   *
-   */
-  public static class Member {
-
-    // start: fields defined in MBean
-    private String gemfireVersion;
-    private boolean manager;
-    private int totalRegionCount;
-    private String host;
-    private String hostnameForClients;
-    private String bindAddress;
-    private long currentHeapSize;
-    private long maxHeapSize;
-    private int avgHeapUsage;
-    private long OffHeapFreeSize;
-    private long OffHeapUsedSize;
-    private long totalBytesOnDisk;
-    private String memberPort;
-
-    private double cpuUsage = 0.0d;
-    private double hostCpuUsage = 0.0d;
-    private long uptime;
-    private String name;
-    private double getsRate;
-    private double putsRate;
-    private boolean isCache;
-    private boolean isGateway;
-    private boolean isLocator;
-    private boolean isServer;
-    private double loadAverage;
-    private int numThreads;
-    private long totalFileDescriptorOpen;
-    private long garbageCollectionCount = 0L;
-    private double throughputWrites;
-    private double throughputReads;
-    private long totalDiskUsage;
-    private String queueBacklog;
-    private String id;
-    private long numSqlfireClients = 0;
-
-    private List<String> serverGroups = new ArrayList<String>();
-    private List<String> redundancyZones = new ArrayList<String>();
-
-    private CircularFifoBuffer cpuUsageSamples = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer heapUsageSamples = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
-    private HashMap<String, Cluster.Client> memberClientsHMap = new HashMap<String, Cluster.Client>();
-    private CircularFifoBuffer totalBytesOnDiskSamples = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer getsPerSecond = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer putsPerSecond = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer throughputWritesTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer throughputReadsTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer garbageCollectionSamples = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private long previousJVMPauseCount = 0L;
-
-    private Cluster.GatewayReceiver gatewayReceiver = null;
-    private List<Cluster.GatewaySender> gatewaySenderList = new ArrayList<Cluster.GatewaySender>();
-    private List<Cluster.AsyncEventQueue> asyncEventQueueList = new ArrayList<Cluster.AsyncEventQueue>();
-    // end: fields defined in MBean
-
-    public static final int MEMBER_STAT_GARBAGE_COLLECTION = 0;
-    public static final int MEMBER_STAT_HEAP_USAGE_SAMPLE = 1;
-    public static final int MEMBER_STAT_CPU_USAGE_SAMPLE = 2;
-    public static final int MEMBER_STAT_GETS_PER_SECOND = 3;
-    public static final int MEMBER_STAT_PUTS_PER_SECOND = 4;
-    public static final int MEMBER_STAT_THROUGHPUT_WRITES = 5;
-    public static final int MEMBER_STAT_THROUGHPUT_READS = 6;
-
-    public Cluster.Region[] getMemberRegionsList() {
-      Cluster.Region[] memberReg = null;
-      synchronized (memberRegions) {
-        memberReg = new Cluster.Region[memberRegions.size()];
-        memberReg = memberRegions.values().toArray(memberReg);
-      }
-
-      return memberReg;
-    }
-
-    public Cluster.Client[] getMemberClients() {
-      Cluster.Client[] memberClients = null;
-      synchronized (memberClientsHMap) {
-        memberClients = new Cluster.Client[memberClientsHMap.size()];
-        memberClients = memberClientsHMap.values().toArray(memberClients);
-      }
-
-      return memberClients;
-    }
-
-    public Cluster.GatewaySender[] getMemberGatewaySenders() {
-      Cluster.GatewaySender[] memberGWS = null;
-      synchronized (gatewaySenderList) {
-        memberGWS = new Cluster.GatewaySender[gatewaySenderList.size()];
-        memberGWS = gatewaySenderList.toArray(memberGWS);
-      }
-      return memberGWS;
-    }
-
-    public Cluster.AsyncEventQueue[] getMemberAsyncEventQueueList() {
-      Cluster.AsyncEventQueue[] memberAEQ = null;
-      synchronized (asyncEventQueueList) {
-        memberAEQ = new Cluster.AsyncEventQueue[asyncEventQueueList.size()];
-        memberAEQ = asyncEventQueueList.toArray(memberAEQ);
-      }
-      return memberAEQ;
-    }
-
-    public Object[] getMemberStatisticTrend(int trendId) {
-      Object[] returnArray = null;
-      switch (trendId) {
-      case MEMBER_STAT_GARBAGE_COLLECTION:
-        synchronized (this.garbageCollectionSamples) {
-          returnArray = this.garbageCollectionSamples.toArray();
-        }
-
-        break;
-
-      case MEMBER_STAT_HEAP_USAGE_SAMPLE:
-        synchronized (this.heapUsageSamples) {
-          returnArray = this.heapUsageSamples.toArray();
-        }
-        break;
-
-      case MEMBER_STAT_CPU_USAGE_SAMPLE:
-        synchronized (this.cpuUsageSamples) {
-          returnArray = this.cpuUsageSamples.toArray();
-        }
-        break;
-
-      case MEMBER_STAT_GETS_PER_SECOND:
-        synchronized (this.getsPerSecond) {
-          returnArray = this.getsPerSecond.toArray();
-        }
-        break;
-
-      case MEMBER_STAT_PUTS_PER_SECOND:
-        synchronized (this.putsPerSecond) {
-          returnArray = this.putsPerSecond.toArray();
-        }
-        break;
-
-      case MEMBER_STAT_THROUGHPUT_WRITES:
-        synchronized (this.throughputWritesTrend) {
-          returnArray = this.throughputWritesTrend.toArray();
-        }
-        break;
-
-      case MEMBER_STAT_THROUGHPUT_READS:
-        synchronized (this.throughputReadsTrend) {
-          returnArray = this.throughputReadsTrend.toArray();
-        }
-        break;
-      }
-
-      return returnArray;
-    }
-
-    public String getGemfireVersion() {
-      return gemfireVersion;
-    }
-
-    public void setGemfireVersion(String gemfireVersion) {
-      this.gemfireVersion = gemfireVersion;
-    }
-
-    public String getMemberPort() {
-      return this.memberPort;
-    }
-
-    public void setMemberPort(String memberPort) {
-      this.memberPort = memberPort;
-    }
-
-    public double getThroughputWrites() {
-      return this.throughputWrites;
-    }
-
-    public void setThroughputWrites(double throughputWrites) {
-      this.throughputWrites = throughputWrites;
-    }
-
-    public double getThroughputReads() {
-      return this.throughputReads;
-    }
-
-    public void setThroughputReads(double throughputReads) {
-      this.throughputReads = throughputReads;
-    }
-
-    public long getTotalDiskUsage() {
-      return this.totalDiskUsage;
-    }
-
-    public void setTotalDiskUsage(long totalDiskUsage) {
-      this.totalDiskUsage = totalDiskUsage;
-    }
-
-    public String getId() {
-      return this.id;
-    }
-
-    public String getName() {
-      return this.name;
-    }
-
-    public double getLoadAverage() {
-      return this.loadAverage;
-    }
-
-    public void setLoadAverage(Double loadAverage) {
-      this.loadAverage = loadAverage;
-    }
-
-    public String getHost() {
-      return this.host;
-    }
-
-    public String getHostnameForClients() {
-      if(StringUtils.isNotNullNotEmptyNotWhiteSpace(hostnameForClients))
-        return this.hostnameForClients;
-      else if(StringUtils.isNotNullNotEmptyNotWhiteSpace(bindAddress))
-        return this.bindAddress;
-      return null;
-    }
-
-    public long getUptime() {
-      return this.uptime;
-    }
-
-    public String getQueueBacklog() {
-      return this.queueBacklog;
-    }
-
-    public HashMap<String, Cluster.Region> getMemberRegions() {
-      return this.memberRegions;
-    }
-
-    public void setMemberRegions(HashMap<String, Cluster.Region> memberRegions) {
-      this.memberRegions = memberRegions;
-    }
-
-    public long getCurrentHeapSize() {
-      return this.currentHeapSize;
-    }
-
-    public void setCurrentHeapSize(long currentHeapSize) {
-      this.currentHeapSize = currentHeapSize;
-    }
-
-    public long getMaxHeapSize() {
-      return this.maxHeapSize;
-    }
-
-    public void setMaxHeapSize(long maxHeapSize) {
-      this.maxHeapSize = maxHeapSize;
-    }
-
-    public boolean isManager() {
-      return this.manager;
-    }
-
-    public void setManager(boolean manager) {
-      this.manager = manager;
-    }
-
-    public int getAvgHeapUsage() {
-      return this.avgHeapUsage;
-    }
-
-    public void setAvgHeapUsage(int avgHeapUsage) {
-      this.avgHeapUsage = avgHeapUsage;
-    }
-
-    public long getOffHeapFreeSize() {
-      return OffHeapFreeSize;
-    }
-
-    public void setOffHeapFreeSize(long offHeapFreeSize) {
-      this.OffHeapFreeSize = offHeapFreeSize;
-    }
-
-    public long getOffHeapUsedSize() {
-      return OffHeapUsedSize;
-    }
-
-    public void setOffHeapUsedSize(long offHeapUsedSize) {
-      this.OffHeapUsedSize = offHeapUsedSize;
-    }
-
-    public void setId(String id) {
-      this.id = id;
-    }
-
-    public void setName(String name) {
-      this.name = name;
-    }
-
-    public void setHost(String host) {
-      this.host = host;
-    }
-
-    public void setHostnameForClients(String hostnameForClients) {
-      this.hostnameForClients = hostnameForClients;
-    }
-
-    public void setBindAddress(String bindAddress){
-      this.bindAddress = bindAddress;
-    }
-
-    public void setUptime(long uptime) {
-      this.uptime = uptime;
-    }
-
-    public void setQueueBacklog(String queueBacklog) {
-      this.queueBacklog = queueBacklog;
-    }
-
-    public int getTotalRegionCount() {
-      return this.totalRegionCount;
-    }
-
-    public void setTotalRegionCount(int totalRegionCount) {
-      this.totalRegionCount = totalRegionCount;
-    }
-
-    public long getTotalBytesOnDisk() {
-      return this.totalBytesOnDisk;
-    }
-
-    public void setTotalBytesOnDisk(long totalBytesOnDisk) {
-      this.totalBytesOnDisk = totalBytesOnDisk;
-    }
-
-    public double getCpuUsage() {
-      return this.cpuUsage;
-    }
-
-    public void setCpuUsage(double cpuUsage) {
-      this.cpuUsage = cpuUsage;
-    }
-
-    public double getHostCpuUsage() {
-      return this.hostCpuUsage;
-    }
-
-    public void setHostCpuUsage(double hostCpuUsage) {
-      this.hostCpuUsage = hostCpuUsage;
-    }
-
-    public double getGetsRate() {
-      return this.getsRate;
-    }
-
-    public void setGetsRate(double getsRate) {
-      this.getsRate = getsRate;
-    }
-
-    public double getPutsRate() {
-      return this.putsRate;
-    }
-
-    public void setPutsRate(double putsRate) {
-      this.putsRate = putsRate;
-    }
-
-    public HashMap<String, Cluster.Client> getMemberClientsHMap() {
-      return this.memberClientsHMap;
-    }
-
-    public void setMemberClientsHMap(
-        HashMap<String, Cluster.Client> memberClientsHMap) {
-      this.memberClientsHMap = memberClientsHMap;
-    }
-
-    public boolean isCache() {
-      return this.isCache;
-    }
-
-    public void setCache(boolean isCache) {
-      this.isCache = isCache;
-    }
-
-    public boolean isGateway() {
-      return this.isGateway;
-    }
-
-    public void setGateway(boolean isGateway) {
-      this.isGateway = isGateway;
-    }
-
-    public int getNumThreads() {
-      return this.numThreads;
-    }
-
-    public void setNumThreads(int numThreads) {
-      this.numThreads = numThreads;
-    }
-
-    public long getTotalFileDescriptorOpen() {
-      return this.totalFileDescriptorOpen;
-    }
-
-    public void setTotalFileDescriptorOpen(long totalFileDescriptorOpen) {
-      this.totalFileDescriptorOpen = totalFileDescriptorOpen;
-    }
-
-    public long getGarbageCollectionCount() {
-      return this.garbageCollectionCount;
-    }
-
-    public void setGarbageCollectionCount(long garbageCollectionCount) {
-      this.garbageCollectionCount = garbageCollectionCount;
-    }
-
-    public boolean isLocator() {
-      return this.isLocator;
-    }
-
-    public void setLocator(boolean isLocator) {
-      this.isLocator = isLocator;
-    }
-
-    public Cluster.GatewayReceiver getGatewayReceiver() {
-      return this.gatewayReceiver;
-    }
-
-    public void setGatewayReceiver(Cluster.GatewayReceiver gatewayReceiver) {
-      this.gatewayReceiver = gatewayReceiver;
-    }
-
-    public List<Cluster.GatewaySender> getGatewaySenderList() {
-      return this.gatewaySenderList;
-    }
-
-    public void setGatewaySenderList(
-        List<Cluster.GatewaySender> gatewaySenderList) {
-      this.gatewaySenderList = gatewaySenderList;
-    }
-
-    public List<Cluster.AsyncEventQueue> getAsyncEventQueueList() {
-      return this.asyncEventQueueList;
-    }
-
-    public void setAsyncEventQueueList(
-        List<Cluster.AsyncEventQueue> asyncEventQueueList) {
-      this.asyncEventQueueList = asyncEventQueueList;
-    }
-
-    public boolean isServer() {
-      return this.isServer;
-    }
-
-    public void setServer(boolean isServer) {
-      this.isServer = isServer;
-    }
-
-    public List<String> getServerGroups() {
-      return this.serverGroups;
-    }
-
-    public void setServerGroups(List<String> serverGroups) {
-      this.serverGroups = serverGroups;
-    }
-
-    public List<String> getRedundancyZones() {
-      return this.redundancyZones;
-    }
-
-    public void setRedundancyZones(List<String> redundancyZones) {
-      this.redundancyZones = redundancyZones;
-    }
-
-    public CircularFifoBuffer getCpuUsageSamples() {
-      return this.cpuUsageSamples;
-    }
-
-    public void setCpuUsageSamples(CircularFifoBuffer cpuUsageSamples) {
-      this.cpuUsageSamples = cpuUsageSamples;
-    }
-
-    public CircularFifoBuffer getHeapUsageSamples() {
-      return this.heapUsageSamples;
-    }
-
-    public void setHeapUsageSamples(CircularFifoBuffer heapUsageSamples) {
-      this.heapUsageSamples = heapUsageSamples;
-    }
-
-    public CircularFifoBuffer getTotalBytesOnDiskSamples() {
-      return this.totalBytesOnDiskSamples;
-    }
-
-    public void setTotalBytesOnDiskSamples(
-        CircularFifoBuffer totalBytesOnDiskSamples) {
-      this.totalBytesOnDiskSamples = totalBytesOnDiskSamples;
-    }
-
-    public CircularFifoBuffer getGetsPerSecond() {
-      return this.getsPerSecond;
-    }
-
-    public void setGetsPerSecond(CircularFifoBuffer getsPerSecond) {
-      this.getsPerSecond = getsPerSecond;
-    }
-
-    public CircularFifoBuffer getPutsPerSecond() {
-      return this.putsPerSecond;
-    }
-
-    public void setPutsPerSecond(CircularFifoBuffer putsPerSecond) {
-      this.putsPerSecond = putsPerSecond;
-    }
-
-    public CircularFifoBuffer getThroughputWritesTrend() {
-      return this.throughputWritesTrend;
-    }
-
-    public void setThroughputWritesTrend(
-        CircularFifoBuffer throughputWritesTrend) {
-      this.throughputWritesTrend = throughputWritesTrend;
-    }
-
-    public CircularFifoBuffer getThroughputReadsTrend() {
-      return this.throughputReadsTrend;
-    }
-
-    public void setThroughputReadsTrend(CircularFifoBuffer throughputReadsTrend) {
-      this.throughputReadsTrend = throughputReadsTrend;
-    }
-
-    public CircularFifoBuffer getGarbageCollectionSamples() {
-      return this.garbageCollectionSamples;
-    }
-
-    public void setGarbageCollectionSamples(
-        CircularFifoBuffer garbageCollectionSamples) {
-      this.garbageCollectionSamples = garbageCollectionSamples;
-    }
-
-    public long getPreviousJVMPauseCount() {
-      return this.previousJVMPauseCount;
-    }
-
-    public void setPreviousJVMPauseCount(long previousJVMPauseCount) {
-      this.previousJVMPauseCount = previousJVMPauseCount;
-    }
-
-    public long getNumSqlfireClients() {
-      return numSqlfireClients;
-    }
-
-    public void setNumSqlfireClients(long numSqlfireClients) {
-      this.numSqlfireClients = numSqlfireClients;
-    }
-
-    public void updateMemberClientsHMap(
-        HashMap<String, Cluster.Client> memberClientsHM) {
-
-      if (Cluster.LAST_UPDATE_TIME == 0) {
-        Cluster.LAST_UPDATE_TIME = System.nanoTime();
-      }
-
-      long systemNanoTime = System.nanoTime();
-
-      for (Map.Entry<String, Cluster.Client> entry : memberClientsHM.entrySet()) {
-        String clientId = entry.getKey();
-        Cluster.Client client = entry.getValue();
-
-        if (memberClientsHMap.get(clientId) != null) {
-          Client existingClient = memberClientsHMap.get(clientId);
-          Client updatedClient = memberClientsHM.get(clientId);
-
-          existingClient.setConnected(updatedClient.isConnected());
-          existingClient.setGets(updatedClient.getGets());
-          existingClient.setPuts(updatedClient.getPuts());
-          existingClient.setCpus(updatedClient.getCpus());
-          existingClient.setQueueSize(updatedClient.getQueueSize());
-          existingClient.setStatus(updatedClient.getStatus());
-          existingClient.setThreads(updatedClient.getThreads());
-          existingClient.setClientCQCount(updatedClient.getClientCQCount()); 
-       	  existingClient.setSubscriptionEnabled(updatedClient.isSubscriptionEnabled()); 
-          long elapsedTime = updatedClient.getUptime()
-              - existingClient.getUptime();
-          existingClient.setUptime(updatedClient.getUptime());
-
-          // set cpu usage
-          long lastCPUTime = 0;
-          lastCPUTime = existingClient.getProcessCpuTime();
-          long currCPUTime = 0;
-          currCPUTime = updatedClient.getProcessCpuTime();
-
-          double newCPUTime = (double) (currCPUTime - lastCPUTime)
-              / (elapsedTime * 1000000000);
-
-          double newCPUUsage = 0;
-          int availableCpus = updatedClient.getCpus();
-          if (availableCpus > 0) {
-            newCPUUsage = newCPUTime / availableCpus;
-          }
-
-          existingClient.setCpuUsage(newCPUUsage);
-          existingClient.setProcessCpuTime(currCPUTime);
-
-        } else {
-          // Add client to clients list
-          memberClientsHMap.put(clientId, client);
-        }
-
-      }
-
-      // Remove unwanted entries from clients list
-      HashMap<String, Cluster.Client> memberClientsHMapNew = new HashMap<String, Cluster.Client>();
-      for (Map.Entry<String, Cluster.Client> entry : memberClientsHMap
-          .entrySet()) {
-        String clientId = entry.getKey();
-        if (memberClientsHM.get(clientId) != null) {
-          memberClientsHMapNew.put(clientId, memberClientsHMap.get(clientId));
-        }
-      }
-      // replace existing memberClientsHMap by memberClientsHMapNew
-      this.setMemberClientsHMap(memberClientsHMapNew);
-
-      // update last update time
-      Cluster.LAST_UPDATE_TIME = systemNanoTime;
-
-    }
-
-  }
-
-  /**
-   * Member Inner Class
-   *
-   *
-   */
-  public static class Statement {
-
-    private String queryDefn;
-    private long numTimesCompiled;
-    private long numExecution;
-    private long numExecutionsInProgress;
-    private long numTimesGlobalIndexLookup;
-    private long numRowsModified;
-    private long parseTime;
-    private long bindTime;
-    private long optimizeTime;
-    private long routingInfoTime;
-    private long generateTime;
-    private long totalCompilationTime;
-    private long executionTime;
-    private long projectionTime;
-    private long totalExecutionTime;
-    private long rowsModificationTime;
-    private long qNNumRowsSeen;
-    private long qNMsgSendTime;
-    private long qNMsgSerTime;
-    private long qNRespDeSerTime;
-
-    public static String[] getGridColumnNames() {
-      String[] colNames = new String[] {
-          PulseConstants.MBEAN_COLNAME_QUERYDEFINITION,
-          PulseConstants.MBEAN_COLNAME_NUMEXECUTION,
-          PulseConstants.MBEAN_COLNAME_TOTALEXECUTIONTIME,
-          PulseConstants.MBEAN_COLNAME_NUMEXECUTIONSINPROGRESS,
-          PulseConstants.MBEAN_COLNAME_NUMTIMESCOMPILED,
-          PulseConstants.MBEAN_COLNAME_NUMTIMESGLOBALINDEXLOOKUP,
-          PulseConstants.MBEAN_COLNAME_NUMROWSMODIFIED,
-          PulseConstants.MBEAN_COLNAME_PARSETIME,
-          PulseConstants.MBEAN_COLNAME_BINDTIME,
-          PulseConstants.MBEAN_COLNAME_OPTIMIZETIME,
-          PulseConstants.MBEAN_COLNAME_ROUTINGINFOTIME,
-          PulseConstants.MBEAN_COLNAME_GENERATETIME,
-          PulseConstants.MBEAN_COLNAME_TOTALCOMPILATIONTIME,
-          PulseConstants.MBEAN_COLNAME_EXECUTIONTIME,
-          PulseConstants.MBEAN_COLNAME_PROJECTIONTIME,
-          PulseConstants.MBEAN_COLNAME_ROWSMODIFICATIONTIME,
-          PulseConstants.MBEAN_COLNAME_QNNUMROWSSEEN,
-          PulseConstants.MBEAN_COLNAME_QNMSGSENDTIME,
-          PulseConstants.MBEAN_COLNAME_QNMSGSERTIME,
-          PulseConstants.MBEAN_COLNAME_QNRESPDESERTIME };
-      return colNames;
-    }
-
-    public static String[] getGridColumnAttributes() {
-      String[] colAttributes = new String[] {
-          PulseConstants.MBEAN_ATTRIBUTE_QUERYDEFINITION,
-          PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION,
-          PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
-          PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
-          PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
-          PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED,
-          PulseConstants.MBEAN_ATTRIBUTE_PARSETIME,
-          PulseConstants.MBEAN_ATTRIBUTE_BINDTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME,
-          PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME,
-          PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME,
-
-          PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
-          PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME,
-          PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME };
-      return colAttributes;
-    }
-
-    public static int[] getGridColumnWidths() {
-      int[] colWidths = new int[] { 300, 150, 160, 180, 150, 200, 150, 130, 130,
-          160, 140, 180, 170, 160, 130,  190, 170, 170, 170, 200 };
-      return colWidths;
-    }
-
-    /**
-     * @return the numTimesCompiled
-     */
-    public String getQueryDefinition() {
-      return queryDefn;
-    }
-
-    /**
-     * @param queryDefn
-     *          the query to set
-     */
-    public void setQueryDefinition(String queryDefn) {
-      this.queryDefn = queryDefn;
-    }
-
-    /**
-     * @return the numTimesCompiled
-     */
-    public long getNumTimesCompiled() {
-      return numTimesCompiled;
-    }
-
-    /**
-     * @param numTimesCompiled
-     *          the numTimesCompiled to set
-     */
-    public void setNumTimesCompiled(long numTimesCompiled) {
-      this.numTimesCompiled = numTimesCompiled;
-    }
-
-    /**
-     * @return the numExecution
-     */
-    public long getNumExecution() {
-      return numExecution;
-    }
-
-    /**
-     * @param numExecution
-     *          the numExecution to set
-     */
-    public void setNumExecution(long numExecution) {
-      this.numExecution = numExecution;
-    }
-
-    /**
-     * @return the numExecutionsInProgress
-     */
-    public long getNumExecutionsInProgress() {
-      return numExecutionsInProgress;
-    }
-
-    /**
-     * @param numExecutionsInProgress
-     *          the numExecutionsInProgress to set
-     */
-    public void setNumExecutionsInProgress(long numExecutionsInProgress) {
-      this.numExecutionsInProgress = numExecutionsInProgress;
-    }
-
-    /**
-     * @return the numTimesGlobalIndexLookup
-     */
-    public long getNumTimesGlobalIndexLookup() {
-      return numTimesGlobalIndexLookup;
-    }
-
-    /**
-     * @param numTimesGlobalIndexLookup
-     *          the numTimesGlobalIndexLookup to set
-     */
-    public void setNumTimesGlobalIndexLookup(long numTimesGlobalIndexLookup) {
-      this.numTimesGlobalIndexLookup = numTimesGlobalIndexLookup;
-    }
-
-    /**
-     * @return the numRowsModified
-     */
-    public long getNumRowsModified() {
-      return numRowsModified;
-    }
-
-    /**
-     * @param numRowsModified
-     *          the numRowsModified to set
-     */
-    public void setNumRowsModified(long numRowsModified) {
-      this.numRowsModified = numRowsModified;
-    }
-
-    /**
-     * @return the parseTime
-     */
-    public long getParseTime() {
-      return parseTime;
-    }
-
-    /**
-     * @param parseTime
-     *          the parseTime to set
-     */
-    public void setParseTime(long parseTime) {
-      this.parseTime = parseTime;
-    }
-
-    /**
-     * @return the bindTime
-     */
-    public long getBindTime() {
-      return bindTime;
-    }
-
-    /**
-     * @param bindTime
-     *          the bindTime to set
-     */
-    public void setBindTime(long bindTime) {
-      this.bindTime = bindTime;
-    }
-
-    /**
-     * @return the optimizeTime
-     */
-    public long getOptimizeTime() {
-      return optimizeTime;
-    }
-
-    /**
-     * @param optimizeTime
-     *          the optimizeTime to set
-     */
-    public void setOptimizeTime(long optimizeTime) {
-      this.optimizeTime = optimizeTime;
-    }
-
-    /**
-     * @return the routingInfoTime
-     */
-    public long getRoutingInfoTime() {
-      return routingInfoTime;
-    }
-
-    /**
-     * @param routingInfoTime
-     *          the routingInfoTime to set
-     */
-    public void setRoutingInfoTime(long routingInfoTime) {
-      this.routingInfoTime = routingInfoTime;
-    }
-
-    /**
-     * @return the generateTime
-     */
-    public long getGenerateTime() {
-      return generateTime;
-    }
-
-    /**
-     * @param generateTime
-     *          the generateTime to set
-     */
-    public void setGenerateTime(long generateTime) {
-      this.generateTime = generateTime;
-    }
-
-    /**
-     * @return the totalCompilationTime
-     */
-    public long getTotalCompilationTime() {
-      return totalCompilationTime;
-    }
-
-    /**
-     * @param totalCompilationTime
-     *          the totalCompilationTime to set
-     */
-    public void setTotalCompilationTime(long totalCompilationTime) {
-      this.totalCompilationTime = totalCompilationTime;
-    }
-
-    /**
-     * @return the executionTime
-     */
-    public long getExecutionTime() {
-      return executionTime;
-    }
-
-    /**
-     * @param executionTime
-     *          the executionTime to set
-     */
-    public void setExecutionTime(long executionTime) {
-      this.executionTime = executionTime;
-    }
-
-    /**
-     * @return the projectionTime
-     */
-    public long getProjectionTime() {
-      return projectionTime;
-    }
-
-    /**
-     * @param projectionTime
-     *          the projectionTime to set
-     */
-    public void setProjectionTime(long projectionTime) {
-      this.projectionTime = projectionTime;
-    }
-
-    /**
-     * @return the totalExecutionTime
-     */
-    public long getTotalExecutionTime() {
-      return totalExecutionTime;
-    }
-
-    /**
-     * @param totalExecutionTime
-     *          the totalExecutionTime to set
-     */
-    public void setTotalExecutionTime(long totalExecutionTime) {
-      this.totalExecutionTime = totalExecutionTime;
-    }
-
-    /**
-     * @return the rowsModificationTime
-     */
-    public long getRowsModificationTime() {
-      return rowsModificationTime;
-    }
-
-    /**
-     * @param rowsModificationTime
-     *          the rowsModificationTime to set
-     */
-    public void setRowsModificationTime(long rowsModificationTime) {
-      this.rowsModificationTime = rowsModificationTime;
-    }
-
-    /**
-     * @return the qNNumRowsSeen
-     */
-    public long getqNNumRowsSeen() {
-      return qNNumRowsSeen;
-    }
-
-    /**
-     * @param qNNumRowsSeen
-     *          the qNNumRowsSeen to set
-     */
-    public void setqNNumRowsSeen(long qNNumRowsSeen) {
-      this.qNNumRowsSeen = qNNumRowsSeen;
-    }
-
-    /**
-     * @return the qNMsgSendTime
-     */
-    public long getqNMsgSendTime() {
-      return qNMsgSendTime;
-    }
-
-    /**
-     * @param qNMsgSendTime
-     *          the qNMsgSendTime to set
-     */
-    public void setqNMsgSendTime(long qNMsgSendTime) {
-      this.qNMsgSendTime = qNMsgSendTime;
-    }
-
-    /**
-     * @return the qNMsgSerTime
-     */
-    public long getqNMsgSerTime() {
-      return qNMsgSerTime;
-    }
-
-    /**
-     * @param qNMsgSerTime
-     *          the qNMsgSerTime to set
-     */
-    public void setqNMsgSerTime(long qNMsgSerTime) {
-      this.qNMsgSerTime = qNMsgSerTime;
-    }
-
-    /**
-     * @return the qNRespDeSerTime
-     */
-    public long getqNRespDeSerTime() {
-      return qNRespDeSerTime;
-    }
-
-    /**
-     * @param qNRespDeSerTime
-     *          the qNRespDeSerTime to set
-     */
-    public void setqNRespDeSerTime(long qNRespDeSerTime) {
-      this.qNRespDeSerTime = qNRespDeSerTime;
-    }
-  }
-
-  public static class RegionOnMember {
-
-    public static final int REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND = 0;
-    public static final int REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND = 1;
-    public static final int REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND = 3;
-    public static final int REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND = 4;
-
-    private String regionFullPath;
-    private String memberName;
-    private long entrySize;
-    private long entryCount;
-    private double getsRate;
-    private double putsRate;
-    private double diskGetsRate;
-    private double diskPutsRate;
-    private int localMaxMemory;
-
-    private CircularFifoBuffer getsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer putsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer diskReadsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer diskWritesPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-
-    /**
-     * @return the entrySize
-     */
-    public long getEntrySize() {
-      return entrySize;
-    }
-
-    /**
-     * @param entrySize the entrySize to set
-     */
-    public void setEntrySize(long entrySize) {
-      this.entrySize = entrySize;
-    }
-
-    /**
-     * @return the entryCount
-     */
-    public long getEntryCount() {
-      return entryCount;
-    }
-
-    /**
-     * @param entryCount the entryCount to set
-     */
-    public void setEntryCount(long entryCount) {
-      this.entryCount = entryCount;
-    }
-
-    /**
-     * @return the putsRate
-     */
-    public double getPutsRate() {
-      return putsRate;
-    }
-
-    /**
-     * @param putsRate the putsRate to set
-     */
-    public void setPutsRate(double putsRate) {
-      this.putsRate = putsRate;
-    }
-
-    /**
-     * @return the getsRate
-     */
-    public double getGetsRate() {
-      return getsRate;
-    }
-
-    /**
-     * @param getsRate the getsRate to set
-     */
-    public void setGetsRate(double getsRate) {
-      this.getsRate = getsRate;
-    }
-
-    /**
-     * @return the diskGetsRate
-     */
-    public double getDiskGetsRate() {
-      return diskGetsRate;
-    }
-
-    /**
-     * @param diskGetsRate the diskGetsRate to set
-     */
-    public void setDiskGetsRate(double diskGetsRate) {
-      this.diskGetsRate = diskGetsRate;
-    }
-
-    /**
-     * @return the diskPutsRate
-     */
-    public double getDiskPutsRate() {
-      return diskPutsRate;
-    }
-
-    /**
-     * @param diskPutsRate the diskPutsRate to set
-     */
-    public void setDiskPutsRate(double diskPutsRate) {
-      this.diskPutsRate = diskPutsRate;
-    }
-
-    /**
-     * @return the local maximum memory
-     */
-    public int getLocalMaxMemory() {
-      return this.localMaxMemory;
-    }
-
-    /**
-     * @param localMaxMemory
-     */
-    public void setLocalMaxMemory(int localMaxMemory) {
-      this.localMaxMemory = localMaxMemory;
-    }
-
-    /**
-     * @return the getsPerSecTrend
-     */
-    public CircularFifoBuffer getGetsPerSecTrend() {
-      return getsPerSecTrend;
-    }
-
-    /**
-     * @param getsPerSecTrend the getsPerSecTrend to set
-     */
-    public void setGetsPerSecTrend(CircularFifoBuffer getsPerSecTrend) {
-      this.getsPerSecTrend = getsPerSecTrend;
-    }
-
-    /**
-     * @return the putsPerSecTrend
-     */
-    public CircularFifoBuffer getPutsPerSecTrend() {
-      return putsPerSecTrend;
-    }
-
-    /**
-     * @param putsPerSecTrend the putsPerSecTrend to set
-     */
-    public void setPutsPerSecTrend(CircularFifoBuffer putsPerSecTrend) {
-      this.putsPerSecTrend = putsPerSecTrend;
-    }
-
-    /**
-     * @return the diskReadsPerSecTrend
-     */
-    public CircularFifoBuffer getDiskReadsPerSecTrend() {
-      return diskReadsPerSecTrend;
-    }
-
-    /**
-     * @param diskReadsPerSecTrend the diskReadsPerSecTrend to set
-     */
-    public void setDiskReadsPerSecTrend(CircularFifoBuffer diskReadsPerSecTrend) {
-      this.diskReadsPerSecTrend = diskReadsPerSecTrend;
-    }
-
-    /**
-     * @return the diskWritesPerSecTrend
-     */
-    public CircularFifoBuffer getDiskWritesPerSecTrend() {
-      return diskWritesPerSecTrend;
-    }
-
-    /**
-     * @param diskWritesPerSecTrend the diskWritesPerSecTrend to set
-     */
-    public void setDiskWritesPerSecTrend(CircularFifoBuffer diskWritesPerSecTrend) {
-      this.diskWritesPerSecTrend = diskWritesPerSecTrend;
-    }
-
-    public Object[] getRegionOnMemberStatisticTrend(int trendId) {
-
-      Object[] returnArray = null;
-      switch (trendId) {
-      case REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND:
-        synchronized (this.getsPerSecTrend) {
-          returnArray = this.getsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND:
-        synchronized (this.putsPerSecTrend) {
-          returnArray = this.putsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND:
-        synchronized (this.diskReadsPerSecTrend) {
-          returnArray = this.diskReadsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND:
-        synchronized (this.diskWritesPerSecTrend) {
-          returnArray = this.diskWritesPerSecTrend.toArray();
-        }
-        break;
-      }
-
-      return returnArray;
-    }
-
-    /**
-     * @return the regionFullPath
-     */
-    public String getRegionFullPath() {
-      return regionFullPath;
-    }
-
-    /**
-     * @param regionFullPath the regionFullPath to set
-     */
-    public void setRegionFullPath(String regionFullPath) {
-      this.regionFullPath = regionFullPath;
-    }
-
-    /**
-     * @return the memberName
-     */
-    public String getMemberName() {
-      return memberName;
-    }
-
-    /**
-     * @param memberName the memberName to set
-     */
-    public void setMemberName(String memberName) {
-      this.memberName = memberName;
-    }
-  }
-
-  /**
-   * Region Inner Class
-   *
-   *
-   */
-  public static class Region {
-    // start: fields defined in MBean
-    private String fullPath;
-    private double diskReadsRate;
-    private double diskWritesRate;
-    private double getsRate;
-    private double putsRate;
-    private double lruEvictionRate;
-    private String regionType;
-    private long systemRegionEntryCount;
-    private int memberCount;
-    private String name;
-    private boolean persistentEnabled;
-    private long entrySize;
-    private boolean wanEnabled;
-    private int emptyNode;
-    private long diskUsage;
-    private String scope;
-    private String diskStoreName;
-    private boolean diskSynchronous;
-    private boolean enableOffHeapMemory;
-    private String compressionCodec = "";
-
-    private List<String> memberName = new ArrayList<String>();
-    private List<RegionOnMember> regionOnMembers  = new ArrayList<RegionOnMember>();
-    private CircularFifoBuffer getsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer putsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer diskReadsPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-    private CircularFifoBuffer diskWritesPerSecTrend = new CircularFifoBuffer(
-        MAX_SAMPLE_SIZE);
-
-    public static final int REGION_STAT_GETS_PER_SEC_TREND = 0;
-    public static final int REGION_STAT_PUTS_PER_SEC_TREND = 1;
-    public static final int REGION_STAT_DISK_READS_PER_SEC_TREND = 3;
-    public static final int REGION_STAT_DISK_WRITES_PER_SEC_TREND = 4;
-
-    // end: fields defined in MBean
-
-    public Object[] getRegionStatisticTrend(int trendId) {
-
-      Object[] returnArray = null;
-      switch (trendId) {
-      case REGION_STAT_GETS_PER_SEC_TREND:
-        synchronized (this.getsPerSecTrend) {
-          returnArray = this.getsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_STAT_PUTS_PER_SEC_TREND:
-        synchronized (this.putsPerSecTrend) {
-          returnArray = this.putsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_STAT_DISK_READS_PER_SEC_TREND:
-        synchronized (this.diskReadsPerSecTrend) {
-          returnArray = this.diskReadsPerSecTrend.toArray();
-        }
-        break;
-
-      case REGION_STAT_DISK_WRITES_PER_SEC_TREND:
-        synchronized (this.diskWritesPerSecTrend) {
-          returnArray = this.diskWritesPerSecTrend.toArray();
-        }
-        break;
-      }
-
-      return returnArray;
-    }
-
-    public boolean isDiskSynchronous() {
-      return this.diskSynchronous;
-    }
-
-    public void setDiskSynchronous(boolean diskSynchronous) {
-      this.diskSynchronous = diskSynchronous;
-    }
-
-    public String getDiskStoreName() {
-      return this.diskStoreName;
-    }
-
-    public void setDiskStoreName(String diskStoreName) {
-      this.diskStoreName = diskStoreName;
-    }
-
-    public String getScope() {
-      return this.scope;
-    }
-
-    public void setScope(String scope) {
-      this.scope = scope;
-    }
-
-    public int getEmptyNode() {
-      return this.emptyNode;
-    }
-
-    public void setEmptyNode(int emptyNode) {
-      this.emptyNode = emptyNode;
-    }
-
-    public long getDiskUsage() {
-      return this.diskUsage;
-    }
-
-    public void setDiskUsage(long diskUsage) {
-      this.diskUsage = diskUsage;
-    }
-
-    public void setEntrySize(long entrySize) {
-      this.entrySize = entrySize;
-    }
-
-    public boolean getWanEnabled() {
-      return this.wanEnabled;
-    }
-
-    public void setWanEnabled(boolean wanEnabled) {
-      this.wanEnabled = wanEnabled;
-    }
-
-    public boolean getPersistentEnabled() {
-      return this.persistentEnabled;
-    }
-
-    public void setPersistentEnabled(boolean persistentEnabled) {
-      this.persistentEnabled = persistentEnabled;
-    }
-
-    public String getName() {
-      return this.name;
-    }
-
-    public void setName(String name) {
-      this.name = name;
-    }
-
-    public long getEntrySize() {
-      return this.entrySize;
-    }
-
-    public List<String> getMemberName() {
-      return this.memberName;
-    }
-
-    public void setMemberName(List<String> memberName) {
-      this.memberName = memberName;
-    }
-
-    public String getFullPath() {
-      return this.fullPath;
-    }
-
-    public void setFullPath(String fullPath) {
-      this.fullPath = fullPath;
-    }
-
-    public double getDiskReadsRate() {
-      return this.diskReadsRate;
-    }
-
-    public void setDiskReadsRate(double diskReadsRate) {
-      this.diskReadsRate = diskReadsRate;
-    }
-
-    public double getDiskWritesRate() {
-      return this.diskWritesRate;
-    }
-
-    public void setDiskWritesRate(double diskWritesRate) {
-      this.diskWritesRate = diskWritesRate;
-    }
-
-    public CircularFifoBuffer getDiskReadsPerSecTrend() {
-      return this.diskReadsPerSecTrend;
-    }
-
-    public void setDiskReadsPerSecTrend(CircularFifoBuffer diskReadsPerSecTrend) {
-      this.diskReadsPerSecTrend = diskReadsPerSecTrend;
-    }
-
-    public CircularFifoBuffer getDiskWritesPerSecTrend() {
-      return this.diskWritesPerSecTrend;
-    }
-
-    public void setDiskWritesPerSecTrend(
-        CircularFifoBuffer diskWritesPerSecTrend) {
-      this.diskWritesPerSecTrend = diskWritesPerSecTrend;
-    }
-
-    public double getGetsRate() {
-      return this.getsRate;
-    }
-
-    public void setGetsRate(double getsRate) {
-      this.getsRate = getsRate;
-    }
-
-    public double getLruEvictionRate() {
-      return this.lruEvictionRate;
-    }
-
-    public void setLruEvictionRate(double lruEvictionRate) {
-      this.lruEvictionRate = lruEvictionRate;
-    }
-
-    public String getRegionType() {
-      return this.regionType;
-    }
-
-    public void setRegionType(String regionType) {
-      this.regionType = regionType;
-    }
-
-    public long getSystemRegionEntryCount() {
-      return this.systemRegionEntryCount;
-    }
-
-    public void setSystemRegionEntryCount(long systemRegionEntryCount) {
-      this.systemRegionEntryCount = systemRegionEntryCount;
-    }
-
-    public int getMemberCount() {
-      return this.memberCount;
-    }
-
-    public void setMemberCount(int memberCount) {
-      this.memberCount = memberCount;
-    }
-
-    public double getPutsRate() {
-      return this.putsRate;
-    }
-
-    public void setPutsRate(double putsRate) {
-      this.putsRate = putsRate;
-    }
-
-    public CircularFifoBuffer getGetsPerSecTrend() {
-      return this.getsPerSecTrend;
-    }
-
-    public void setGetsPerSecTrend(CircularFifoBuffer getsPerSecTrend) {
-      this.getsPerSecTrend = getsPerSecTrend;
-    }
-
-    public CircularFifoBuffer getPutsPerSecTrend() {
-      return this.putsPerSecTrend;
-    }
-
-    public void setPutsPerSecTrend(CircularFifoBuffer putsPerSecTrend) {
-      this.putsPerSecTrend = putsPerSecTrend;
-    }
-
-    public boolean isEnableOffHeapMemory() {
-      return this.enableOffHeapMemory;
-    }
-
-    public void setEnableOffHeapMemory(boolean enableOffHeapMemory) {
-      this.enableOffHeapMemory = enableOffHeapMemory;
-    }
-
-    public String getCompressionCodec() {
-      return this.compressionCodec;
-    }
-
-    public void setCompressionCodec(String compressionCodec) {
-      this.compressionCodec = compressionCodec;
-    }
-
-    public Cluster.RegionOnMember[] getRegionOnMembers() {
-      Cluster.RegionOnMember[] regionOnMembers = null;
-      synchronized (this.regionOnMembers) {
-        regionOnMembers = new Cluster.RegionOnMember[this.regionOnMembers.size()];
-        regionOnMembers = this.regionOnMembers.toArray(regionOnMembers);
-      }
-
-      return regionOnMembers;
-    }
-
-    /**
-     * @param regionOnMembers the regionOnMembers to set
-     */
-    public void setRegionOnMembers(List<RegionOnMember> regionOnMembers) {
-      this.regionOnMembers = regionOnMembers;
-    }
-  }
-
-  /**
-   * Alert Inner Class
-   *
-   *
-   */
-  public static class Alert {
-    public static final int SEVERE = 0;
-    public static final int ERROR = 1;
-    public static final int WARNING = 2;
-    public static final int INFO = 3;
-
-    public static AtomicInteger ALERT_ID_CTR = new AtomicInteger();
-
-    private int id;
-    private Date timestamp;
-    private int severity;
-    private String memberName;
-    private String description;
-    private boolean isAcknowledged;
-    private String iso8601Ts;
-
-    public String getIso8601Ts() {
-      return iso8601Ts;
-    }
-
-    public void setIso8601Ts(String iso8601Ts) {
-      this.iso8601Ts = iso8601Ts;
-    }
-
-    public boolean isAcknowledged() {
-      return this.isAcknowledged;
-    }
-
-    public void setAcknowledged(boolean isAcknowledged) {
-      this.isAcknowledged = isAcknowledged;
-    }
-
-    public Date getTimestamp() {
-      return this.timestamp;
-    }
-
-    public void setTimestamp(Date timestamp) {
-      this.timestamp = timestamp;
-      this.iso8601Ts = formatToISOTimestamp(timestamp);
-    }
-
-    public int getSeverity() {
-      return this.severity;
-    }
-
-    public void setSeverity(int severity) {
-      this.severity = severity;
-    }
-
-    public String getMemberName() {
-      return this.memberName;
-    }
-
-    public void setMemberName(String memberName) {
-      this.memberName = memberName;
-    }
-
-    public String getDescription() {
-      return this.description;
-    }
-
-    public void setDescription(String description) {
-      this.description = description;
-    }
-
-    public int getId() {
-      return this.id;
-    }
-
-    public void setId(int id) {
-      this.id = id;
-    }
-
-    public static int nextID() {
-      /*
-       * int id = -1; synchronized (Alert.class) { ALERT_ID_CTR = ALERT_ID_CTR +
-       * 1; id = ALERT_ID_CTR; }
-       */
-      return ALERT_ID_CTR.incrementAndGet();
-    }
-
-    private static DateFormat df = new SimpleDateFormat(PulseConstants.PULSE_NOTIFICATION_ALERT_DATE_PATTERN);
-
-    public static String formatToISOTimestamp(Date date) {
-      TimeZone tz = TimeZone.getTimeZone("UTC");
-      df.setTimeZone(tz);
-      return df.format(date);
-    }
-
-  }
-
-  /**
-   * Client Inner Class
-   *
-   *
-   */
-  public static class Client {
-
-    private String id;
-    private String name;
-    private String host;
-    private int queueSize;
-    private double cpuUsage;
-    private long uptime;
-    private int threads;
-    private int gets;
-    private int puts;
-    private int cpus;
-    private int clientCQCount; 
-    private long processCpuTime;
-    private String status;
-    private boolean isConnected = false;
-    private boolean isSubscriptionEnabled = false; 
-
-    public String getId() {
-      return this.id;
-    }
-
-    public int getGets() {
-      return this.gets;
-    }
-
-    public int getPuts() {
-      return this.puts;
-    }
-
-	public int getClientCQCount() {
-	  return clientCQCount;
-	}
-
-	public void setClientCQCount(int clientCQCount) {
-	  this.clientCQCount = clientCQCount;
-	}
-     
-	public boolean isSubscriptionEnabled() { 
-	  return isSubscriptionEnabled; 
-	} 
-	 		 
-	public void setSubscriptionEnabled(boolean isSubscriptionEnabled) { 
-	  this.isSubscriptionEnabled = isSubscriptionEnabled; 
-	} 
-
-    public void setId(String id) {
-      this.id = id;
-    }
-
-    public String getName() {
-      return this.name;
-    }
-
-    public void setName(String name) {
-      this.name = name;
-    }
-
-    public String getHost() {
-      return this.host;
-    }
-
-    public void setHost(String host) {
-      this.host = host;
-    }
-
-    public int getQueueSize() {
-      return this.queueSize;
-    }
-
-    public void setQueueSize(int queueSize) {
-      this.queueSize = queueSize;
-    }
-
-    public double getCpuUsage() {
-      return this.cpuUsage;
-    }
-
-    public void setCpuUsage(double cpuUsage) {
-      this.cpuUsage = cpuUsage;
-    }
-
-    public void setGets(int gets) {
-      this.gets = gets;
-    }
-
-    public void setPuts(int puts) {
-      this.puts = puts;
-    }
-
-    public long getUptime() {
-      return this.uptime;
-    }
-
-    public void setUptime(long uptime) {
-      this.uptime = uptime;
-    }
-
-    public int getThreads() {
-      return this.threads;
-    }
-
-    public void setThreads(int threads) {
-      this.threads = threads;
-    }
-
-    public String getStatus() {
-      return this.status;
-    }
-
-    public void setStatus(String status) {
-      this.status = status;
-    }
-
-    public int getCpus() {
-      return this.cpus;
-    }
-
-    public void setCpus(int cpus) {
-      this.cpus = cpus;
-    }
-
-    public long getProcessCpuTime() {
-      return this.processCpuTime;
-    }
-
-    public void setProcessCpuTime(long processCpuTime) {
-      this.processCpuTime = processCpuTime;
-    }
-
-    public boolean isConnected() {
-      return isConnected;
-    }
-
-    public void setConnected(boolean isConnected) {
-      this.isConnected = isConnected;
-    }
-
-  }
-
-  /**
-   * Gateway Receiver Inner Class
-   *
-   *
-   */
-  public static class GatewayReceiver {
-
-    private int listeningPort;
-    private double linkThroughput;
-    private long avgBatchProcessingTime;
-    private String id;
-    private int queueSize;
-    private Boolean status;
-    private int batchSize;
-
-    public int getListeningPort() {
-      return this.listeningPort;
-    }
-
-    public void setListeningPort(int listeningPort) {
-      this.listeningPort = listeningPort;
-    }
-
-    public double getLinkThroughput() {
-      return this.linkThroughput;
-    }
-
-    public void setLinkThroughput(double linkThroughput) {
-      this.linkThroughput = linkThroughput;
-    }
-
-    public long getAvgBatchProcessingTime() {
-      return this.avgBatchProcessingTime;
-    }
-
-    public void setAvgBatchProcessingTime(long avgBatchProcessingTime) {
-      this.avgBatchProcessingTime = avgBatchProcessingTime;
-    }
-
-    public String getId() {
-      return this.id;
-    }
-
-    public void setId(String id) {
-      this.id = id;
-    }
-
-    public int getQueueSize() {
-      return this.queueSize;
-    }
-
-    public void setQueueSize(int queueSize) {
-      this.queueSize = queueSize;
-    }
-
-    public Boolean getStatus() {
-      return this.status;
-    }
-
-    public void setStatus(Boolean status) {
-      this.status = status;
-    }
-
-    public int getBatchSize() {
-      return this.batchSize;
-    }
-
-    public void setBatchSize(int batchSize) {
-      this.batchSize = batchSize;
-    }
-  }
-
-  /**
-   * Gateway Sender Inner class
-   *
-   *
-   */
-  public static class GatewaySender {
-
-    private double linkThroughput;
-    private String id;
-    private int queueSize;
-    private Boolean status;
-    private boolean primary;
-    private boolean senderType;
-    private int batchSize;
-    private boolean persistenceEnabled;
-    private int remoteDSId;
-    private int eventsExceedingAlertThreshold;
-
-    public double getLinkThroughput() {
-      return this.linkThroughput;
-    }
-
-    public void setLinkThroughput(double linkThroughput) {
-      this.linkThroughput = linkThroughput;
-    }
-
-    public String getId() {
-      return this.id;
-    }
-
-    public void setId(String id) {
-      this.id = id;
-    }
-
-    public int getQueueSize() {
-      return this.queueSize;
-    }
-
-    public void setQueueSize(int queueSize) {
-      this.queueSize = queueSize;
-    }
-
-    public Boolean getStatus() {
-      return this.status;
-    }
-
-    public void setStatus(Boolean status) {
-      this.status = status;
-    }
-
-    public boolean getPrimary() {
-      return this.primary;
-    }
-
-    public void setPrimary(boolean primary) {
-      this.primary = primary;
-    }
-
-    public boolean getSenderType() {
-      return this.senderType;
-    }
-
-    public void setSenderType(boolean senderType) {
-      this.senderType = senderType;
-    }
-
-    public int getBatchSize() {
-      return this.batchSize;
-    }
-
-    public void setBatchSize(int batchSize) {
-      this.batchSize = batchSize;
-    }
-
-    public boolean getPersistenceEnabled() {
-      return this.persistenceEnabled;
-    }
-
-    public void setPersistenceEnabled(boolean persistenceEnabled) {
-      this.persistenceEnabled = persistenceEnabled;
-    }
-
-    /**
-     * @return the remoteDSId
-     */
-    public int getRemoteDSId() {
-      return remoteDSId;
-    }
-
-    /**
-     * @param remoteDSId the remoteDSId to set
-     */
-    public void setRemoteDSId(int remoteDSId) {
-      this.remoteDSId = remoteDSId;
-    }
-
-    /**
-     * @return the eventsExceedingAlertThreshold
-     */
-    public int getEventsExceedingAlertThreshold() {
-      return eventsExceedingAlertThreshold;
-    }
-
-    /**
-     * @param eventsExceedingAlertThreshold the eventsExceedingAlertThreshold to set
-     */
-    public void setEventsExceedingAlertThreshold(int eventsExceedingAlertThreshold) {
-      this.eventsExceedingAlertThreshold = eventsExceedingAlertThreshold;
-    }
-  }
-
-  /**
-   * Async Event Queue Inner class
-   *
-   *
-   */
-  public static class AsyncEventQueue {
-
-    private String id;
-    private boolean primary;
-    private boolean parallel;
-    private int batchSize;
-    private long batchTimeInterval;
-    private boolean batchConflationEnabled;
-    private String asyncEventListener;
-    private int eventQueueSize;
-
-    public String getId() {
-      return this.id;
-    }
-
-    public void setId(String id) {
-      this.id = id;
-    }
-
-    public boolean getPrimary() {
-      return this.primary;
-    }
-
-    public void setPrimary(boolean primary) {
-      this.primary = primary;
-    }
-
-    /**
-     * @return the parallel
-     */
-    public boolean isParallel() {
-      return parallel;
-    }
-
-    /**
-     * @param parallel the parallel to set
-     */
-    public void setParallel(boolean parallel) {
-      this.parallel = parallel;
-    }
-
-    public int getBatchSize() {
-      return this.batchSize;
-    }
-
-    public void setBatchSize(int batchSize) {
-      this.batchSize = batchSize;
-    }
-
-    /**
-     * @return the batchTimeInterval
-     */
-    public long getBatchTimeInterval() {
-      return batchTimeInterval;
-    }
-
-    /**
-     * @param batchTimeInterval the batchTimeInterval to set
-     */
-    public void setBatchTimeInterval(long batchTimeInterval) {
-      this.batchTimeInterval = batchTimeInterval;
-    }
-
-    /**
-     * @return the batchConflationEnabled
-     */
-    public boolean isBatchConflationEnabled() {
-      return batchConflationEnabled;
-    }
-
-    /**
-     * @param batchConflationEnabled the batchConflationEnabled to set
-     */
-    public void setBatchConflationEnabled(boolean batchConflationEnabled) {
-      this.batchConflationEnabled = batchConflationEnabled;
-    }
-
-    /**
-     * @return the asyncEventListener
-     */
-    public String getAsyncEventListener() {
-      return asyncEventListener;
-    }
-
-    /**
-     * @param asyncEventListener the asyncEventListener to set
-     */
-    public void setAsyncEventListener(String asyncEventListener) {
-      this.asyncEventListener = asyncEventListener;
-    }
-
-    /**
-     * @return the eventQueueSize
-     */
-    public int getEventQueueSize() {
-      return eventQueueSize;
-    }
-
-    /**
-     * @param eventQueueSize the eventQueueSize to set
-     */
-    public void setEventQueueSize(int eventQueueSize) {
-      this.eventQueueSize = eventQueueSize;
-    }
-  }
-
-  /**
-   * Default constructor only used for testing
-   */
-  public Cluster() {
-  }
-
-
-  /**
-   * This function is used for calling getUpdator function of ClusterDataFactory
-   * and starting the thread for updating the Cluster details.
-   *
-   * @param host
-   *          host name
-   * @param port
-   *          port
-   * @param userName
-   *          pulse user name
-   * @param userPassword
-   *          pulse user password
-   * @throws ConnectException
-   */
-  public Cluster(String host, String port, String userName, String userPassword)
-      throws ConnectException {
-    this.serverName = host;
-    this.port = port;
-    this.jmxUserName = userName;
-    this.jmxUserPassword = userPassword;
-
-    this.updater = ClusterDataFactory.getUpdater(this, host, port);
-    // start();
-  }
-
-  /**
-   * thread run method for updating the cluster data
-   */
-  @Override
-  public void run() {
-    while (!this.stopUpdates) {
-      try {
-        if (!this.updateData()) {
-          this.stale++;
-        } else {
-          this.stale = 0;
-        }
-      } catch (Exception e) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("Exception Occurred while updating cluster data : " + e.getMessage());
-        }
-      }
-
-      try {
-        Thread.sleep(POLL_INTERVAL);
-      } catch (InterruptedException e) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info("InterruptedException Occurred : " + e.getMessage());
-        }
-      }
-    }
-
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_STOP_THREAD_UPDATES")
-          + " :: " + this.serverName + ":" + this.port);
-    }
-  }
-
-  /**
-   * calling updateData
-   *
-   * @return true if update was successful. false if it failed.
-   */
-  private boolean updateData() {
-    // This will eventually call JMX. Currently we will update this with
-    // some dummy data.
-    // Connect if required or hold a connection. If unable to connect,
-    // return false
-    if (LOGGER.finerEnabled()) {
-      LOGGER.finer(resourceBundle.getString("LOG_MSG_CLUSTER_DATA_IS_UPDATING")
-          + "::" + this.serverName + ":" + this.port);
-    }
-    return this.updater.updateData();
-  }
-
-  /**
-   * for stopping the update thread
-   */
-  public void stopThread() {
-    this.stopUpdates = true;
-
-    try {
-      join();
-    } catch (InterruptedException e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info("InterruptedException occured while stoping cluster thread : " + e.getMessage());
-      }
-    }
-  }
-
-  public Map<String, Cluster.Member> getMembersHMap() {
-    return this.membersHMap;
-  }
-
-  public void setMembersHMap(HashMap<String, Cluster.Member> membersHMap) {
-    this.membersHMap = membersHMap;
-  }
-
-  public Map<String, Boolean> getWanInformation() {
-    Map<String, Boolean> wanMap = null;
-    synchronized (this.wanInformation) {
-      wanMap = (Map<String, Boolean>) this.wanInformation.clone();
-    }
-
-    return wanMap;
-  }
-
-  // Returns actual wanInformation object reference
-  public Map<String, Boolean> getWanInformationObject() {
-    return this.wanInformation;
-  }
-
-  public void setWanInformation(HashMap<String, Boolean> wanInformation) {
-    this.wanInformation = wanInformation;
-  }
-
-  public String getJmxUserName() {
-    return this.jmxUserName;
-  }
-
-  public void setJmxUserName(String jmxUserName) {
-    this.jmxUserName = jmxUserName;
-  }
-
-  public String getJmxUserPassword() {
-    return this.jmxUserPassword;
-  }
-
-  public void setJmxUserPassword(String jmxUserPassword) {
-    this.jmxUserPassword = jmxUserPassword;
-  }
-
-  public String getConnectionErrorMsg() {
-    return this.connectionErrorMsg;
-  }
-
-  public void setConnectionErrorMsg(String connectionErrorMsg) {
-    this.connectionErrorMsg = connectionErrorMsg;
-  }
-
-  public String getServerName() {
-    return this.serverName;
-  }
-
-  public boolean isConnectedFlag() {
-    return this.connectedFlag;
-  }
-
-  public void setConnectedFlag(boolean connectedFlag) {
-    this.connectedFlag = connectedFlag;
-  }
-
-  public String getPort() {
-    return this.port;
-  }
-
-  public int getStale() {
-    return this.stale;
-  }
-
-  public double getWritePerSec() {
-    return this.writePerSec;
-  }
-
-  public void setWritePerSec(double writePerSec) {
-    this.writePerSec = writePerSec;
-  }
-
-  public double getReadPerSec() {
-    return this.readPerSec;
-  }
-
-  public void setReadPerSec(double readPerSec) {
-    this.readPerSec = readPerSec;
-  }
-
-  public double getQueriesPerSec() {
-    return this.queriesPerSec;
-  }
-
-  public void setQueriesPerSec(double queriesPerSec) {
-    this.queriesPerSec = queriesPerSec;
-  }
-
-  public double getLoadPerSec() {
-    return this.loadPerSec;
-  }
-
-  public void setLoadPerSec(double loadPerSec) {
-    this.loadPerSec = loadPerSec;
-  }
-
-  public int getNotificationPageNumber() {
-    return this.notificationPageNumber;
-  }
-
-  public void setNotificationPageNumber(int notificationPageNumber) {
-    this.notificationPageNumber = notificationPageNumber;
-  }
-
-  public void setStale(int stale) {
-    this.stale = stale;
-  }
-
-  public boolean isStopUpdates() {
-    return this.stopUpdates;
-  }
-
-  public void setStopUpdates(boolean stopUpdates) {
-    this.stopUpdates = stopUpdates;
-  }
-
-  public long getUsedHeapSize() {
-    return this.usedHeapSize;
-  }
-
-  public void setUsedHeapSize(long usedHeapSize) {
-    this.usedHeapSize = usedHeapSize;
-  }
-
-  public int getServerCount() {
-    return this.serverCount;
-  }
-
-  public void setServerCount(int serverCount) {
-    this.serverCount = serverCount;
-  }
-
-  public int getTxnCommittedCount() {
-    return txnCommittedCount;
-  }
-
-  public void setTxnCommittedCount(int txnCommittedCount) {
-    this.txnCommittedCount = txnCommittedCount;
-  }
-
-  public int getTxnRollbackCount() {
-    return txnRollbackCount;
-  }
-
-  public void setTxnRollbackCount(int txnRollbackCount) {
-    this.txnRollbackCount = txnRollbackCount;
-  }
-
-  public int getRunningFunctionCount() {
-    return this.runningFunctionCount;
-  }
-
-  public long getRegisteredCQCount() {
-    return this.registeredCQCount;
-  }
-
-  public int getSubscriptionCount() {
-    return this.subscriptionCount;
-  }
-
-  public void setSubscriptionCount(int subscriptionCount) {
-    this.subscriptionCount = subscriptionCount;
-  }
-
-  public void setRegisteredCQCount(long registeredCQCount) {
-    this.registeredCQCount = registeredCQCount;
-  }
-
-  public void setRunningFunctionCount(int runningFunctionCount) {
-    this.runningFunctionCount = runningFunctionCount;
-  }
-
-  public Map<String, Cluster.Region> getClusterRegions() {
-    return this.clusterRegionMap;
-  }
-
-  public Cluster.Region getClusterRegion(String regionFullPath) {
-    return this.clusterRegionMap.get(regionFullPath);
-  }
-
-  public void setClusterRegions(Map<String, Region> clusterRegionMap) {
-    this.clusterRegionMap = clusterRegionMap;
-  }
-
-  public Map<String, Cluster.Statement> getClusterStatements() {
-    return this.clusterStatementMap;
-  }
-
-  public void setClusterStatements(Map<String, Statement> clusterStatementMap) {
-    this.clusterStatementMap = clusterStatementMap;
-  }
-
-  public Alert[] getAlertsList() {
-    Alert[] list = null;
-    synchronized (this.alertsList) {
-      list = new Alert[this.alertsList.size()];
-      list = this.alertsList.toArray(list);
-    }
-
-    return list;
-  }
-
-  public void setAlertsList(List<Alert> alertsList) {
-    this.alertsList = alertsList;
-  }
-
-  public void setServerName(String serverName) {
-    this.serverName = serverName;
-  }
-
-  public void setPort(String port) {
-    this.port = port;
-  }
-
-  public Set<String> getDeletedMembers() {
-    return this.deletedMembers;
-  }
-
-  public void setDeletedMembers(Set<String> deletedMembers) {
-    this.deletedMembers = deletedMembers;
-  }
-
-  public Set<String> getDeletedRegions() {
-    return this.deletedRegions;
-  }
-
-  public void setDeletedRegions(Set<String> deletedRegions) {
-    this.deletedRegions = deletedRegions;
-  }
-
-  public Map<String, List<Member>> getPhysicalToMember() {
-    Map<String, List<Member>> ptom = null;
-    // synchronized (physicalToMember) {
-    ptom = this.physicalToMember;
-    // }
-    return ptom;
-  }
-
-  public void setPhysicalToMember(HashMap<String, List<Member>> physicalToMember) {
-    // synchronized (this.physicalToMember) {
-    this.physicalToMember = physicalToMember;
-    // }
-  }
-
-  public int getMemberCount() {
-    return this.memberCount;
-  }
-
-  public void setMemberCount(int memberCount) {
-    this.memberCount = memberCount;
-  }
-
-  public long getClientConnectionCount() {
-    return this.clientConnectionCount;
-  }
-
-  public void setClientConnectionCount(long clientConnectionCount) {
-    this.clientConnectionCount = clientConnectionCount;
-  }
-
-  public int getClusterId() {
-    return this.clusterId;
-  }
-
-  public void setClusterId(int clusterId) {
-    this.clusterId = clusterId;
-  }
-
-  public int getLocatorCount() {
-    return this.locatorCount;
-  }
-
-  public void setLocatorCount(int locatorCount) {
-    this.locatorCount = locatorCount;
-  }
-
-  public int getTotalRegionCount() {
-    return this.totalRegionCount;
-  }
-
-  public void setTotalRegionCount(int totalRegionCount) {
-    this.totalRegionCount = totalRegionCount;
-  }
-
-  public long getTotalHeapSize() {
-    return this.totalHeapSize;
-  }
-
-  public void setTotalHeapSize(long totalHeapSize) {
-    this.totalHeapSize = totalHeapSize;
-  }
-
-  public long getTotalRegionEntryCount() {
-    return this.totalRegionEntryCount;
-  }
-
-  public void setTotalRegionEntryCount(long totalRegionEntryCount) {
-    this.totalRegionEntryCount = totalRegionEntryCount;
-  }
-
-  public int getCurrentQueryCount() {
-    return this.currentQueryCount;
-  }
-
-  public void setCurrentQueryCount(int currentQueryCount) {
-    this.currentQueryCount = currentQueryCount;
-  }
-
-  public long getTotalBytesOnDisk() {
-    return this.totalBytesOnDisk;
-  }
-
-  public void setTotalBytesOnDisk(long totalBytesOnDisk) {
-    this.totalBytesOnDisk = totalBytesOnDisk;
-  }
-
-  public double getDiskReadsRate() {
-    return this.diskReadsRate;
-  }
-
-  public void setDiskReadsRate(double diskReadsRate) {
-    this.diskReadsRate = diskReadsRate;
-  }
-
-  public double getDiskWritesRate() {
-    return this.diskWritesRate;
-  }
-
-  public void setDiskWritesRate(double diskWritesRate) {
-    this.diskWritesRate = diskWritesRate;
-  }
-
-  public int getAvgDiskStorage() {
-    return this.avgDiskStorage;
-  }
-
-  public void setAvgDiskStorage(int avgDiskStorage) {
-    this.avgDiskStorage = avgDiskStorage;
-  }
-
-  public int getAvgDiskWritesRate() {
-    return this.avgDiskWritesRate;
-  }
-
-  public void setAvgDiskWritesRate(int avgDiskWritesRate) {
-    this.avgDiskWritesRate = avgDiskWritesRate;
-  }
-
-  public CircularFifoBuffer getWritePerSecTrend() {
-    return this.writePerSecTrend;
-  }
-
-  public void setWritePerSecTrend(CircularFifoBuffer writePerSecTrend) {
-    this.writePerSecTrend = writePerSecTrend;
-  }
-
-  public long getGarbageCollectionCount() {
-    return this.garbageCollectionCount;
-  }
-
-  public void setGarbageCollectionCount(long garbageCollectionCount) {
-    this.garbageCollectionCount = garbageCollectionCount;
-  }
-
-  public CircularFifoBuffer getTotalBytesOnDiskTrend() {
-    return this.totalBytesOnDiskTrend;
-  }
-
-  public void setTotalBytesOnDiskTrend(CircularFifoBuffer totalBytesOnDiskTrend) {
-    this.totalBytesOnDiskTrend = totalBytesOnDiskTrend;
-  }
-
-  public CircularFifoBuffer getThroughoutWritesTrend() {
-    return this.throughoutWritesTrend;
-  }
-
-  public void setThroughoutWritesTrend(CircularFifoBuffer throughoutWritesTrend) {
-    this.throughoutWritesTrend = throughoutWritesTrend;
-  }
-
-  public CircularFifoBuffer getThroughoutReadsTrend() {
-    return this.throughoutReadsTrend;
-  }
-
-  public void setThroughoutReadsTrend(CircularFifoBuffer throughoutReadsTrend) {
-    this.throughoutReadsTrend = throughoutReadsTrend;
-  }
-
-  public CircularFifoBuffer getReadPerSecTrend() {
-    return this.readPerSecTrend;
-  }
-
-  public void setReadPerSecTrend(CircularFifoBuffer readPerSecTrend) {
-    this.readPerSecTrend = readPerSecTrend;
-  }
-
-  public CircularFifoBuffer getQueriesPerSecTrend() {
-    return this.queriesPerSecTrend;
-  }
-
-  public void setQueriesPerSecTrend(CircularFifoBuffer queriesPerSecTrend) {
-    this.queriesPerSecTrend = queriesPerSecTrend;
-  }
-
-  public CircularFifoBuffer getMemoryUsageTrend() {
-    return this.memoryUsageTrend;
-  }
-
-  public void setMemoryUsageTrend(CircularFifoBuffer memoryUsageTrend) {
-    this.memoryUsageTrend = memoryUsageTrend;
-  }
-
-  public CircularFifoBuffer getGarbageCollectionTrend() {
-    return this.garbageCollectionTrend;
-  }
-
-  public void setGarbageCollectionTrend(
-      CircularFifoBuffer garbageCollectionSamples) {
-    this.garbageCollectionTrend = garbageCollectionSamples;
-  }
-
-  public long getPreviousJVMPauseCount() {
-    return this.previousJVMPauseCount;
-  }
-
-  public void setPreviousJVMPauseCount(long previousJVMPauseCount) {
-    this.previousJVMPauseCount = previousJVMPauseCount;
-  }
-
-  public DataBrowser getDataBrowser() {
-    // Initialize dataBrowser if null
-    if (this.dataBrowser == null) {
-      this.dataBrowser = new DataBrowser();
-    }
-    return this.dataBrowser;
-  }
-
-  public void setDataBrowser(DataBrowser dataBrowser) {
-    this.dataBrowser = dataBrowser;
-  }
-
-  public ObjectNode executeQuery(String queryText, String members, int limit) {
-    // Execute data browser query
-    return this.updater.executeQuery(queryText, members, limit);
-  }
-
-  public ArrayNode getQueryHistoryByUserId(String userId) {
-    return this.getDataBrowser().getQueryHistoryByUserId(userId);
-  }
-
-  public boolean addQueryInHistory(String queryText, String userName) {
-    return this.getDataBrowser().addQueryInHistory(queryText, userName);
-  }
-
-  public boolean deleteQueryById(String userId, String queryId) {
-    return this.getDataBrowser().deleteQueryById(userId, queryId);
-  }
-  
-  public JMXConnector connectToGemFire() {
-    if(this.updater instanceof JMXDataUpdater) {
-      return ((JMXDataUpdater) this.updater).getJMXConnection(false);
-    } else {
-      return null;
-    }
-  }
-
-  /**
-   * inner class for creating Mock Data
-   *
-   *
-   */
-  public class MockDataUpdater implements IClusterUpdater {
-    public MockDataUpdater() {
-    }
-
-    /**
-     * function used for updating Cluster data for Mock
-     */
-    @Override
-    public boolean updateData() {
-      setConnectedFlag(true);
-      Random r = new Random(System.currentTimeMillis());
-      totalHeapSize = (long) Math.abs(r.nextInt(3200 - 2048) + 2048);
-      usedHeapSize = (long) Math.abs(r.nextInt(2048));
-      writePerSec = Math.abs(r.nextInt(100));
-      subscriptionCount = Math.abs(r.nextInt(100));
-      registeredCQCount = (long) Math.abs(r.nextInt(100));
-      txnCommittedCount = Math.abs(r.nextInt(100));
-      txnRollbackCount = Math.abs(r.nextInt(100));
-      runningFunctionCount = Math.abs(r.nextInt(100));
-      clusterId = Math.abs(r.nextInt(100));
-      writePerSecTrend.add(writePerSec);
-      diskWritesRate = writePerSec;
-      garbageCollectionCount = (long) Math.abs(r.nextInt(100));
-      garbageCollectionTrend.add(garbageCollectionCount);
-
-      readPerSec = Math.abs(r.nextInt(100));
-      readPerSecTrend.add(readPerSec);
-
-      diskReadsRate = readPerSec;
-      queriesPerSec = Math.abs(r.nextInt(100));
-      queriesPerSecTrend.add(queriesPerSec);
-
-      loadPerSec = Math.abs(r.nextInt(100));
-      totalHeapSize = totalHeapSize;
-      totalBytesOnDisk = totalHeapSize;
-
-      totalBytesOnDiskTrend.add(totalBytesOnDisk);
-
-      memoryUsageTrend.add(usedHeapSize);
-      throughoutWritesTrend.add(writePerSec);
-      throughoutReadsTrend.add(readPerSec);
-
-      memberCount = 0;
-
-      // Create 3 members first time around
-      if (membersHMap.size() == 0) {
-
-        membersHMap.put(
-            "pnq-visitor1",
-            initializeMember(
-                "pnq-visitor1(Launcher_Manager-1099-13-40-24-5368)-24357",
-                "pnq-visitor1", true, true, true, true));
-
-        for (int i = 2; i <= 8; i++) {
-          if ((i % 2) == 0) {
-            membersHMap.put(
-                "pnq-visitor" + i,
-                initializeMember("pnq-visitor" + i
-                    + "(Launcher_Server-1099-13-40-24-5368)-24357",
-                    "pnq-visitor" + i, false, false, true, false));
-          } else {
-            if ((i % 3) == 0) {
-              membersHMap.put(
-                  "pnq-visitor" + i,
-                  initializeMember("pnq-visitor" + i
-                      + "(Launcher_Server-1099-13-40-24-5368)-24357",
-                      "pnq-visitor" + i, false, false, false, false));
-            } else {
-              membersHMap.put(
-                  "pnq-visitor" + i,
-                  initializeMember("pnq-visitor" + i
-                      + "(Launcher_Server-1099-13-40-24-5368)-24357",
-                      "pnq-visitor" + i, false, true, true, true));
-            }
-          }
-        }
-
-        for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
-          HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
-          HashMap<String, Cluster.Client> memberClientsHM = new HashMap<String, Cluster.Client>();
-
-          Random randomGenerator = new Random();
-          int randomInt = (randomGenerator.nextInt(15)) + 10;
-          int regionExists = 0;
-          for (int y = 0; y < randomInt; y++) {
-            Region region = initMemberRegion(y, memberSet.getValue().getName());
-            if (clusterRegionMap.entrySet().size() > 0) {
-              for (Region clusterRegion : clusterRegionMap.values()) {
-                if ((region.name).equals(clusterRegion.name)) {
-                  clusterRegion.memberName.add(memberSet.getValue().getName());
-                  clusterRegion.memberCount = clusterRegion.memberCount + 1;
-                  regionExists = 1;
-                  break;
-                }
-              }
-              if (regionExists == 0) {
-                addClusterRegion(region.getFullPath(), region);
-              }
-            } else {
-              addClusterRegion(region.getFullPath(), region);
-            }
-            memberRegions.put(region.getFullPath(), region);
-            totalRegionCount = clusterRegionMap.values().size();
-          }
-          membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
-
-          if (memberSet.getValue().isCache) {
-            Client client = initMemberClient(0, memberSet.getValue().getHost());
-            memberClientsHM.put(client.getId(), client);
-            randomInt = randomGenerator.nextInt(10);
-            for (int y = 1; y < randomInt; y++) {
-              Client newClient = initMemberClient(y, memberSet.getValue()
-                  .getHost());
-              memberClientsHM.put(newClient.getId(), newClient);
-            }
-            membersHMap.get(memberSet.getKey()).updateMemberClientsHMap(
-                memberClientsHM);
-            clientConnectionCount = clientConnectionCount
-                + membersHMap.get(memberSet.getKey()).getMemberClientsHMap()
-                    .size();
-          }
-
-        }
-      }
-
-		// add additional regions to members
-      for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
-        HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
-
-        Random randomGenerator = new Random();
-        int randomInt = (randomGenerator.nextInt(5)) + 5;
-        int regionExists = 0;
-        for (int y = 0; y < randomInt; y++) {
-          Region region = initMemberRegion(y, memberSet.getValue().getName());
-          if (clusterRegionMap.entrySet().size() > 0) {
-            for (Region clusterRegion : clusterRegionMap.values()) {
-              if ((region.name).equals(clusterRegion.name)) {
-                clusterRegion.memberName.add(memberSet.getValue().getName());
-                clusterRegion.memberCount = clusterRegion.memberCount + 1;
-                regionExists = 1;
-                break;
-              }
-            }
-            if (regionExists == 0) {
-              addClusterRegion(region.getFullPath(), region);
-            }
-          } else {
-            addClusterRegion(region.getFullPath(), region);
-          }
-          memberRegions.put(region.getFullPath(), region);
-          totalRegionCount = clusterRegionMap.values().size();
-        }
-        membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
-
-      }
-
-      wanInformation.clear();
-      int wanInfoSize = Math.abs(r.nextInt(10));
-      wanInfoSize++;
-      for (int i = 0; i < wanInfoSize; i++) {
-        String name = "Mock Cluster" + i;
-        Boolean value = false;
-        if (i % 2 == 0) {
-          value = true;
-        }
-        wanInformation.put(name, value);
-      }
-      memberCount = membersHMap.size();
-
-      totalHeapSize = (long) 0;
-      for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
-        refresh(membersHMap.get(memberSet.getKey()));
-        Member member = membersHMap.get(memberSet.getKey());
-        totalHeapSize += member.currentHeapSize;
-      }
-
-      for (Region region : clusterRegionMap.values()) {
-        // Memory reads and writes
-        region.getsRate = (Math.abs(r.nextInt(100))) + 1;
-        region.putsRate = (Math.abs(r.nextInt(100))) + 1;
-        region.getsPerSecTrend.add(region.getsRate);
-        region.putsPerSecTrend.add(region.putsRate);
-
-        // Disk reads and writes
-        region.diskReadsRate = (Math.abs(r.nextInt(100))) + 1;
-        region.diskWritesRate = (Math.abs(r.nextInt(100))) + 1;
-        region.diskReadsPerSecTrend.add(region.diskReadsRate);
-        region.diskWritesPerSecTrend.add(region.diskWritesRate);
-      }
-
-      if(clusterStatementMap.size() < 500){
-        for(int i = 1; i <= 500; ++i) 

<TRUNCATED>

[70/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Cluster.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Cluster.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Cluster.java
new file mode 100644
index 0000000..7bf44ff
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/Cluster.java
@@ -0,0 +1,3815 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.apache.commons.collections.buffer.CircularFifoBuffer;
+
+import javax.management.remote.JMXConnector;
+import java.io.BufferedReader;
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.InputStreamReader;
+import java.lang.reflect.Constructor;
+import java.lang.reflect.InvocationTargetException;
+import java.net.ConnectException;
+import java.net.URL;
+import java.text.DateFormat;
+import java.text.SimpleDateFormat;
+import java.util.ArrayList;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Map.Entry;
+import java.util.Random;
+import java.util.ResourceBundle;
+import java.util.Set;
+import java.util.TimeZone;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.atomic.AtomicInteger;
+/**
+ * Class Cluster This class is the Data Model for the data used for the Pulse
+ * Web UI.
+ *
+ * @since GemFire version 7.0.Beta 2012-09-23
+ */
+public class Cluster extends Thread {
+  private static final int POLL_INTERVAL = 5000;
+  public static final int MAX_SAMPLE_SIZE = 180;
+  public static final int ALERTS_MAX_SIZE = 1000;
+  public static final int PAGE_ALERTS_MAX_SIZE = 100;
+
+  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+  private final ResourceBundle resourceBundle = Repository.get()
+      .getResourceBundle();
+
+  private String jmxUserName;
+  private String jmxUserPassword;
+  private String serverName;
+  private String port;
+  private int stale = 0;
+  private double loadPerSec;
+
+  // start: fields defined in System MBean
+  private IClusterUpdater updater = null;
+  private DataBrowser dataBrowser = null;
+  private int memberCount;
+  private long clientConnectionCount;
+  private int locatorCount;
+  private int totalRegionCount;
+  private long totalHeapSize = 0L;
+  private long totalRegionEntryCount;
+  private int currentQueryCount;
+  private long totalBytesOnDisk;
+  private double diskReadsRate;
+  private double diskWritesRate;
+  private double writePerSec;
+  private double readPerSec;
+  private double queriesPerSec;
+  private int avgDiskStorage;
+  private int avgDiskWritesRate;
+  private int runningFunctionCount;
+  private long registeredCQCount;
+  private int subscriptionCount;
+  private int serverCount;
+  private int txnCommittedCount;
+  private int txnRollbackCount;
+  private long usedHeapSize = 0L;
+  private long garbageCollectionCount = 0L;
+  private int clusterId;
+  private int notificationPageNumber = 1;
+  private boolean connectedFlag;
+  private String connectionErrorMsg = "";
+
+  private Set<String> deletedMembers = new HashSet<String>();
+
+  private Map<String, List<Cluster.Member>> physicalToMember = new HashMap<String, List<Cluster.Member>>();
+
+  private Map<String, Cluster.Member> membersHMap = new HashMap<String, Cluster.Member>();
+
+  private Set<String> deletedRegions = new HashSet<String>();
+
+  private Map<String, Cluster.Region> clusterRegionMap = new ConcurrentHashMap<String, Cluster.Region>();
+  private List<Cluster.Alert> alertsList = new ArrayList<Cluster.Alert>();
+
+  private CircularFifoBuffer totalBytesOnDiskTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer throughoutWritesTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer throughoutReadsTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer writePerSecTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer readPerSecTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer queriesPerSecTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer memoryUsageTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private CircularFifoBuffer garbageCollectionTrend = new CircularFifoBuffer(
+      MAX_SAMPLE_SIZE);
+  private long previousJVMPauseCount = 0L;
+
+  private HashMap<String, Boolean> wanInformation = new HashMap<String, Boolean>();
+  private Map<String, Cluster.Statement> clusterStatementMap = new ConcurrentHashMap<String, Cluster.Statement>();
+
+  public static final int CLUSTER_STAT_TOTAL_BYTES_ON_DISK = 0;
+  public static final int CLUSTER_STAT_THROUGHPUT_WRITES = 1;
+  public static final int CLUSTER_STAT_THROUGHPUT_READS = 2;
+  public static final int CLUSTER_STAT_WRITES_PER_SECOND = 3;
+  public static final int CLUSTER_STAT_READ_PER_SECOND = 4;
+  public static final int CLUSTER_STAT_QUERIES_PER_SECOND = 5;
+  public static final int CLUSTER_STAT_MEMORY_USAGE = 6;
+  public static final int CLUSTER_STAT_GARBAGE_COLLECTION = 7;
+
+  // end: fields defined in System MBean
+
+  // used for updating member's client data
+  public static long LAST_UPDATE_TIME = 0;
+
+  public int getStaleStatus() {
+    return this.stale;
+  }
+
+  private boolean stopUpdates = false;
+
+  private static final int MAX_HOSTS = 40;
+
+  private final List<String> hostNames = new ArrayList<String>();
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public Object[] getStatisticTrend(int trendId) {
+
+    Object[] returnArray = null;
+    switch (trendId) {
+    case CLUSTER_STAT_TOTAL_BYTES_ON_DISK:
+      synchronized (this.totalBytesOnDiskTrend) {
+        returnArray = this.totalBytesOnDiskTrend.toArray();
+      }
+
+      break;
+
+    case CLUSTER_STAT_THROUGHPUT_READS:
+      synchronized (this.throughoutReadsTrend) {
+        returnArray = this.throughoutReadsTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_THROUGHPUT_WRITES:
+      synchronized (this.throughoutWritesTrend) {
+        returnArray = this.throughoutWritesTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_WRITES_PER_SECOND:
+      synchronized (this.writePerSecTrend) {
+        returnArray = this.writePerSecTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_READ_PER_SECOND:
+      synchronized (this.readPerSecTrend) {
+        returnArray = this.readPerSecTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_QUERIES_PER_SECOND:
+      synchronized (this.queriesPerSecTrend) {
+        returnArray = this.queriesPerSecTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_MEMORY_USAGE:
+      synchronized (this.memoryUsageTrend) {
+        returnArray = this.memoryUsageTrend.toArray();
+      }
+      break;
+
+    case CLUSTER_STAT_GARBAGE_COLLECTION:
+      synchronized (this.garbageCollectionTrend) {
+        returnArray = this.garbageCollectionTrend.toArray();
+      }
+      break;
+    }
+
+    return returnArray;
+  }
+
+  /**
+   * Member Inner Class
+   *
+   *
+   */
+  public static class Member {
+
+    // start: fields defined in MBean
+    private String gemfireVersion;
+    private boolean manager;
+    private int totalRegionCount;
+    private String host;
+    private String hostnameForClients;
+    private String bindAddress;
+    private long currentHeapSize;
+    private long maxHeapSize;
+    private int avgHeapUsage;
+    private long OffHeapFreeSize;
+    private long OffHeapUsedSize;
+    private long totalBytesOnDisk;
+    private String memberPort;
+
+    private double cpuUsage = 0.0d;
+    private double hostCpuUsage = 0.0d;
+    private long uptime;
+    private String name;
+    private double getsRate;
+    private double putsRate;
+    private boolean isCache;
+    private boolean isGateway;
+    private boolean isLocator;
+    private boolean isServer;
+    private double loadAverage;
+    private int numThreads;
+    private long totalFileDescriptorOpen;
+    private long garbageCollectionCount = 0L;
+    private double throughputWrites;
+    private double throughputReads;
+    private long totalDiskUsage;
+    private String queueBacklog;
+    private String id;
+    private long numSqlfireClients = 0;
+
+    private List<String> serverGroups = new ArrayList<String>();
+    private List<String> redundancyZones = new ArrayList<String>();
+
+    private CircularFifoBuffer cpuUsageSamples = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer heapUsageSamples = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
+    private HashMap<String, Cluster.Client> memberClientsHMap = new HashMap<String, Cluster.Client>();
+    private CircularFifoBuffer totalBytesOnDiskSamples = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer getsPerSecond = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer putsPerSecond = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer throughputWritesTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer throughputReadsTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer garbageCollectionSamples = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private long previousJVMPauseCount = 0L;
+
+    private Cluster.GatewayReceiver gatewayReceiver = null;
+    private List<Cluster.GatewaySender> gatewaySenderList = new ArrayList<Cluster.GatewaySender>();
+    private List<Cluster.AsyncEventQueue> asyncEventQueueList = new ArrayList<Cluster.AsyncEventQueue>();
+    // end: fields defined in MBean
+
+    public static final int MEMBER_STAT_GARBAGE_COLLECTION = 0;
+    public static final int MEMBER_STAT_HEAP_USAGE_SAMPLE = 1;
+    public static final int MEMBER_STAT_CPU_USAGE_SAMPLE = 2;
+    public static final int MEMBER_STAT_GETS_PER_SECOND = 3;
+    public static final int MEMBER_STAT_PUTS_PER_SECOND = 4;
+    public static final int MEMBER_STAT_THROUGHPUT_WRITES = 5;
+    public static final int MEMBER_STAT_THROUGHPUT_READS = 6;
+
+    public Cluster.Region[] getMemberRegionsList() {
+      Cluster.Region[] memberReg = null;
+      synchronized (memberRegions) {
+        memberReg = new Cluster.Region[memberRegions.size()];
+        memberReg = memberRegions.values().toArray(memberReg);
+      }
+
+      return memberReg;
+    }
+
+    public Cluster.Client[] getMemberClients() {
+      Cluster.Client[] memberClients = null;
+      synchronized (memberClientsHMap) {
+        memberClients = new Cluster.Client[memberClientsHMap.size()];
+        memberClients = memberClientsHMap.values().toArray(memberClients);
+      }
+
+      return memberClients;
+    }
+
+    public Cluster.GatewaySender[] getMemberGatewaySenders() {
+      Cluster.GatewaySender[] memberGWS = null;
+      synchronized (gatewaySenderList) {
+        memberGWS = new Cluster.GatewaySender[gatewaySenderList.size()];
+        memberGWS = gatewaySenderList.toArray(memberGWS);
+      }
+      return memberGWS;
+    }
+
+    public Cluster.AsyncEventQueue[] getMemberAsyncEventQueueList() {
+      Cluster.AsyncEventQueue[] memberAEQ = null;
+      synchronized (asyncEventQueueList) {
+        memberAEQ = new Cluster.AsyncEventQueue[asyncEventQueueList.size()];
+        memberAEQ = asyncEventQueueList.toArray(memberAEQ);
+      }
+      return memberAEQ;
+    }
+
+    public Object[] getMemberStatisticTrend(int trendId) {
+      Object[] returnArray = null;
+      switch (trendId) {
+      case MEMBER_STAT_GARBAGE_COLLECTION:
+        synchronized (this.garbageCollectionSamples) {
+          returnArray = this.garbageCollectionSamples.toArray();
+        }
+
+        break;
+
+      case MEMBER_STAT_HEAP_USAGE_SAMPLE:
+        synchronized (this.heapUsageSamples) {
+          returnArray = this.heapUsageSamples.toArray();
+        }
+        break;
+
+      case MEMBER_STAT_CPU_USAGE_SAMPLE:
+        synchronized (this.cpuUsageSamples) {
+          returnArray = this.cpuUsageSamples.toArray();
+        }
+        break;
+
+      case MEMBER_STAT_GETS_PER_SECOND:
+        synchronized (this.getsPerSecond) {
+          returnArray = this.getsPerSecond.toArray();
+        }
+        break;
+
+      case MEMBER_STAT_PUTS_PER_SECOND:
+        synchronized (this.putsPerSecond) {
+          returnArray = this.putsPerSecond.toArray();
+        }
+        break;
+
+      case MEMBER_STAT_THROUGHPUT_WRITES:
+        synchronized (this.throughputWritesTrend) {
+          returnArray = this.throughputWritesTrend.toArray();
+        }
+        break;
+
+      case MEMBER_STAT_THROUGHPUT_READS:
+        synchronized (this.throughputReadsTrend) {
+          returnArray = this.throughputReadsTrend.toArray();
+        }
+        break;
+      }
+
+      return returnArray;
+    }
+
+    public String getGemfireVersion() {
+      return gemfireVersion;
+    }
+
+    public void setGemfireVersion(String gemfireVersion) {
+      this.gemfireVersion = gemfireVersion;
+    }
+
+    public String getMemberPort() {
+      return this.memberPort;
+    }
+
+    public void setMemberPort(String memberPort) {
+      this.memberPort = memberPort;
+    }
+
+    public double getThroughputWrites() {
+      return this.throughputWrites;
+    }
+
+    public void setThroughputWrites(double throughputWrites) {
+      this.throughputWrites = throughputWrites;
+    }
+
+    public double getThroughputReads() {
+      return this.throughputReads;
+    }
+
+    public void setThroughputReads(double throughputReads) {
+      this.throughputReads = throughputReads;
+    }
+
+    public long getTotalDiskUsage() {
+      return this.totalDiskUsage;
+    }
+
+    public void setTotalDiskUsage(long totalDiskUsage) {
+      this.totalDiskUsage = totalDiskUsage;
+    }
+
+    public String getId() {
+      return this.id;
+    }
+
+    public String getName() {
+      return this.name;
+    }
+
+    public double getLoadAverage() {
+      return this.loadAverage;
+    }
+
+    public void setLoadAverage(Double loadAverage) {
+      this.loadAverage = loadAverage;
+    }
+
+    public String getHost() {
+      return this.host;
+    }
+
+    public String getHostnameForClients() {
+      if(StringUtils.isNotNullNotEmptyNotWhiteSpace(hostnameForClients))
+        return this.hostnameForClients;
+      else if(StringUtils.isNotNullNotEmptyNotWhiteSpace(bindAddress))
+        return this.bindAddress;
+      return null;
+    }
+
+    public long getUptime() {
+      return this.uptime;
+    }
+
+    public String getQueueBacklog() {
+      return this.queueBacklog;
+    }
+
+    public HashMap<String, Cluster.Region> getMemberRegions() {
+      return this.memberRegions;
+    }
+
+    public void setMemberRegions(HashMap<String, Cluster.Region> memberRegions) {
+      this.memberRegions = memberRegions;
+    }
+
+    public long getCurrentHeapSize() {
+      return this.currentHeapSize;
+    }
+
+    public void setCurrentHeapSize(long currentHeapSize) {
+      this.currentHeapSize = currentHeapSize;
+    }
+
+    public long getMaxHeapSize() {
+      return this.maxHeapSize;
+    }
+
+    public void setMaxHeapSize(long maxHeapSize) {
+      this.maxHeapSize = maxHeapSize;
+    }
+
+    public boolean isManager() {
+      return this.manager;
+    }
+
+    public void setManager(boolean manager) {
+      this.manager = manager;
+    }
+
+    public int getAvgHeapUsage() {
+      return this.avgHeapUsage;
+    }
+
+    public void setAvgHeapUsage(int avgHeapUsage) {
+      this.avgHeapUsage = avgHeapUsage;
+    }
+
+    public long getOffHeapFreeSize() {
+      return OffHeapFreeSize;
+    }
+
+    public void setOffHeapFreeSize(long offHeapFreeSize) {
+      this.OffHeapFreeSize = offHeapFreeSize;
+    }
+
+    public long getOffHeapUsedSize() {
+      return OffHeapUsedSize;
+    }
+
+    public void setOffHeapUsedSize(long offHeapUsedSize) {
+      this.OffHeapUsedSize = offHeapUsedSize;
+    }
+
+    public void setId(String id) {
+      this.id = id;
+    }
+
+    public void setName(String name) {
+      this.name = name;
+    }
+
+    public void setHost(String host) {
+      this.host = host;
+    }
+
+    public void setHostnameForClients(String hostnameForClients) {
+      this.hostnameForClients = hostnameForClients;
+    }
+
+    public void setBindAddress(String bindAddress){
+      this.bindAddress = bindAddress;
+    }
+
+    public void setUptime(long uptime) {
+      this.uptime = uptime;
+    }
+
+    public void setQueueBacklog(String queueBacklog) {
+      this.queueBacklog = queueBacklog;
+    }
+
+    public int getTotalRegionCount() {
+      return this.totalRegionCount;
+    }
+
+    public void setTotalRegionCount(int totalRegionCount) {
+      this.totalRegionCount = totalRegionCount;
+    }
+
+    public long getTotalBytesOnDisk() {
+      return this.totalBytesOnDisk;
+    }
+
+    public void setTotalBytesOnDisk(long totalBytesOnDisk) {
+      this.totalBytesOnDisk = totalBytesOnDisk;
+    }
+
+    public double getCpuUsage() {
+      return this.cpuUsage;
+    }
+
+    public void setCpuUsage(double cpuUsage) {
+      this.cpuUsage = cpuUsage;
+    }
+
+    public double getHostCpuUsage() {
+      return this.hostCpuUsage;
+    }
+
+    public void setHostCpuUsage(double hostCpuUsage) {
+      this.hostCpuUsage = hostCpuUsage;
+    }
+
+    public double getGetsRate() {
+      return this.getsRate;
+    }
+
+    public void setGetsRate(double getsRate) {
+      this.getsRate = getsRate;
+    }
+
+    public double getPutsRate() {
+      return this.putsRate;
+    }
+
+    public void setPutsRate(double putsRate) {
+      this.putsRate = putsRate;
+    }
+
+    public HashMap<String, Cluster.Client> getMemberClientsHMap() {
+      return this.memberClientsHMap;
+    }
+
+    public void setMemberClientsHMap(
+        HashMap<String, Cluster.Client> memberClientsHMap) {
+      this.memberClientsHMap = memberClientsHMap;
+    }
+
+    public boolean isCache() {
+      return this.isCache;
+    }
+
+    public void setCache(boolean isCache) {
+      this.isCache = isCache;
+    }
+
+    public boolean isGateway() {
+      return this.isGateway;
+    }
+
+    public void setGateway(boolean isGateway) {
+      this.isGateway = isGateway;
+    }
+
+    public int getNumThreads() {
+      return this.numThreads;
+    }
+
+    public void setNumThreads(int numThreads) {
+      this.numThreads = numThreads;
+    }
+
+    public long getTotalFileDescriptorOpen() {
+      return this.totalFileDescriptorOpen;
+    }
+
+    public void setTotalFileDescriptorOpen(long totalFileDescriptorOpen) {
+      this.totalFileDescriptorOpen = totalFileDescriptorOpen;
+    }
+
+    public long getGarbageCollectionCount() {
+      return this.garbageCollectionCount;
+    }
+
+    public void setGarbageCollectionCount(long garbageCollectionCount) {
+      this.garbageCollectionCount = garbageCollectionCount;
+    }
+
+    public boolean isLocator() {
+      return this.isLocator;
+    }
+
+    public void setLocator(boolean isLocator) {
+      this.isLocator = isLocator;
+    }
+
+    public Cluster.GatewayReceiver getGatewayReceiver() {
+      return this.gatewayReceiver;
+    }
+
+    public void setGatewayReceiver(Cluster.GatewayReceiver gatewayReceiver) {
+      this.gatewayReceiver = gatewayReceiver;
+    }
+
+    public List<Cluster.GatewaySender> getGatewaySenderList() {
+      return this.gatewaySenderList;
+    }
+
+    public void setGatewaySenderList(
+        List<Cluster.GatewaySender> gatewaySenderList) {
+      this.gatewaySenderList = gatewaySenderList;
+    }
+
+    public List<Cluster.AsyncEventQueue> getAsyncEventQueueList() {
+      return this.asyncEventQueueList;
+    }
+
+    public void setAsyncEventQueueList(
+        List<Cluster.AsyncEventQueue> asyncEventQueueList) {
+      this.asyncEventQueueList = asyncEventQueueList;
+    }
+
+    public boolean isServer() {
+      return this.isServer;
+    }
+
+    public void setServer(boolean isServer) {
+      this.isServer = isServer;
+    }
+
+    public List<String> getServerGroups() {
+      return this.serverGroups;
+    }
+
+    public void setServerGroups(List<String> serverGroups) {
+      this.serverGroups = serverGroups;
+    }
+
+    public List<String> getRedundancyZones() {
+      return this.redundancyZones;
+    }
+
+    public void setRedundancyZones(List<String> redundancyZones) {
+      this.redundancyZones = redundancyZones;
+    }
+
+    public CircularFifoBuffer getCpuUsageSamples() {
+      return this.cpuUsageSamples;
+    }
+
+    public void setCpuUsageSamples(CircularFifoBuffer cpuUsageSamples) {
+      this.cpuUsageSamples = cpuUsageSamples;
+    }
+
+    public CircularFifoBuffer getHeapUsageSamples() {
+      return this.heapUsageSamples;
+    }
+
+    public void setHeapUsageSamples(CircularFifoBuffer heapUsageSamples) {
+      this.heapUsageSamples = heapUsageSamples;
+    }
+
+    public CircularFifoBuffer getTotalBytesOnDiskSamples() {
+      return this.totalBytesOnDiskSamples;
+    }
+
+    public void setTotalBytesOnDiskSamples(
+        CircularFifoBuffer totalBytesOnDiskSamples) {
+      this.totalBytesOnDiskSamples = totalBytesOnDiskSamples;
+    }
+
+    public CircularFifoBuffer getGetsPerSecond() {
+      return this.getsPerSecond;
+    }
+
+    public void setGetsPerSecond(CircularFifoBuffer getsPerSecond) {
+      this.getsPerSecond = getsPerSecond;
+    }
+
+    public CircularFifoBuffer getPutsPerSecond() {
+      return this.putsPerSecond;
+    }
+
+    public void setPutsPerSecond(CircularFifoBuffer putsPerSecond) {
+      this.putsPerSecond = putsPerSecond;
+    }
+
+    public CircularFifoBuffer getThroughputWritesTrend() {
+      return this.throughputWritesTrend;
+    }
+
+    public void setThroughputWritesTrend(
+        CircularFifoBuffer throughputWritesTrend) {
+      this.throughputWritesTrend = throughputWritesTrend;
+    }
+
+    public CircularFifoBuffer getThroughputReadsTrend() {
+      return this.throughputReadsTrend;
+    }
+
+    public void setThroughputReadsTrend(CircularFifoBuffer throughputReadsTrend) {
+      this.throughputReadsTrend = throughputReadsTrend;
+    }
+
+    public CircularFifoBuffer getGarbageCollectionSamples() {
+      return this.garbageCollectionSamples;
+    }
+
+    public void setGarbageCollectionSamples(
+        CircularFifoBuffer garbageCollectionSamples) {
+      this.garbageCollectionSamples = garbageCollectionSamples;
+    }
+
+    public long getPreviousJVMPauseCount() {
+      return this.previousJVMPauseCount;
+    }
+
+    public void setPreviousJVMPauseCount(long previousJVMPauseCount) {
+      this.previousJVMPauseCount = previousJVMPauseCount;
+    }
+
+    public long getNumSqlfireClients() {
+      return numSqlfireClients;
+    }
+
+    public void setNumSqlfireClients(long numSqlfireClients) {
+      this.numSqlfireClients = numSqlfireClients;
+    }
+
+    public void updateMemberClientsHMap(
+        HashMap<String, Cluster.Client> memberClientsHM) {
+
+      if (Cluster.LAST_UPDATE_TIME == 0) {
+        Cluster.LAST_UPDATE_TIME = System.nanoTime();
+      }
+
+      long systemNanoTime = System.nanoTime();
+
+      for (Map.Entry<String, Cluster.Client> entry : memberClientsHM.entrySet()) {
+        String clientId = entry.getKey();
+        Cluster.Client client = entry.getValue();
+
+        if (memberClientsHMap.get(clientId) != null) {
+          Client existingClient = memberClientsHMap.get(clientId);
+          Client updatedClient = memberClientsHM.get(clientId);
+
+          existingClient.setConnected(updatedClient.isConnected());
+          existingClient.setGets(updatedClient.getGets());
+          existingClient.setPuts(updatedClient.getPuts());
+          existingClient.setCpus(updatedClient.getCpus());
+          existingClient.setQueueSize(updatedClient.getQueueSize());
+          existingClient.setStatus(updatedClient.getStatus());
+          existingClient.setThreads(updatedClient.getThreads());
+          existingClient.setClientCQCount(updatedClient.getClientCQCount()); 
+       	  existingClient.setSubscriptionEnabled(updatedClient.isSubscriptionEnabled()); 
+          long elapsedTime = updatedClient.getUptime()
+              - existingClient.getUptime();
+          existingClient.setUptime(updatedClient.getUptime());
+
+          // set cpu usage
+          long lastCPUTime = 0;
+          lastCPUTime = existingClient.getProcessCpuTime();
+          long currCPUTime = 0;
+          currCPUTime = updatedClient.getProcessCpuTime();
+
+          double newCPUTime = (double) (currCPUTime - lastCPUTime)
+              / (elapsedTime * 1000000000);
+
+          double newCPUUsage = 0;
+          int availableCpus = updatedClient.getCpus();
+          if (availableCpus > 0) {
+            newCPUUsage = newCPUTime / availableCpus;
+          }
+
+          existingClient.setCpuUsage(newCPUUsage);
+          existingClient.setProcessCpuTime(currCPUTime);
+
+        } else {
+          // Add client to clients list
+          memberClientsHMap.put(clientId, client);
+        }
+
+      }
+
+      // Remove unwanted entries from clients list
+      HashMap<String, Cluster.Client> memberClientsHMapNew = new HashMap<String, Cluster.Client>();
+      for (Map.Entry<String, Cluster.Client> entry : memberClientsHMap
+          .entrySet()) {
+        String clientId = entry.getKey();
+        if (memberClientsHM.get(clientId) != null) {
+          memberClientsHMapNew.put(clientId, memberClientsHMap.get(clientId));
+        }
+      }
+      // replace existing memberClientsHMap by memberClientsHMapNew
+      this.setMemberClientsHMap(memberClientsHMapNew);
+
+      // update last update time
+      Cluster.LAST_UPDATE_TIME = systemNanoTime;
+
+    }
+
+  }
+
+  /**
+   * Member Inner Class
+   *
+   *
+   */
+  public static class Statement {
+
+    private String queryDefn;
+    private long numTimesCompiled;
+    private long numExecution;
+    private long numExecutionsInProgress;
+    private long numTimesGlobalIndexLookup;
+    private long numRowsModified;
+    private long parseTime;
+    private long bindTime;
+    private long optimizeTime;
+    private long routingInfoTime;
+    private long generateTime;
+    private long totalCompilationTime;
+    private long executionTime;
+    private long projectionTime;
+    private long totalExecutionTime;
+    private long rowsModificationTime;
+    private long qNNumRowsSeen;
+    private long qNMsgSendTime;
+    private long qNMsgSerTime;
+    private long qNRespDeSerTime;
+
+    public static String[] getGridColumnNames() {
+      String[] colNames = new String[] {
+          PulseConstants.MBEAN_COLNAME_QUERYDEFINITION,
+          PulseConstants.MBEAN_COLNAME_NUMEXECUTION,
+          PulseConstants.MBEAN_COLNAME_TOTALEXECUTIONTIME,
+          PulseConstants.MBEAN_COLNAME_NUMEXECUTIONSINPROGRESS,
+          PulseConstants.MBEAN_COLNAME_NUMTIMESCOMPILED,
+          PulseConstants.MBEAN_COLNAME_NUMTIMESGLOBALINDEXLOOKUP,
+          PulseConstants.MBEAN_COLNAME_NUMROWSMODIFIED,
+          PulseConstants.MBEAN_COLNAME_PARSETIME,
+          PulseConstants.MBEAN_COLNAME_BINDTIME,
+          PulseConstants.MBEAN_COLNAME_OPTIMIZETIME,
+          PulseConstants.MBEAN_COLNAME_ROUTINGINFOTIME,
+          PulseConstants.MBEAN_COLNAME_GENERATETIME,
+          PulseConstants.MBEAN_COLNAME_TOTALCOMPILATIONTIME,
+          PulseConstants.MBEAN_COLNAME_EXECUTIONTIME,
+          PulseConstants.MBEAN_COLNAME_PROJECTIONTIME,
+          PulseConstants.MBEAN_COLNAME_ROWSMODIFICATIONTIME,
+          PulseConstants.MBEAN_COLNAME_QNNUMROWSSEEN,
+          PulseConstants.MBEAN_COLNAME_QNMSGSENDTIME,
+          PulseConstants.MBEAN_COLNAME_QNMSGSERTIME,
+          PulseConstants.MBEAN_COLNAME_QNRESPDESERTIME };
+      return colNames;
+    }
+
+    public static String[] getGridColumnAttributes() {
+      String[] colAttributes = new String[] {
+          PulseConstants.MBEAN_ATTRIBUTE_QUERYDEFINITION,
+          PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION,
+          PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
+          PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
+          PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
+          PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED,
+          PulseConstants.MBEAN_ATTRIBUTE_PARSETIME,
+          PulseConstants.MBEAN_ATTRIBUTE_BINDTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME,
+          PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME,
+          PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME,
+
+          PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
+          PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME,
+          PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME };
+      return colAttributes;
+    }
+
+    public static int[] getGridColumnWidths() {
+      int[] colWidths = new int[] { 300, 150, 160, 180, 150, 200, 150, 130, 130,
+          160, 140, 180, 170, 160, 130,  190, 170, 170, 170, 200 };
+      return colWidths;
+    }
+
+    /**
+     * @return the numTimesCompiled
+     */
+    public String getQueryDefinition() {
+      return queryDefn;
+    }
+
+    /**
+     * @param queryDefn
+     *          the query to set
+     */
+    public void setQueryDefinition(String queryDefn) {
+      this.queryDefn = queryDefn;
+    }
+
+    /**
+     * @return the numTimesCompiled
+     */
+    public long getNumTimesCompiled() {
+      return numTimesCompiled;
+    }
+
+    /**
+     * @param numTimesCompiled
+     *          the numTimesCompiled to set
+     */
+    public void setNumTimesCompiled(long numTimesCompiled) {
+      this.numTimesCompiled = numTimesCompiled;
+    }
+
+    /**
+     * @return the numExecution
+     */
+    public long getNumExecution() {
+      return numExecution;
+    }
+
+    /**
+     * @param numExecution
+     *          the numExecution to set
+     */
+    public void setNumExecution(long numExecution) {
+      this.numExecution = numExecution;
+    }
+
+    /**
+     * @return the numExecutionsInProgress
+     */
+    public long getNumExecutionsInProgress() {
+      return numExecutionsInProgress;
+    }
+
+    /**
+     * @param numExecutionsInProgress
+     *          the numExecutionsInProgress to set
+     */
+    public void setNumExecutionsInProgress(long numExecutionsInProgress) {
+      this.numExecutionsInProgress = numExecutionsInProgress;
+    }
+
+    /**
+     * @return the numTimesGlobalIndexLookup
+     */
+    public long getNumTimesGlobalIndexLookup() {
+      return numTimesGlobalIndexLookup;
+    }
+
+    /**
+     * @param numTimesGlobalIndexLookup
+     *          the numTimesGlobalIndexLookup to set
+     */
+    public void setNumTimesGlobalIndexLookup(long numTimesGlobalIndexLookup) {
+      this.numTimesGlobalIndexLookup = numTimesGlobalIndexLookup;
+    }
+
+    /**
+     * @return the numRowsModified
+     */
+    public long getNumRowsModified() {
+      return numRowsModified;
+    }
+
+    /**
+     * @param numRowsModified
+     *          the numRowsModified to set
+     */
+    public void setNumRowsModified(long numRowsModified) {
+      this.numRowsModified = numRowsModified;
+    }
+
+    /**
+     * @return the parseTime
+     */
+    public long getParseTime() {
+      return parseTime;
+    }
+
+    /**
+     * @param parseTime
+     *          the parseTime to set
+     */
+    public void setParseTime(long parseTime) {
+      this.parseTime = parseTime;
+    }
+
+    /**
+     * @return the bindTime
+     */
+    public long getBindTime() {
+      return bindTime;
+    }
+
+    /**
+     * @param bindTime
+     *          the bindTime to set
+     */
+    public void setBindTime(long bindTime) {
+      this.bindTime = bindTime;
+    }
+
+    /**
+     * @return the optimizeTime
+     */
+    public long getOptimizeTime() {
+      return optimizeTime;
+    }
+
+    /**
+     * @param optimizeTime
+     *          the optimizeTime to set
+     */
+    public void setOptimizeTime(long optimizeTime) {
+      this.optimizeTime = optimizeTime;
+    }
+
+    /**
+     * @return the routingInfoTime
+     */
+    public long getRoutingInfoTime() {
+      return routingInfoTime;
+    }
+
+    /**
+     * @param routingInfoTime
+     *          the routingInfoTime to set
+     */
+    public void setRoutingInfoTime(long routingInfoTime) {
+      this.routingInfoTime = routingInfoTime;
+    }
+
+    /**
+     * @return the generateTime
+     */
+    public long getGenerateTime() {
+      return generateTime;
+    }
+
+    /**
+     * @param generateTime
+     *          the generateTime to set
+     */
+    public void setGenerateTime(long generateTime) {
+      this.generateTime = generateTime;
+    }
+
+    /**
+     * @return the totalCompilationTime
+     */
+    public long getTotalCompilationTime() {
+      return totalCompilationTime;
+    }
+
+    /**
+     * @param totalCompilationTime
+     *          the totalCompilationTime to set
+     */
+    public void setTotalCompilationTime(long totalCompilationTime) {
+      this.totalCompilationTime = totalCompilationTime;
+    }
+
+    /**
+     * @return the executionTime
+     */
+    public long getExecutionTime() {
+      return executionTime;
+    }
+
+    /**
+     * @param executionTime
+     *          the executionTime to set
+     */
+    public void setExecutionTime(long executionTime) {
+      this.executionTime = executionTime;
+    }
+
+    /**
+     * @return the projectionTime
+     */
+    public long getProjectionTime() {
+      return projectionTime;
+    }
+
+    /**
+     * @param projectionTime
+     *          the projectionTime to set
+     */
+    public void setProjectionTime(long projectionTime) {
+      this.projectionTime = projectionTime;
+    }
+
+    /**
+     * @return the totalExecutionTime
+     */
+    public long getTotalExecutionTime() {
+      return totalExecutionTime;
+    }
+
+    /**
+     * @param totalExecutionTime
+     *          the totalExecutionTime to set
+     */
+    public void setTotalExecutionTime(long totalExecutionTime) {
+      this.totalExecutionTime = totalExecutionTime;
+    }
+
+    /**
+     * @return the rowsModificationTime
+     */
+    public long getRowsModificationTime() {
+      return rowsModificationTime;
+    }
+
+    /**
+     * @param rowsModificationTime
+     *          the rowsModificationTime to set
+     */
+    public void setRowsModificationTime(long rowsModificationTime) {
+      this.rowsModificationTime = rowsModificationTime;
+    }
+
+    /**
+     * @return the qNNumRowsSeen
+     */
+    public long getqNNumRowsSeen() {
+      return qNNumRowsSeen;
+    }
+
+    /**
+     * @param qNNumRowsSeen
+     *          the qNNumRowsSeen to set
+     */
+    public void setqNNumRowsSeen(long qNNumRowsSeen) {
+      this.qNNumRowsSeen = qNNumRowsSeen;
+    }
+
+    /**
+     * @return the qNMsgSendTime
+     */
+    public long getqNMsgSendTime() {
+      return qNMsgSendTime;
+    }
+
+    /**
+     * @param qNMsgSendTime
+     *          the qNMsgSendTime to set
+     */
+    public void setqNMsgSendTime(long qNMsgSendTime) {
+      this.qNMsgSendTime = qNMsgSendTime;
+    }
+
+    /**
+     * @return the qNMsgSerTime
+     */
+    public long getqNMsgSerTime() {
+      return qNMsgSerTime;
+    }
+
+    /**
+     * @param qNMsgSerTime
+     *          the qNMsgSerTime to set
+     */
+    public void setqNMsgSerTime(long qNMsgSerTime) {
+      this.qNMsgSerTime = qNMsgSerTime;
+    }
+
+    /**
+     * @return the qNRespDeSerTime
+     */
+    public long getqNRespDeSerTime() {
+      return qNRespDeSerTime;
+    }
+
+    /**
+     * @param qNRespDeSerTime
+     *          the qNRespDeSerTime to set
+     */
+    public void setqNRespDeSerTime(long qNRespDeSerTime) {
+      this.qNRespDeSerTime = qNRespDeSerTime;
+    }
+  }
+
+  public static class RegionOnMember {
+
+    public static final int REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND = 0;
+    public static final int REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND = 1;
+    public static final int REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND = 3;
+    public static final int REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND = 4;
+
+    private String regionFullPath;
+    private String memberName;
+    private long entrySize;
+    private long entryCount;
+    private double getsRate;
+    private double putsRate;
+    private double diskGetsRate;
+    private double diskPutsRate;
+    private int localMaxMemory;
+
+    private CircularFifoBuffer getsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer putsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer diskReadsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer diskWritesPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+
+    /**
+     * @return the entrySize
+     */
+    public long getEntrySize() {
+      return entrySize;
+    }
+
+    /**
+     * @param entrySize the entrySize to set
+     */
+    public void setEntrySize(long entrySize) {
+      this.entrySize = entrySize;
+    }
+
+    /**
+     * @return the entryCount
+     */
+    public long getEntryCount() {
+      return entryCount;
+    }
+
+    /**
+     * @param entryCount the entryCount to set
+     */
+    public void setEntryCount(long entryCount) {
+      this.entryCount = entryCount;
+    }
+
+    /**
+     * @return the putsRate
+     */
+    public double getPutsRate() {
+      return putsRate;
+    }
+
+    /**
+     * @param putsRate the putsRate to set
+     */
+    public void setPutsRate(double putsRate) {
+      this.putsRate = putsRate;
+    }
+
+    /**
+     * @return the getsRate
+     */
+    public double getGetsRate() {
+      return getsRate;
+    }
+
+    /**
+     * @param getsRate the getsRate to set
+     */
+    public void setGetsRate(double getsRate) {
+      this.getsRate = getsRate;
+    }
+
+    /**
+     * @return the diskGetsRate
+     */
+    public double getDiskGetsRate() {
+      return diskGetsRate;
+    }
+
+    /**
+     * @param diskGetsRate the diskGetsRate to set
+     */
+    public void setDiskGetsRate(double diskGetsRate) {
+      this.diskGetsRate = diskGetsRate;
+    }
+
+    /**
+     * @return the diskPutsRate
+     */
+    public double getDiskPutsRate() {
+      return diskPutsRate;
+    }
+
+    /**
+     * @param diskPutsRate the diskPutsRate to set
+     */
+    public void setDiskPutsRate(double diskPutsRate) {
+      this.diskPutsRate = diskPutsRate;
+    }
+
+    /**
+     * @return the local maximum memory
+     */
+    public int getLocalMaxMemory() {
+      return this.localMaxMemory;
+    }
+
+    /**
+     * @param localMaxMemory
+     */
+    public void setLocalMaxMemory(int localMaxMemory) {
+      this.localMaxMemory = localMaxMemory;
+    }
+
+    /**
+     * @return the getsPerSecTrend
+     */
+    public CircularFifoBuffer getGetsPerSecTrend() {
+      return getsPerSecTrend;
+    }
+
+    /**
+     * @param getsPerSecTrend the getsPerSecTrend to set
+     */
+    public void setGetsPerSecTrend(CircularFifoBuffer getsPerSecTrend) {
+      this.getsPerSecTrend = getsPerSecTrend;
+    }
+
+    /**
+     * @return the putsPerSecTrend
+     */
+    public CircularFifoBuffer getPutsPerSecTrend() {
+      return putsPerSecTrend;
+    }
+
+    /**
+     * @param putsPerSecTrend the putsPerSecTrend to set
+     */
+    public void setPutsPerSecTrend(CircularFifoBuffer putsPerSecTrend) {
+      this.putsPerSecTrend = putsPerSecTrend;
+    }
+
+    /**
+     * @return the diskReadsPerSecTrend
+     */
+    public CircularFifoBuffer getDiskReadsPerSecTrend() {
+      return diskReadsPerSecTrend;
+    }
+
+    /**
+     * @param diskReadsPerSecTrend the diskReadsPerSecTrend to set
+     */
+    public void setDiskReadsPerSecTrend(CircularFifoBuffer diskReadsPerSecTrend) {
+      this.diskReadsPerSecTrend = diskReadsPerSecTrend;
+    }
+
+    /**
+     * @return the diskWritesPerSecTrend
+     */
+    public CircularFifoBuffer getDiskWritesPerSecTrend() {
+      return diskWritesPerSecTrend;
+    }
+
+    /**
+     * @param diskWritesPerSecTrend the diskWritesPerSecTrend to set
+     */
+    public void setDiskWritesPerSecTrend(CircularFifoBuffer diskWritesPerSecTrend) {
+      this.diskWritesPerSecTrend = diskWritesPerSecTrend;
+    }
+
+    public Object[] getRegionOnMemberStatisticTrend(int trendId) {
+
+      Object[] returnArray = null;
+      switch (trendId) {
+      case REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND:
+        synchronized (this.getsPerSecTrend) {
+          returnArray = this.getsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND:
+        synchronized (this.putsPerSecTrend) {
+          returnArray = this.putsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND:
+        synchronized (this.diskReadsPerSecTrend) {
+          returnArray = this.diskReadsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND:
+        synchronized (this.diskWritesPerSecTrend) {
+          returnArray = this.diskWritesPerSecTrend.toArray();
+        }
+        break;
+      }
+
+      return returnArray;
+    }
+
+    /**
+     * @return the regionFullPath
+     */
+    public String getRegionFullPath() {
+      return regionFullPath;
+    }
+
+    /**
+     * @param regionFullPath the regionFullPath to set
+     */
+    public void setRegionFullPath(String regionFullPath) {
+      this.regionFullPath = regionFullPath;
+    }
+
+    /**
+     * @return the memberName
+     */
+    public String getMemberName() {
+      return memberName;
+    }
+
+    /**
+     * @param memberName the memberName to set
+     */
+    public void setMemberName(String memberName) {
+      this.memberName = memberName;
+    }
+  }
+
+  /**
+   * Region Inner Class
+   *
+   *
+   */
+  public static class Region {
+    // start: fields defined in MBean
+    private String fullPath;
+    private double diskReadsRate;
+    private double diskWritesRate;
+    private double getsRate;
+    private double putsRate;
+    private double lruEvictionRate;
+    private String regionType;
+    private long systemRegionEntryCount;
+    private int memberCount;
+    private String name;
+    private boolean persistentEnabled;
+    private long entrySize;
+    private boolean wanEnabled;
+    private int emptyNode;
+    private long diskUsage;
+    private String scope;
+    private String diskStoreName;
+    private boolean diskSynchronous;
+    private boolean enableOffHeapMemory;
+    private String compressionCodec = "";
+
+    private List<String> memberName = new ArrayList<String>();
+    private List<RegionOnMember> regionOnMembers  = new ArrayList<RegionOnMember>();
+    private CircularFifoBuffer getsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer putsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer diskReadsPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+    private CircularFifoBuffer diskWritesPerSecTrend = new CircularFifoBuffer(
+        MAX_SAMPLE_SIZE);
+
+    public static final int REGION_STAT_GETS_PER_SEC_TREND = 0;
+    public static final int REGION_STAT_PUTS_PER_SEC_TREND = 1;
+    public static final int REGION_STAT_DISK_READS_PER_SEC_TREND = 3;
+    public static final int REGION_STAT_DISK_WRITES_PER_SEC_TREND = 4;
+
+    // end: fields defined in MBean
+
+    public Object[] getRegionStatisticTrend(int trendId) {
+
+      Object[] returnArray = null;
+      switch (trendId) {
+      case REGION_STAT_GETS_PER_SEC_TREND:
+        synchronized (this.getsPerSecTrend) {
+          returnArray = this.getsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_STAT_PUTS_PER_SEC_TREND:
+        synchronized (this.putsPerSecTrend) {
+          returnArray = this.putsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_STAT_DISK_READS_PER_SEC_TREND:
+        synchronized (this.diskReadsPerSecTrend) {
+          returnArray = this.diskReadsPerSecTrend.toArray();
+        }
+        break;
+
+      case REGION_STAT_DISK_WRITES_PER_SEC_TREND:
+        synchronized (this.diskWritesPerSecTrend) {
+          returnArray = this.diskWritesPerSecTrend.toArray();
+        }
+        break;
+      }
+
+      return returnArray;
+    }
+
+    public boolean isDiskSynchronous() {
+      return this.diskSynchronous;
+    }
+
+    public void setDiskSynchronous(boolean diskSynchronous) {
+      this.diskSynchronous = diskSynchronous;
+    }
+
+    public String getDiskStoreName() {
+      return this.diskStoreName;
+    }
+
+    public void setDiskStoreName(String diskStoreName) {
+      this.diskStoreName = diskStoreName;
+    }
+
+    public String getScope() {
+      return this.scope;
+    }
+
+    public void setScope(String scope) {
+      this.scope = scope;
+    }
+
+    public int getEmptyNode() {
+      return this.emptyNode;
+    }
+
+    public void setEmptyNode(int emptyNode) {
+      this.emptyNode = emptyNode;
+    }
+
+    public long getDiskUsage() {
+      return this.diskUsage;
+    }
+
+    public void setDiskUsage(long diskUsage) {
+      this.diskUsage = diskUsage;
+    }
+
+    public void setEntrySize(long entrySize) {
+      this.entrySize = entrySize;
+    }
+
+    public boolean getWanEnabled() {
+      return this.wanEnabled;
+    }
+
+    public void setWanEnabled(boolean wanEnabled) {
+      this.wanEnabled = wanEnabled;
+    }
+
+    public boolean getPersistentEnabled() {
+      return this.persistentEnabled;
+    }
+
+    public void setPersistentEnabled(boolean persistentEnabled) {
+      this.persistentEnabled = persistentEnabled;
+    }
+
+    public String getName() {
+      return this.name;
+    }
+
+    public void setName(String name) {
+      this.name = name;
+    }
+
+    public long getEntrySize() {
+      return this.entrySize;
+    }
+
+    public List<String> getMemberName() {
+      return this.memberName;
+    }
+
+    public void setMemberName(List<String> memberName) {
+      this.memberName = memberName;
+    }
+
+    public String getFullPath() {
+      return this.fullPath;
+    }
+
+    public void setFullPath(String fullPath) {
+      this.fullPath = fullPath;
+    }
+
+    public double getDiskReadsRate() {
+      return this.diskReadsRate;
+    }
+
+    public void setDiskReadsRate(double diskReadsRate) {
+      this.diskReadsRate = diskReadsRate;
+    }
+
+    public double getDiskWritesRate() {
+      return this.diskWritesRate;
+    }
+
+    public void setDiskWritesRate(double diskWritesRate) {
+      this.diskWritesRate = diskWritesRate;
+    }
+
+    public CircularFifoBuffer getDiskReadsPerSecTrend() {
+      return this.diskReadsPerSecTrend;
+    }
+
+    public void setDiskReadsPerSecTrend(CircularFifoBuffer diskReadsPerSecTrend) {
+      this.diskReadsPerSecTrend = diskReadsPerSecTrend;
+    }
+
+    public CircularFifoBuffer getDiskWritesPerSecTrend() {
+      return this.diskWritesPerSecTrend;
+    }
+
+    public void setDiskWritesPerSecTrend(
+        CircularFifoBuffer diskWritesPerSecTrend) {
+      this.diskWritesPerSecTrend = diskWritesPerSecTrend;
+    }
+
+    public double getGetsRate() {
+      return this.getsRate;
+    }
+
+    public void setGetsRate(double getsRate) {
+      this.getsRate = getsRate;
+    }
+
+    public double getLruEvictionRate() {
+      return this.lruEvictionRate;
+    }
+
+    public void setLruEvictionRate(double lruEvictionRate) {
+      this.lruEvictionRate = lruEvictionRate;
+    }
+
+    public String getRegionType() {
+      return this.regionType;
+    }
+
+    public void setRegionType(String regionType) {
+      this.regionType = regionType;
+    }
+
+    public long getSystemRegionEntryCount() {
+      return this.systemRegionEntryCount;
+    }
+
+    public void setSystemRegionEntryCount(long systemRegionEntryCount) {
+      this.systemRegionEntryCount = systemRegionEntryCount;
+    }
+
+    public int getMemberCount() {
+      return this.memberCount;
+    }
+
+    public void setMemberCount(int memberCount) {
+      this.memberCount = memberCount;
+    }
+
+    public double getPutsRate() {
+      return this.putsRate;
+    }
+
+    public void setPutsRate(double putsRate) {
+      this.putsRate = putsRate;
+    }
+
+    public CircularFifoBuffer getGetsPerSecTrend() {
+      return this.getsPerSecTrend;
+    }
+
+    public void setGetsPerSecTrend(CircularFifoBuffer getsPerSecTrend) {
+      this.getsPerSecTrend = getsPerSecTrend;
+    }
+
+    public CircularFifoBuffer getPutsPerSecTrend() {
+      return this.putsPerSecTrend;
+    }
+
+    public void setPutsPerSecTrend(CircularFifoBuffer putsPerSecTrend) {
+      this.putsPerSecTrend = putsPerSecTrend;
+    }
+
+    public boolean isEnableOffHeapMemory() {
+      return this.enableOffHeapMemory;
+    }
+
+    public void setEnableOffHeapMemory(boolean enableOffHeapMemory) {
+      this.enableOffHeapMemory = enableOffHeapMemory;
+    }
+
+    public String getCompressionCodec() {
+      return this.compressionCodec;
+    }
+
+    public void setCompressionCodec(String compressionCodec) {
+      this.compressionCodec = compressionCodec;
+    }
+
+    public Cluster.RegionOnMember[] getRegionOnMembers() {
+      Cluster.RegionOnMember[] regionOnMembers = null;
+      synchronized (this.regionOnMembers) {
+        regionOnMembers = new Cluster.RegionOnMember[this.regionOnMembers.size()];
+        regionOnMembers = this.regionOnMembers.toArray(regionOnMembers);
+      }
+
+      return regionOnMembers;
+    }
+
+    /**
+     * @param regionOnMembers the regionOnMembers to set
+     */
+    public void setRegionOnMembers(List<RegionOnMember> regionOnMembers) {
+      this.regionOnMembers = regionOnMembers;
+    }
+  }
+
+  /**
+   * Alert Inner Class
+   *
+   *
+   */
+  public static class Alert {
+    public static final int SEVERE = 0;
+    public static final int ERROR = 1;
+    public static final int WARNING = 2;
+    public static final int INFO = 3;
+
+    public static AtomicInteger ALERT_ID_CTR = new AtomicInteger();
+
+    private int id;
+    private Date timestamp;
+    private int severity;
+    private String memberName;
+    private String description;
+    private boolean isAcknowledged;
+    private String iso8601Ts;
+
+    public String getIso8601Ts() {
+      return iso8601Ts;
+    }
+
+    public void setIso8601Ts(String iso8601Ts) {
+      this.iso8601Ts = iso8601Ts;
+    }
+
+    public boolean isAcknowledged() {
+      return this.isAcknowledged;
+    }
+
+    public void setAcknowledged(boolean isAcknowledged) {
+      this.isAcknowledged = isAcknowledged;
+    }
+
+    public Date getTimestamp() {
+      return this.timestamp;
+    }
+
+    public void setTimestamp(Date timestamp) {
+      this.timestamp = timestamp;
+      this.iso8601Ts = formatToISOTimestamp(timestamp);
+    }
+
+    public int getSeverity() {
+      return this.severity;
+    }
+
+    public void setSeverity(int severity) {
+      this.severity = severity;
+    }
+
+    public String getMemberName() {
+      return this.memberName;
+    }
+
+    public void setMemberName(String memberName) {
+      this.memberName = memberName;
+    }
+
+    public String getDescription() {
+      return this.description;
+    }
+
+    public void setDescription(String description) {
+      this.description = description;
+    }
+
+    public int getId() {
+      return this.id;
+    }
+
+    public void setId(int id) {
+      this.id = id;
+    }
+
+    public static int nextID() {
+      /*
+       * int id = -1; synchronized (Alert.class) { ALERT_ID_CTR = ALERT_ID_CTR +
+       * 1; id = ALERT_ID_CTR; }
+       */
+      return ALERT_ID_CTR.incrementAndGet();
+    }
+
+    private static DateFormat df = new SimpleDateFormat(PulseConstants.PULSE_NOTIFICATION_ALERT_DATE_PATTERN);
+
+    public static String formatToISOTimestamp(Date date) {
+      TimeZone tz = TimeZone.getTimeZone("UTC");
+      df.setTimeZone(tz);
+      return df.format(date);
+    }
+
+  }
+
+  /**
+   * Client Inner Class
+   *
+   *
+   */
+  public static class Client {
+
+    private String id;
+    private String name;
+    private String host;
+    private int queueSize;
+    private double cpuUsage;
+    private long uptime;
+    private int threads;
+    private int gets;
+    private int puts;
+    private int cpus;
+    private int clientCQCount; 
+    private long processCpuTime;
+    private String status;
+    private boolean isConnected = false;
+    private boolean isSubscriptionEnabled = false; 
+
+    public String getId() {
+      return this.id;
+    }
+
+    public int getGets() {
+      return this.gets;
+    }
+
+    public int getPuts() {
+      return this.puts;
+    }
+
+	public int getClientCQCount() {
+	  return clientCQCount;
+	}
+
+	public void setClientCQCount(int clientCQCount) {
+	  this.clientCQCount = clientCQCount;
+	}
+     
+	public boolean isSubscriptionEnabled() { 
+	  return isSubscriptionEnabled; 
+	} 
+	 		 
+	public void setSubscriptionEnabled(boolean isSubscriptionEnabled) { 
+	  this.isSubscriptionEnabled = isSubscriptionEnabled; 
+	} 
+
+    public void setId(String id) {
+      this.id = id;
+    }
+
+    public String getName() {
+      return this.name;
+    }
+
+    public void setName(String name) {
+      this.name = name;
+    }
+
+    public String getHost() {
+      return this.host;
+    }
+
+    public void setHost(String host) {
+      this.host = host;
+    }
+
+    public int getQueueSize() {
+      return this.queueSize;
+    }
+
+    public void setQueueSize(int queueSize) {
+      this.queueSize = queueSize;
+    }
+
+    public double getCpuUsage() {
+      return this.cpuUsage;
+    }
+
+    public void setCpuUsage(double cpuUsage) {
+      this.cpuUsage = cpuUsage;
+    }
+
+    public void setGets(int gets) {
+      this.gets = gets;
+    }
+
+    public void setPuts(int puts) {
+      this.puts = puts;
+    }
+
+    public long getUptime() {
+      return this.uptime;
+    }
+
+    public void setUptime(long uptime) {
+      this.uptime = uptime;
+    }
+
+    public int getThreads() {
+      return this.threads;
+    }
+
+    public void setThreads(int threads) {
+      this.threads = threads;
+    }
+
+    public String getStatus() {
+      return this.status;
+    }
+
+    public void setStatus(String status) {
+      this.status = status;
+    }
+
+    public int getCpus() {
+      return this.cpus;
+    }
+
+    public void setCpus(int cpus) {
+      this.cpus = cpus;
+    }
+
+    public long getProcessCpuTime() {
+      return this.processCpuTime;
+    }
+
+    public void setProcessCpuTime(long processCpuTime) {
+      this.processCpuTime = processCpuTime;
+    }
+
+    public boolean isConnected() {
+      return isConnected;
+    }
+
+    public void setConnected(boolean isConnected) {
+      this.isConnected = isConnected;
+    }
+
+  }
+
+  /**
+   * Gateway Receiver Inner Class
+   *
+   *
+   */
+  public static class GatewayReceiver {
+
+    private int listeningPort;
+    private double linkThroughput;
+    private long avgBatchProcessingTime;
+    private String id;
+    private int queueSize;
+    private Boolean status;
+    private int batchSize;
+
+    public int getListeningPort() {
+      return this.listeningPort;
+    }
+
+    public void setListeningPort(int listeningPort) {
+      this.listeningPort = listeningPort;
+    }
+
+    public double getLinkThroughput() {
+      return this.linkThroughput;
+    }
+
+    public void setLinkThroughput(double linkThroughput) {
+      this.linkThroughput = linkThroughput;
+    }
+
+    public long getAvgBatchProcessingTime() {
+      return this.avgBatchProcessingTime;
+    }
+
+    public void setAvgBatchProcessingTime(long avgBatchProcessingTime) {
+      this.avgBatchProcessingTime = avgBatchProcessingTime;
+    }
+
+    public String getId() {
+      return this.id;
+    }
+
+    public void setId(String id) {
+      this.id = id;
+    }
+
+    public int getQueueSize() {
+      return this.queueSize;
+    }
+
+    public void setQueueSize(int queueSize) {
+      this.queueSize = queueSize;
+    }
+
+    public Boolean getStatus() {
+      return this.status;
+    }
+
+    public void setStatus(Boolean status) {
+      this.status = status;
+    }
+
+    public int getBatchSize() {
+      return this.batchSize;
+    }
+
+    public void setBatchSize(int batchSize) {
+      this.batchSize = batchSize;
+    }
+  }
+
+  /**
+   * Gateway Sender Inner class
+   *
+   *
+   */
+  public static class GatewaySender {
+
+    private double linkThroughput;
+    private String id;
+    private int queueSize;
+    private Boolean status;
+    private boolean primary;
+    private boolean senderType;
+    private int batchSize;
+    private boolean persistenceEnabled;
+    private int remoteDSId;
+    private int eventsExceedingAlertThreshold;
+
+    public double getLinkThroughput() {
+      return this.linkThroughput;
+    }
+
+    public void setLinkThroughput(double linkThroughput) {
+      this.linkThroughput = linkThroughput;
+    }
+
+    public String getId() {
+      return this.id;
+    }
+
+    public void setId(String id) {
+      this.id = id;
+    }
+
+    public int getQueueSize() {
+      return this.queueSize;
+    }
+
+    public void setQueueSize(int queueSize) {
+      this.queueSize = queueSize;
+    }
+
+    public Boolean getStatus() {
+      return this.status;
+    }
+
+    public void setStatus(Boolean status) {
+      this.status = status;
+    }
+
+    public boolean getPrimary() {
+      return this.primary;
+    }
+
+    public void setPrimary(boolean primary) {
+      this.primary = primary;
+    }
+
+    public boolean getSenderType() {
+      return this.senderType;
+    }
+
+    public void setSenderType(boolean senderType) {
+      this.senderType = senderType;
+    }
+
+    public int getBatchSize() {
+      return this.batchSize;
+    }
+
+    public void setBatchSize(int batchSize) {
+      this.batchSize = batchSize;
+    }
+
+    public boolean getPersistenceEnabled() {
+      return this.persistenceEnabled;
+    }
+
+    public void setPersistenceEnabled(boolean persistenceEnabled) {
+      this.persistenceEnabled = persistenceEnabled;
+    }
+
+    /**
+     * @return the remoteDSId
+     */
+    public int getRemoteDSId() {
+      return remoteDSId;
+    }
+
+    /**
+     * @param remoteDSId the remoteDSId to set
+     */
+    public void setRemoteDSId(int remoteDSId) {
+      this.remoteDSId = remoteDSId;
+    }
+
+    /**
+     * @return the eventsExceedingAlertThreshold
+     */
+    public int getEventsExceedingAlertThreshold() {
+      return eventsExceedingAlertThreshold;
+    }
+
+    /**
+     * @param eventsExceedingAlertThreshold the eventsExceedingAlertThreshold to set
+     */
+    public void setEventsExceedingAlertThreshold(int eventsExceedingAlertThreshold) {
+      this.eventsExceedingAlertThreshold = eventsExceedingAlertThreshold;
+    }
+  }
+
+  /**
+   * Async Event Queue Inner class
+   *
+   *
+   */
+  public static class AsyncEventQueue {
+
+    private String id;
+    private boolean primary;
+    private boolean parallel;
+    private int batchSize;
+    private long batchTimeInterval;
+    private boolean batchConflationEnabled;
+    private String asyncEventListener;
+    private int eventQueueSize;
+
+    public String getId() {
+      return this.id;
+    }
+
+    public void setId(String id) {
+      this.id = id;
+    }
+
+    public boolean getPrimary() {
+      return this.primary;
+    }
+
+    public void setPrimary(boolean primary) {
+      this.primary = primary;
+    }
+
+    /**
+     * @return the parallel
+     */
+    public boolean isParallel() {
+      return parallel;
+    }
+
+    /**
+     * @param parallel the parallel to set
+     */
+    public void setParallel(boolean parallel) {
+      this.parallel = parallel;
+    }
+
+    public int getBatchSize() {
+      return this.batchSize;
+    }
+
+    public void setBatchSize(int batchSize) {
+      this.batchSize = batchSize;
+    }
+
+    /**
+     * @return the batchTimeInterval
+     */
+    public long getBatchTimeInterval() {
+      return batchTimeInterval;
+    }
+
+    /**
+     * @param batchTimeInterval the batchTimeInterval to set
+     */
+    public void setBatchTimeInterval(long batchTimeInterval) {
+      this.batchTimeInterval = batchTimeInterval;
+    }
+
+    /**
+     * @return the batchConflationEnabled
+     */
+    public boolean isBatchConflationEnabled() {
+      return batchConflationEnabled;
+    }
+
+    /**
+     * @param batchConflationEnabled the batchConflationEnabled to set
+     */
+    public void setBatchConflationEnabled(boolean batchConflationEnabled) {
+      this.batchConflationEnabled = batchConflationEnabled;
+    }
+
+    /**
+     * @return the asyncEventListener
+     */
+    public String getAsyncEventListener() {
+      return asyncEventListener;
+    }
+
+    /**
+     * @param asyncEventListener the asyncEventListener to set
+     */
+    public void setAsyncEventListener(String asyncEventListener) {
+      this.asyncEventListener = asyncEventListener;
+    }
+
+    /**
+     * @return the eventQueueSize
+     */
+    public int getEventQueueSize() {
+      return eventQueueSize;
+    }
+
+    /**
+     * @param eventQueueSize the eventQueueSize to set
+     */
+    public void setEventQueueSize(int eventQueueSize) {
+      this.eventQueueSize = eventQueueSize;
+    }
+  }
+
+  /**
+   * Default constructor only used for testing
+   */
+  public Cluster() {
+  }
+
+
+  /**
+   * This function is used for calling getUpdator function of ClusterDataFactory
+   * and starting the thread for updating the Cluster details.
+   *
+   * @param host
+   *          host name
+   * @param port
+   *          port
+   * @param userName
+   *          pulse user name
+   * @param userPassword
+   *          pulse user password
+   * @throws ConnectException
+   */
+  public Cluster(String host, String port, String userName, String userPassword)
+      throws ConnectException {
+    this.serverName = host;
+    this.port = port;
+    this.jmxUserName = userName;
+    this.jmxUserPassword = userPassword;
+
+    this.updater = ClusterDataFactory.getUpdater(this, host, port);
+    // start();
+  }
+
+  /**
+   * thread run method for updating the cluster data
+   */
+  @Override
+  public void run() {
+    while (!this.stopUpdates) {
+      try {
+        if (!this.updateData()) {
+          this.stale++;
+        } else {
+          this.stale = 0;
+        }
+      } catch (Exception e) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("Exception Occurred while updating cluster data : " + e.getMessage());
+        }
+      }
+
+      try {
+        Thread.sleep(POLL_INTERVAL);
+      } catch (InterruptedException e) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("InterruptedException Occurred : " + e.getMessage());
+        }
+      }
+    }
+
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_STOP_THREAD_UPDATES")
+          + " :: " + this.serverName + ":" + this.port);
+    }
+  }
+
+  /**
+   * calling updateData
+   *
+   * @return true if update was successful. false if it failed.
+   */
+  private boolean updateData() {
+    // This will eventually call JMX. Currently we will update this with
+    // some dummy data.
+    // Connect if required or hold a connection. If unable to connect,
+    // return false
+    if (LOGGER.finerEnabled()) {
+      LOGGER.finer(resourceBundle.getString("LOG_MSG_CLUSTER_DATA_IS_UPDATING")
+          + "::" + this.serverName + ":" + this.port);
+    }
+    return this.updater.updateData();
+  }
+
+  /**
+   * for stopping the update thread
+   */
+  public void stopThread() {
+    this.stopUpdates = true;
+
+    try {
+      join();
+    } catch (InterruptedException e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("InterruptedException occured while stoping cluster thread : " + e.getMessage());
+      }
+    }
+  }
+
+  public Map<String, Cluster.Member> getMembersHMap() {
+    return this.membersHMap;
+  }
+
+  public void setMembersHMap(HashMap<String, Cluster.Member> membersHMap) {
+    this.membersHMap = membersHMap;
+  }
+
+  public Map<String, Boolean> getWanInformation() {
+    Map<String, Boolean> wanMap = null;
+    synchronized (this.wanInformation) {
+      wanMap = (Map<String, Boolean>) this.wanInformation.clone();
+    }
+
+    return wanMap;
+  }
+
+  // Returns actual wanInformation object reference
+  public Map<String, Boolean> getWanInformationObject() {
+    return this.wanInformation;
+  }
+
+  public void setWanInformation(HashMap<String, Boolean> wanInformation) {
+    this.wanInformation = wanInformation;
+  }
+
+  public String getJmxUserName() {
+    return this.jmxUserName;
+  }
+
+  public void setJmxUserName(String jmxUserName) {
+    this.jmxUserName = jmxUserName;
+  }
+
+  public String getJmxUserPassword() {
+    return this.jmxUserPassword;
+  }
+
+  public void setJmxUserPassword(String jmxUserPassword) {
+    this.jmxUserPassword = jmxUserPassword;
+  }
+
+  public String getConnectionErrorMsg() {
+    return this.connectionErrorMsg;
+  }
+
+  public void setConnectionErrorMsg(String connectionErrorMsg) {
+    this.connectionErrorMsg = connectionErrorMsg;
+  }
+
+  public String getServerName() {
+    return this.serverName;
+  }
+
+  public boolean isConnectedFlag() {
+    return this.connectedFlag;
+  }
+
+  public void setConnectedFlag(boolean connectedFlag) {
+    this.connectedFlag = connectedFlag;
+  }
+
+  public String getPort() {
+    return this.port;
+  }
+
+  public int getStale() {
+    return this.stale;
+  }
+
+  public double getWritePerSec() {
+    return this.writePerSec;
+  }
+
+  public void setWritePerSec(double writePerSec) {
+    this.writePerSec = writePerSec;
+  }
+
+  public double getReadPerSec() {
+    return this.readPerSec;
+  }
+
+  public void setReadPerSec(double readPerSec) {
+    this.readPerSec = readPerSec;
+  }
+
+  public double getQueriesPerSec() {
+    return this.queriesPerSec;
+  }
+
+  public void setQueriesPerSec(double queriesPerSec) {
+    this.queriesPerSec = queriesPerSec;
+  }
+
+  public double getLoadPerSec() {
+    return this.loadPerSec;
+  }
+
+  public void setLoadPerSec(double loadPerSec) {
+    this.loadPerSec = loadPerSec;
+  }
+
+  public int getNotificationPageNumber() {
+    return this.notificationPageNumber;
+  }
+
+  public void setNotificationPageNumber(int notificationPageNumber) {
+    this.notificationPageNumber = notificationPageNumber;
+  }
+
+  public void setStale(int stale) {
+    this.stale = stale;
+  }
+
+  public boolean isStopUpdates() {
+    return this.stopUpdates;
+  }
+
+  public void setStopUpdates(boolean stopUpdates) {
+    this.stopUpdates = stopUpdates;
+  }
+
+  public long getUsedHeapSize() {
+    return this.usedHeapSize;
+  }
+
+  public void setUsedHeapSize(long usedHeapSize) {
+    this.usedHeapSize = usedHeapSize;
+  }
+
+  public int getServerCount() {
+    return this.serverCount;
+  }
+
+  public void setServerCount(int serverCount) {
+    this.serverCount = serverCount;
+  }
+
+  public int getTxnCommittedCount() {
+    return txnCommittedCount;
+  }
+
+  public void setTxnCommittedCount(int txnCommittedCount) {
+    this.txnCommittedCount = txnCommittedCount;
+  }
+
+  public int getTxnRollbackCount() {
+    return txnRollbackCount;
+  }
+
+  public void setTxnRollbackCount(int txnRollbackCount) {
+    this.txnRollbackCount = txnRollbackCount;
+  }
+
+  public int getRunningFunctionCount() {
+    return this.runningFunctionCount;
+  }
+
+  public long getRegisteredCQCount() {
+    return this.registeredCQCount;
+  }
+
+  public int getSubscriptionCount() {
+    return this.subscriptionCount;
+  }
+
+  public void setSubscriptionCount(int subscriptionCount) {
+    this.subscriptionCount = subscriptionCount;
+  }
+
+  public void setRegisteredCQCount(long registeredCQCount) {
+    this.registeredCQCount = registeredCQCount;
+  }
+
+  public void setRunningFunctionCount(int runningFunctionCount) {
+    this.runningFunctionCount = runningFunctionCount;
+  }
+
+  public Map<String, Cluster.Region> getClusterRegions() {
+    return this.clusterRegionMap;
+  }
+
+  public Cluster.Region getClusterRegion(String regionFullPath) {
+    return this.clusterRegionMap.get(regionFullPath);
+  }
+
+  public void setClusterRegions(Map<String, Region> clusterRegionMap) {
+    this.clusterRegionMap = clusterRegionMap;
+  }
+
+  public Map<String, Cluster.Statement> getClusterStatements() {
+    return this.clusterStatementMap;
+  }
+
+  public void setClusterStatements(Map<String, Statement> clusterStatementMap) {
+    this.clusterStatementMap = clusterStatementMap;
+  }
+
+  public Alert[] getAlertsList() {
+    Alert[] list = null;
+    synchronized (this.alertsList) {
+      list = new Alert[this.alertsList.size()];
+      list = this.alertsList.toArray(list);
+    }
+
+    return list;
+  }
+
+  public void setAlertsList(List<Alert> alertsList) {
+    this.alertsList = alertsList;
+  }
+
+  public void setServerName(String serverName) {
+    this.serverName = serverName;
+  }
+
+  public void setPort(String port) {
+    this.port = port;
+  }
+
+  public Set<String> getDeletedMembers() {
+    return this.deletedMembers;
+  }
+
+  public void setDeletedMembers(Set<String> deletedMembers) {
+    this.deletedMembers = deletedMembers;
+  }
+
+  public Set<String> getDeletedRegions() {
+    return this.deletedRegions;
+  }
+
+  public void setDeletedRegions(Set<String> deletedRegions) {
+    this.deletedRegions = deletedRegions;
+  }
+
+  public Map<String, List<Member>> getPhysicalToMember() {
+    Map<String, List<Member>> ptom = null;
+    // synchronized (physicalToMember) {
+    ptom = this.physicalToMember;
+    // }
+    return ptom;
+  }
+
+  public void setPhysicalToMember(HashMap<String, List<Member>> physicalToMember) {
+    // synchronized (this.physicalToMember) {
+    this.physicalToMember = physicalToMember;
+    // }
+  }
+
+  public int getMemberCount() {
+    return this.memberCount;
+  }
+
+  public void setMemberCount(int memberCount) {
+    this.memberCount = memberCount;
+  }
+
+  public long getClientConnectionCount() {
+    return this.clientConnectionCount;
+  }
+
+  public void setClientConnectionCount(long clientConnectionCount) {
+    this.clientConnectionCount = clientConnectionCount;
+  }
+
+  public int getClusterId() {
+    return this.clusterId;
+  }
+
+  public void setClusterId(int clusterId) {
+    this.clusterId = clusterId;
+  }
+
+  public int getLocatorCount() {
+    return this.locatorCount;
+  }
+
+  public void setLocatorCount(int locatorCount) {
+    this.locatorCount = locatorCount;
+  }
+
+  public int getTotalRegionCount() {
+    return this.totalRegionCount;
+  }
+
+  public void setTotalRegionCount(int totalRegionCount) {
+    this.totalRegionCount = totalRegionCount;
+  }
+
+  public long getTotalHeapSize() {
+    return this.totalHeapSize;
+  }
+
+  public void setTotalHeapSize(long totalHeapSize) {
+    this.totalHeapSize = totalHeapSize;
+  }
+
+  public long getTotalRegionEntryCount() {
+    return this.totalRegionEntryCount;
+  }
+
+  public void setTotalRegionEntryCount(long totalRegionEntryCount) {
+    this.totalRegionEntryCount = totalRegionEntryCount;
+  }
+
+  public int getCurrentQueryCount() {
+    return this.currentQueryCount;
+  }
+
+  public void setCurrentQueryCount(int currentQueryCount) {
+    this.currentQueryCount = currentQueryCount;
+  }
+
+  public long getTotalBytesOnDisk() {
+    return this.totalBytesOnDisk;
+  }
+
+  public void setTotalBytesOnDisk(long totalBytesOnDisk) {
+    this.totalBytesOnDisk = totalBytesOnDisk;
+  }
+
+  public double getDiskReadsRate() {
+    return this.diskReadsRate;
+  }
+
+  public void setDiskReadsRate(double diskReadsRate) {
+    this.diskReadsRate = diskReadsRate;
+  }
+
+  public double getDiskWritesRate() {
+    return this.diskWritesRate;
+  }
+
+  public void setDiskWritesRate(double diskWritesRate) {
+    this.diskWritesRate = diskWritesRate;
+  }
+
+  public int getAvgDiskStorage() {
+    return this.avgDiskStorage;
+  }
+
+  public void setAvgDiskStorage(int avgDiskStorage) {
+    this.avgDiskStorage = avgDiskStorage;
+  }
+
+  public int getAvgDiskWritesRate() {
+    return this.avgDiskWritesRate;
+  }
+
+  public void setAvgDiskWritesRate(int avgDiskWritesRate) {
+    this.avgDiskWritesRate = avgDiskWritesRate;
+  }
+
+  public CircularFifoBuffer getWritePerSecTrend() {
+    return this.writePerSecTrend;
+  }
+
+  public void setWritePerSecTrend(CircularFifoBuffer writePerSecTrend) {
+    this.writePerSecTrend = writePerSecTrend;
+  }
+
+  public long getGarbageCollectionCount() {
+    return this.garbageCollectionCount;
+  }
+
+  public void setGarbageCollectionCount(long garbageCollectionCount) {
+    this.garbageCollectionCount = garbageCollectionCount;
+  }
+
+  public CircularFifoBuffer getTotalBytesOnDiskTrend() {
+    return this.totalBytesOnDiskTrend;
+  }
+
+  public void setTotalBytesOnDiskTrend(CircularFifoBuffer totalBytesOnDiskTrend) {
+    this.totalBytesOnDiskTrend = totalBytesOnDiskTrend;
+  }
+
+  public CircularFifoBuffer getThroughoutWritesTrend() {
+    return this.throughoutWritesTrend;
+  }
+
+  public void setThroughoutWritesTrend(CircularFifoBuffer throughoutWritesTrend) {
+    this.throughoutWritesTrend = throughoutWritesTrend;
+  }
+
+  public CircularFifoBuffer getThroughoutReadsTrend() {
+    return this.throughoutReadsTrend;
+  }
+
+  public void setThroughoutReadsTrend(CircularFifoBuffer throughoutReadsTrend) {
+    this.throughoutReadsTrend = throughoutReadsTrend;
+  }
+
+  public CircularFifoBuffer getReadPerSecTrend() {
+    return this.readPerSecTrend;
+  }
+
+  public void setReadPerSecTrend(CircularFifoBuffer readPerSecTrend) {
+    this.readPerSecTrend = readPerSecTrend;
+  }
+
+  public CircularFifoBuffer getQueriesPerSecTrend() {
+    return this.queriesPerSecTrend;
+  }
+
+  public void setQueriesPerSecTrend(CircularFifoBuffer queriesPerSecTrend) {
+    this.queriesPerSecTrend = queriesPerSecTrend;
+  }
+
+  public CircularFifoBuffer getMemoryUsageTrend() {
+    return this.memoryUsageTrend;
+  }
+
+  public void setMemoryUsageTrend(CircularFifoBuffer memoryUsageTrend) {
+    this.memoryUsageTrend = memoryUsageTrend;
+  }
+
+  public CircularFifoBuffer getGarbageCollectionTrend() {
+    return this.garbageCollectionTrend;
+  }
+
+  public void setGarbageCollectionTrend(
+      CircularFifoBuffer garbageCollectionSamples) {
+    this.garbageCollectionTrend = garbageCollectionSamples;
+  }
+
+  public long getPreviousJVMPauseCount() {
+    return this.previousJVMPauseCount;
+  }
+
+  public void setPreviousJVMPauseCount(long previousJVMPauseCount) {
+    this.previousJVMPauseCount = previousJVMPauseCount;
+  }
+
+  public DataBrowser getDataBrowser() {
+    // Initialize dataBrowser if null
+    if (this.dataBrowser == null) {
+      this.dataBrowser = new DataBrowser();
+    }
+    return this.dataBrowser;
+  }
+
+  public void setDataBrowser(DataBrowser dataBrowser) {
+    this.dataBrowser = dataBrowser;
+  }
+
+  public ObjectNode executeQuery(String queryText, String members, int limit) {
+    // Execute data browser query
+    return this.updater.executeQuery(queryText, members, limit);
+  }
+
+  public ArrayNode getQueryHistoryByUserId(String userId) {
+    return this.getDataBrowser().getQueryHistoryByUserId(userId);
+  }
+
+  public boolean addQueryInHistory(String queryText, String userName) {
+    return this.getDataBrowser().addQueryInHistory(queryText, userName);
+  }
+
+  public boolean deleteQueryById(String userId, String queryId) {
+    return this.getDataBrowser().deleteQueryById(userId, queryId);
+  }
+  
+  public JMXConnector connectToGemFire() {
+    if(this.updater instanceof JMXDataUpdater) {
+      return ((JMXDataUpdater) this.updater).getJMXConnection(false);
+    } else {
+      return null;
+    }
+  }
+
+  /**
+   * inner class for creating Mock Data
+   *
+   *
+   */
+  public class MockDataUpdater implements IClusterUpdater {
+    public MockDataUpdater() {
+    }
+
+    /**
+     * function used for updating Cluster data for Mock
+     */
+    @Override
+    public boolean updateData() {
+      setConnectedFlag(true);
+      Random r = new Random(System.currentTimeMillis());
+      totalHeapSize = (long) Math.abs(r.nextInt(3200 - 2048) + 2048);
+      usedHeapSize = (long) Math.abs(r.nextInt(2048));
+      writePerSec = Math.abs(r.nextInt(100));
+      subscriptionCount = Math.abs(r.nextInt(100));
+      registeredCQCount = (long) Math.abs(r.nextInt(100));
+      txnCommittedCount = Math.abs(r.nextInt(100));
+      txnRollbackCount = Math.abs(r.nextInt(100));
+      runningFunctionCount = Math.abs(r.nextInt(100));
+      clusterId = Math.abs(r.nextInt(100));
+      writePerSecTrend.add(writePerSec);
+      diskWritesRate = writePerSec;
+      garbageCollectionCount = (long) Math.abs(r.nextInt(100));
+      garbageCollectionTrend.add(garbageCollectionCount);
+
+      readPerSec = Math.abs(r.nextInt(100));
+      readPerSecTrend.add(readPerSec);
+
+      diskReadsRate = readPerSec;
+      queriesPerSec = Math.abs(r.nextInt(100));
+      queriesPerSecTrend.add(queriesPerSec);
+
+      loadPerSec = Math.abs(r.nextInt(100));
+      totalHeapSize = totalHeapSize;
+      totalBytesOnDisk = totalHeapSize;
+
+      totalBytesOnDiskTrend.add(totalBytesOnDisk);
+
+      memoryUsageTrend.add(usedHeapSize);
+      throughoutWritesTrend.add(writePerSec);
+      throughoutReadsTrend.add(readPerSec);
+
+      memberCount = 0;
+
+      // Create 3 members first time around
+      if (membersHMap.size() == 0) {
+
+        membersHMap.put(
+            "pnq-visitor1",
+            initializeMember(
+                "pnq-visitor1(Launcher_Manager-1099-13-40-24-5368)-24357",
+                "pnq-visitor1", true, true, true, true));
+
+        for (int i = 2; i <= 8; i++) {
+          if ((i % 2) == 0) {
+            membersHMap.put(
+                "pnq-visitor" + i,
+                initializeMember("pnq-visitor" + i
+                    + "(Launcher_Server-1099-13-40-24-5368)-24357",
+                    "pnq-visitor" + i, false, false, true, false));
+          } else {
+            if ((i % 3) == 0) {
+              membersHMap.put(
+                  "pnq-visitor" + i,
+                  initializeMember("pnq-visitor" + i
+                      + "(Launcher_Server-1099-13-40-24-5368)-24357",
+                      "pnq-visitor" + i, false, false, false, false));
+            } else {
+              membersHMap.put(
+                  "pnq-visitor" + i,
+                  initializeMember("pnq-visitor" + i
+                      + "(Launcher_Server-1099-13-40-24-5368)-24357",
+                      "pnq-visitor" + i, false, true, true, true));
+            }
+          }
+        }
+
+        for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
+          HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
+          HashMap<String, Cluster.Client> memberClientsHM = new HashMap<String, Cluster.Client>();
+
+          Random randomGenerator = new Random();
+          int randomInt = (randomGenerator.nextInt(15)) + 10;
+          int regionExists = 0;
+          for (int y = 0; y < randomInt; y++) {
+            Region region = initMemberRegion(y, memberSet.getValue().getName());
+            if (clusterRegionMap.entrySet().size() > 0) {
+              for (Region clusterRegion : clusterRegionMap.values()) {
+                if ((region.name).equals(clusterRegion.name)) {
+                  clusterRegion.memberName.add(memberSet.getValue().getName());
+                  clusterRegion.memberCount = clusterRegion.memberCount + 1;
+                  regionExists = 1;
+                  break;
+                }
+              }
+              if (regionExists == 0) {
+                addClusterRegion(region.getFullPath(), region);
+              }
+            } else {
+              addClusterRegion(region.getFullPath(), region);
+            }
+            memberRegions.put(region.getFullPath(), region);
+            totalRegionCount = clusterRegionMap.values().size();
+          }
+          membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
+
+          if (memberSet.getValue().isCache) {
+            Client client = initMemberClient(0, memberSet.getValue().getHost());
+            memberClientsHM.put(client.getId(), client);
+            randomInt = randomGenerator.nextInt(10);
+            for (int y = 1; y < randomInt; y++) {
+              Client newClient = initMemberClient(y, memberSet.getValue()
+                  .getHost());
+              memberClientsHM.put(newClient.getId(), newClient);
+            }
+            membersHMap.get(memberSet.getKey()).updateMemberClientsHMap(
+                memberClientsHM);
+            clientConnectionCount = clientConnectionCount
+                + membersHMap.get(memberSet.getKey()).getMemberClientsHMap()
+                    .size();
+          }
+
+        }
+      }
+
+		// add additional regions to members
+      for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
+        HashMap<String, Cluster.Region> memberRegions = new HashMap<String, Cluster.Region>();
+
+        Random randomGenerator = new Random();
+        int randomInt = (randomGenerator.nextInt(5)) + 5;
+        int regionExists = 0;
+        for (int y = 0; y < randomInt; y++) {
+          Region region = initMemberRegion(y, memberSet.getValue().getName());
+          if (clusterRegionMap.entrySet().size() > 0) {
+            for (Region clusterRegion : clusterRegionMap.values()) {
+              if ((region.name).equals(clusterRegion.name)) {
+                clusterRegion.memberName.add(memberSet.getValue().getName());
+                clusterRegion.memberCount = clusterRegion.memberCount + 1;
+                regionExists = 1;
+                break;
+              }
+            }
+            if (regionExists == 0) {
+              addClusterRegion(region.getFullPath(), region);
+            }
+          } else {
+            addClusterRegion(region.getFullPath(), region);
+          }
+          memberRegions.put(region.getFullPath(), region);
+          totalRegionCount = clusterRegionMap.values().size();
+        }
+        membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
+
+      }
+
+      wanInformation.clear();
+      int wanInfoSize = Math.abs(r.nextInt(10));
+      wanInfoSize++;
+      for (int i = 0; i < wanInfoSize; i++) {
+        String name = "Mock Cluster" + i;
+        Boolean value = false;
+        if (i % 2 == 0) {
+          value = true;
+        }
+        wanInformation.put(name, value);
+      }
+      memberCount = membersHMap.size();
+
+      totalHeapSize = (long) 0;
+      for (Entry<String, Member> memberSet : membersHMap.entrySet()) {
+        refresh(membersHMap.get(memberSet.getKey()));
+        Member member = membersHMap.get(memberSet.getKey());
+        totalHeapSize += member.currentHeapSize;
+      }
+
+      for (Region region : clusterRegionMap.values()) {
+        // Memory reads and writes
+        region.getsRate = (Math.abs(r.nextInt(100))) + 1;
+        region.putsRate = (Math.abs(r.nextInt(100))) + 1;
+        region.getsPerSecTrend.add(region.getsRate);
+        region.putsPerSecTrend.add(region.putsRate);
+
+        // Disk reads and writes
+        region.diskReadsRate = (Math.abs(r.nextInt(100))) + 1;
+        region.diskWritesRate = (Math.abs(r.nextInt(100))) + 1;
+        region.diskReadsPerSecTrend.add(region.diskReadsRate);
+        region.diskWritesPerSecTrend.add(region.diskWritesRate);
+      }
+
+      if(clusterStatementMap.size() < 500){
+        for(int i = 1; i <= 500; ++i) {
+        

<TRUNCATED>

[16/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRemoveAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRemoveAllOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRemoveAllOperation.java
index 0390b29..9940a57 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRemoveAllOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRemoveAllOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,36 +28,36 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.persistence.PersistentReplicatesOfflineException;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.EntryVersionsList;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllEntryData;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.persistence.PersistentReplicatesOfflineException;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.EntryVersionsList;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllEntryData;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  * Handles distribution of a Region.removeAll operation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedTombstoneOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedTombstoneOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedTombstoneOperation.java
index 1627fb8..c4995cb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedTombstoneOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedTombstoneOperation.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.SerializationVersions;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedDataSerializable;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.SerializationVersions;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedDataSerializable;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -86,7 +86,7 @@ public class DistributedTombstoneOperation extends DistributedCacheOperation {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.DistributedCacheOperation#getLocalFilterRouting(com.gemstone.gemfire.internal.cache.FilterRoutingInfo)
+   * @see org.apache.geode.internal.cache.DistributedCacheOperation#getLocalFilterRouting(org.apache.geode.internal.cache.FilterRoutingInfo)
    */
   @Override
   protected FilterInfo getLocalFilterRouting(FilterRoutingInfo frInfo) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DummyCachePerfStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DummyCachePerfStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DummyCachePerfStats.java
index 8c0eabf..0122d5a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DummyCachePerfStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DummyCachePerfStats.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.distributed.internal.PoolStatHelper;
+import org.apache.geode.Statistics;
+import org.apache.geode.distributed.internal.PoolStatHelper;
 
 /**
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionAttributes.java
index f855255..5f69999 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionAttributes.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
 
 /**
  * Class <code>DynamicRegionAttributes</code> encapsulates the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionFactoryImpl.java
index 09afc91..584a2a7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DynamicRegionFactoryImpl.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.DynamicRegionFactory;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.DynamicRegionFactory;
 
 /** This class provides non-published methods that allow the cache
     to initialize and close the factory.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesMap.java
index 3db1320..0f01bcf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesMap.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
 
 import java.util.concurrent.Callable;
 import java.util.concurrent.ConcurrentMap;
-import com.gemstone.gemfire.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DM;
 
 /**
  * Interface for accessing extended features of a ConcurrentMap used for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesSet.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesSet.java
index 109b9c7..de91f03 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntriesSet.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.AbstractSet;
 import java.util.ArrayList;
@@ -24,12 +24,12 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.NoSuchElementException;
 
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.internal.QueryExecutionContext;
-import com.gemstone.gemfire.internal.cache.LocalRegion.IteratorType;
-import com.gemstone.gemfire.internal.cache.LocalRegion.NonTXEntry;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.internal.QueryExecutionContext;
+import org.apache.geode.internal.cache.LocalRegion.IteratorType;
+import org.apache.geode.internal.cache.LocalRegion.NonTXEntry;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /** Set view of entries */
 public class EntriesSet extends AbstractSet {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntryBits.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryBits.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryBits.java
index a67a335..bf453ca 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryBits.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryBits.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Interprets a one-byte bit field used for entry properties.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntryEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryEventImpl.java
index bd7596f..a555cca 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryEventImpl.java
@@ -15,50 +15,50 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.IndexMaintenanceException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.util.TimestampedEntryEvent;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerHelper;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tx.DistTxKeyInfo;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventCallbackArgument;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.*;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.ArrayUtils;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.pdx.internal.PeerTypeRegistration;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.IndexMaintenanceException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.util.TimestampedEntryEvent;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.cache.partitioned.PutMessage;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerHelper;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tx.DistTxKeyInfo;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventCallbackArgument;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.*;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.ArrayUtils;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.pdx.internal.PeerTypeRegistration;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
 import java.util.function.Function;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
 
 /**
  * Implementation of an entry event
@@ -1036,7 +1036,7 @@ public class EntryEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#getRegion()
+   * @see org.apache.geode.cache.CacheEvent#getRegion()
    */
   public final LocalRegion getRegion() {
     return region;
@@ -1057,7 +1057,7 @@ public class EntryEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#getCallbackArgument()
+   * @see org.apache.geode.cache.CacheEvent#getCallbackArgument()
    */
   public Object getCallbackArgument()
   {
@@ -1390,7 +1390,7 @@ public class EntryEventImpl
                             || obj == Token.NOT_AVAILABLE
                             || Token.isInvalidOrRemoved(obj)
                             // don't serialize delta object already serialized
-                            || obj instanceof com.gemstone.gemfire.Delta) { // internal delta
+                            || obj instanceof org.apache.geode.Delta) { // internal delta
       return obj;
     }
     final CachedDeserializable cd;
@@ -1579,7 +1579,7 @@ public class EntryEventImpl
     //This is a horrible hack, but we need to get the size of the object
     //When we store an entry. This code is only used when we do a put
     //in the primary.
-    if(v instanceof com.gemstone.gemfire.Delta && region.isUsedForPartitionedRegionBucket()) {
+    if(v instanceof org.apache.geode.Delta && region.isUsedForPartitionedRegionBucket()) {
       int vSize;
       Object ov = basicGetOldValue();
       if(ov instanceof CachedDeserializable && !GemFireCacheImpl.DELTAS_RECALCULATE_SIZE) {
@@ -1703,7 +1703,7 @@ public class EntryEventImpl
       boolean deltaBytesApplied = false;
       try {
         long start = CachePerfStats.getStatTime();
-        ((com.gemstone.gemfire.Delta)value).fromDelta(new DataInputStream(
+        ((org.apache.geode.Delta)value).fromDelta(new DataInputStream(
             new ByteArrayInputStream(getDeltaBytes())));
         this.region.getCachePerfStats().endDeltaUpdate(start);
         deltaBytesApplied = true;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntryExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryExpiryTask.java
index ac2a054..816f32f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryExpiryTask.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * EntryExpiryTask represents a timeout event for a region entry.
  */
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Released;
 import org.apache.logging.log4j.Logger;
 
 import java.util.concurrent.locks.Lock;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntryOperationImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryOperationImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryOperationImpl.java
index 4b757fb..0c78af8 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntryOperationImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntryOperationImpl.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryOperation;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.EntryOperation;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EntrySnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EntrySnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EntrySnapshot.java
index b5c828f..240aed1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EntrySnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EntrySnapshot.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,14 +22,14 @@ import java.io.IOException;
 import java.util.Hashtable;
 import java.util.Map;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
    * A Region.Entry implementation for remote entries and all PR entries
@@ -205,7 +205,7 @@ private static final long serialVersionUID = -2139749921655693280L;
 
     /*
      * (non-Javadoc)
-     * @see com.gemstone.gemfire.cache.Region.Entry#isLocal()
+     * @see org.apache.geode.cache.Region.Entry#isLocal()
      */
     public boolean isLocal() {
       // pr entries are always non-local to support the bucket being moved out

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EnumListenerEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EnumListenerEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EnumListenerEvent.java
index 1fa5709..5212614 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EnumListenerEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EnumListenerEvent.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 public abstract class EnumListenerEvent
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EventID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EventID.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EventID.java
index a9fb7da..6d17a67 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EventID.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EventID.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.ha.HARegionQueue;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.Breadcrumbs;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EventIDHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EventIDHolder.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EventIDHolder.java
index 6dd8586..4d27aee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EventIDHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EventIDHolder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * This class is an event that just holds an EventID.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EventStateHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EventStateHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EventStateHelper.java
index b59b0a4..3ba96ad 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EventStateHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EventStateHelper.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.CreateRegionProcessor.CreateRegionReplyMessage;
-import com.gemstone.gemfire.internal.cache.EventTracker.EventSeqnoHolder;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.RegionStateMessage;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue.DispatchedAndCurrentEvents;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.CreateRegionProcessor.CreateRegionReplyMessage;
+import org.apache.geode.internal.cache.EventTracker.EventSeqnoHolder;
+import org.apache.geode.internal.cache.InitialImageOperation.RegionStateMessage;
+import org.apache.geode.internal.cache.ha.HARegionQueue.DispatchedAndCurrentEvents;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EventTracker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EventTracker.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EventTracker.java
index ee24cf9..af294a9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EventTracker.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EventTracker.java
@@ -17,22 +17,22 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.client.PoolFactory;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.SystemTimer.SystemTimerTask;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.client.PoolFactory;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.SystemTimer.SystemTimerTask;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -57,7 +57,7 @@ public class EventTracker
    * a mapping of originator to the last event applied to this cache 
    *
    * Keys are instances of {@link ThreadIdentifier}, values are instances
-   * of {@link com.gemstone.gemfire.internal.cache.EventTracker.EventSeqnoHolder}.
+   * of {@link org.apache.geode.internal.cache.EventTracker.EventSeqnoHolder}.
    */
   protected final ConcurrentMap<ThreadIdentifier, EventSeqnoHolder> recordedEvents 
       = new ConcurrentHashMap<ThreadIdentifier, EventSeqnoHolder>(100);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/EvictionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/EvictionAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/EvictionAttributesImpl.java
index 50242aa..c30b7b5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/EvictionAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/EvictionAttributesImpl.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.EvictionAttributesMutator;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController;
-import com.gemstone.gemfire.internal.cache.lru.LRUAlgorithm;
-import com.gemstone.gemfire.internal.cache.lru.LRUCapacityController;
-import com.gemstone.gemfire.internal.cache.lru.MemLRUCapacityController;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.EvictionAttributesMutator;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.lru.HeapLRUCapacityController;
+import org.apache.geode.internal.cache.lru.LRUAlgorithm;
+import org.apache.geode.internal.cache.lru.LRUCapacityController;
+import org.apache.geode.internal.cache.lru.MemLRUCapacityController;
 
 /**
  * Defines the attributes for configuring the eviction controller associated
@@ -39,14 +39,14 @@ import com.gemstone.gemfire.internal.cache.lru.MemLRUCapacityController;
  * previoulsy deprecated CapacityController interface. Eviction, as defined
  * here, is the process of removing an Entry from the Region and potentially
  * placing it elsewhere, as defined by the
- * {@link com.gemstone.gemfire.cache.EvictionAction}. The algorithms used to
+ * {@link org.apache.geode.cache.EvictionAction}. The algorithms used to
  * determine when to perform the <code>EvictionAction</code> are enumerated in
- * the {@link com.gemstone.gemfire.cache.EvictionAlgorithm} class.
+ * the {@link org.apache.geode.cache.EvictionAlgorithm} class.
  * 
- * @see com.gemstone.gemfire.cache.EvictionAlgorithm
- * @see com.gemstone.gemfire.cache.AttributesFactory
- * @see com.gemstone.gemfire.cache.RegionAttributes
- * @see com.gemstone.gemfire.cache.AttributesMutator
+ * @see org.apache.geode.cache.EvictionAlgorithm
+ * @see org.apache.geode.cache.AttributesFactory
+ * @see org.apache.geode.cache.RegionAttributes
+ * @see org.apache.geode.cache.AttributesMutator
  * 
  * @since GemFire 5.0
  */
@@ -98,7 +98,7 @@ public final class EvictionAttributesImpl extends EvictionAttributes
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.EvictionAttributes#getObjectSizer()
+   * @see org.apache.geode.cache.EvictionAttributes#getObjectSizer()
    */
   @Override
   public ObjectSizer getObjectSizer()
@@ -107,7 +107,7 @@ public final class EvictionAttributesImpl extends EvictionAttributes
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.EvictionAttributes#getAlgorithm()
+   * @see org.apache.geode.cache.EvictionAttributes#getAlgorithm()
    */
   @Override
   public EvictionAlgorithm getAlgorithm()
@@ -135,7 +135,7 @@ public final class EvictionAttributesImpl extends EvictionAttributes
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.EvictionAttributes#getMaximum()
+   * @see org.apache.geode.cache.EvictionAttributes#getMaximum()
    */
   @Override
   public int getMaximum()
@@ -166,7 +166,7 @@ public final class EvictionAttributesImpl extends EvictionAttributes
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.EvictionAttributes#getAction()
+   * @see org.apache.geode.cache.EvictionAttributes#getAction()
    */
   @Override
   public EvictionAction getAction()

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ExpirationScheduler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ExpirationScheduler.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ExpirationScheduler.java
index 754db38..83f0c07 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ExpirationScheduler.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ExpirationScheduler.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.concurrent.atomic.AtomicInteger;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ExpiryTask.java
index 5e09cbe..72e2e70 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ExpiryTask.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * ExpiryTask represents a timeout event for expiration
  */
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.PooledExecutorWithDMStats;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.PooledExecutorWithDMStats;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.tcp.ConnectionTable;
 import org.apache.logging.log4j.Logger;
 
 import java.util.concurrent.RejectedExecutionException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ExportDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ExportDiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ExportDiskRegion.java
index 17b73b4..83e4703 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ExportDiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ExportDiskRegion.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.util.HashMap;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.DiskEntry.RecoveredEntry;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.DiskEntry.RecoveredEntry;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
 
 /**
  * An implementation if DiskRegion used for offline export. After each oplog

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FilterProfile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FilterProfile.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FilterProfile.java
index 73df7be..e64cb1a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FilterProfile.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FilterProfile.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -35,47 +35,47 @@ import java.util.regex.Pattern;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.SerializedCacheValue;
-import com.gemstone.gemfire.cache.query.internal.CqStateImpl;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.CqServiceProvider;
-import com.gemstone.gemfire.cache.query.internal.cq.ServerCQ;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.ClassLoadUtil;
-import com.gemstone.gemfire.internal.CopyOnWriteHashSet;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllEntryData;
-import com.gemstone.gemfire.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.UnregisterAllInterest;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CopyOnWriteHashMap;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.SerializedCacheValue;
+import org.apache.geode.cache.query.internal.CqStateImpl;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.CqServiceProvider;
+import org.apache.geode.cache.query.internal.cq.ServerCQ;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.ClassLoadUtil;
+import org.apache.geode.internal.CopyOnWriteHashSet;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllEntryData;
+import org.apache.geode.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.UnregisterAllInterest;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CopyOnWriteHashMap;
 
 /**
  * FilterProfile represents a distributed system member and is used for
@@ -1809,7 +1809,7 @@ public class FilterProfile implements DataSerializableFixedID {
     String serverCqName;
     
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.DistributionMessage#process(com.gemstone.gemfire.distributed.internal.DistributionManager)
+     * @see org.apache.geode.distributed.internal.DistributionMessage#process(org.apache.geode.distributed.internal.DistributionManager)
      */
     @Override
     protected void process(DistributionManager dm) {
@@ -1934,7 +1934,7 @@ public class FilterProfile implements DataSerializableFixedID {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
      */
     public int getDSFID() {
       return FILTER_PROFILE_UPDATE;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FilterRoutingInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FilterRoutingInfo.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FilterRoutingInfo.java
index 46fd295..7901397 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FilterRoutingInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FilterRoutingInfo.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedDataInputStream;
-import com.gemstone.gemfire.internal.VersionedDataSerializable;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedDataInputStream;
+import org.apache.geode.internal.VersionedDataSerializable;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FindDurableQueueProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FindDurableQueueProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FindDurableQueueProcessor.java
index 7ec993a..241a965 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FindDurableQueueProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FindDurableQueueProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,20 +28,20 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.ServerLocator;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.ServerLocator;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A processor for helping a locator find the durable queues for a given durable client id.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FindRemoteTXMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FindRemoteTXMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FindRemoteTXMessage.java
index 5310495..d9321bc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FindRemoteTXMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FindRemoteTXMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,23 +25,23 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Message to all the peers to ask which member hosts the transaction

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FindVersionTagOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FindVersionTagOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FindVersionTagOperation.java
index 221d7dc..3fbfaba 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FindVersionTagOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FindVersionTagOperation.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,18 +27,18 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  *
@@ -126,7 +126,7 @@ public class FindVersionTagOperation {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.DistributionMessage#process(com.gemstone.gemfire.distributed.internal.DistributionManager)
+     * @see org.apache.geode.distributed.internal.DistributionMessage#process(org.apache.geode.distributed.internal.DistributionManager)
      */
     @Override
     protected void process(DistributionManager dm) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FixedPartitionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FixedPartitionAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FixedPartitionAttributesImpl.java
index e0b915a..ce11829 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FixedPartitionAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FixedPartitionAttributesImpl.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ForceReattemptException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ForceReattemptException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ForceReattemptException.java
index 04b95bb..e3df1a6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ForceReattemptException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ForceReattemptException.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.internal.Assert;
 
 /**
  * Indicates that the current partitioned region operation failed.  It
  * is only thrown in a context where the higher level operation needs to
  * instigate a retry of some sort.
  * 
- * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage
+ * @see org.apache.geode.internal.cache.partitioned.PartitionMessage
  * @since GemFire 5.0
  */
 public class ForceReattemptException extends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ForceableLinkedBlockingQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ForceableLinkedBlockingQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ForceableLinkedBlockingQueue.java
index f58fc02..8f1c3a8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ForceableLinkedBlockingQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ForceableLinkedBlockingQueue.java
@@ -26,7 +26,7 @@
  * Expert Group and released to the public domain, as explained at
  * http://creativecommons.org/licenses/publicdomain
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.concurrent.*;
 import java.util.concurrent.atomic.AtomicInteger;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingOrderedReplyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingOrderedReplyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingOrderedReplyMessage.java
index 3c196bc..c0d3d4d 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingOrderedReplyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingOrderedReplyMessage.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingReplyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingReplyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingReplyMessage.java
index aaf6548..fef5f95 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingReplyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/FunctionStreamingReplyMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,14 +23,14 @@ import java.io.NotSerializableException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 public class FunctionStreamingReplyMessage extends ReplyMessage{
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/GatewayEventFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/GatewayEventFilter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/GatewayEventFilter.java
index e791b12..94e3fb2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/GatewayEventFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/GatewayEventFilter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 /**
  * 
  *


[03/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionInvocationTargetException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionInvocationTargetException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionInvocationTargetException.java
index 1171c17..54517d4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionInvocationTargetException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionInvocationTargetException.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.distributed.DistributedMember;
 
 public class InternalFunctionInvocationTargetException extends
     FunctionInvocationTargetException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionService.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionService.java
index f0ed757..1374636 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionService.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionService.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.internal.FunctionServiceManager;
-import com.gemstone.gemfire.internal.cache.AbstractRegion;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.internal.FunctionServiceManager;
+import org.apache.geode.internal.cache.AbstractRegion;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalRegionFunctionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalRegionFunctionContext.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalRegionFunctionContext.java
index 90ad79c..2bf8e15 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalRegionFunctionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalRegionFunctionContext.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.internal.cache.LocalDataSet;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.internal.cache.LocalDataSet;
 
 /**
  * Internal interface used to provide for some essential functionality for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalResultSender.java
index eb3349f..21a5195 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalResultSender.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.cache.execute.ResultSender;
+import org.apache.geode.cache.execute.ResultSender;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollector.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollector.java
index b190ae9..826ce93 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollector.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
 
 /**
  * Extends {@link ResultCollector} interface to provide for methods that are

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
index ce06b78..4893a4b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public final class LocalResultCollectorImpl implements LocalResultCollector {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
index 3912245..5320cdd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Collections;
 import java.util.HashMap;
@@ -22,24 +22,24 @@ import java.util.HashSet;
 import java.util.Iterator;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.SetUtils;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
index ceecb66..cc4889e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.MemberFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.MemberFunctionStreamingMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultWaiter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultWaiter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultWaiter.java
index af8c5f3..5ab060a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultWaiter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultWaiter.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashMap;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.MemberFunctionStreamingMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.MemberFunctionStreamingMessage;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberMappedArgument.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberMappedArgument.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberMappedArgument.java
index 001b701..6bfd552 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberMappedArgument.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberMappedArgument.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.io.Serializable;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContext.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContext.java
index 43dc087..6723da1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContext.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
 
 /**
  * Context available when called using

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContextImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContextImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContextImpl.java
index dec81a8..f8ee8f2 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContextImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionContextImpl.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.ResultSender;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.ResultSender;
 
 /**
  * Context available when called using

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionExecutor.java
index a9f933a..1604d83 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionExecutor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashMap;
 import java.util.HashSet;
@@ -22,28 +22,28 @@ import java.util.Map;
 import java.util.Random;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.SetUtils;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-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.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionResultWaiter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionResultWaiter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionResultWaiter.java
index dfcc90e..47a7a00 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionResultWaiter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MultiRegionFunctionResultWaiter.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashMap;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.MemberFunctionStreamingMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.MemberFunctionStreamingMessage;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/NoResult.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/NoResult.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/NoResult.java
index 484b21d..ec4a27a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/NoResult.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/NoResult.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.io.Serializable;
 
 import java.util.concurrent.TimeUnit;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A Special ResultCollector implementation. Functions having

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionExecutor.java
index 359b7f6..3337e0a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionExecutor.java
@@ -15,28 +15,28 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Iterator;
 import java.util.NoSuchElementException;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.TransactionDataRebalancedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.SetUtils;
-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.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.TransactionDataRebalancedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 
@@ -344,7 +344,7 @@ public class PartitionedRegionFunctionExecutor extends AbstractExecution {
     return buf.toString();
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.execute.AbstractExecution#validateExecution(com.gemstone.gemfire.cache.execute.Function, java.util.Set)
+   * @see org.apache.geode.internal.cache.execute.AbstractExecution#validateExecution(org.apache.geode.cache.execute.Function, java.util.Set)
    */
   @Override
   public void validateExecution(Function function, Set targetMembers) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
index 3a3e6e3..e15d401 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * ResultSender needs ResultCollector in which to add results one by one.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
index 53eb05b..550e649 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-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.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PRFunctionStreamingResultCollector;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
+import org.apache.geode.internal.cache.partitioned.PRFunctionStreamingResultCollector;
 
 /**
  * ResultReciever (which could be resultCollector?)will be instantiated and will be used

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/RegionFunctionContextImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/RegionFunctionContextImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/RegionFunctionContextImpl.java
index 302b24e..4052df7 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/RegionFunctionContextImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/RegionFunctionContextImpl.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Collections;
 import java.util.HashMap;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.internal.cache.LocalDataSet;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.internal.cache.LocalDataSet;
 
 /**
  * Context available to data dependent functions. When function is executed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerFunctionExecutor.java
index 0cca113..4295898 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerFunctionExecutor.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.internal.ExecuteFunctionNoAckOp;
-import com.gemstone.gemfire.cache.client.internal.ExecuteFunctionOp;
-import com.gemstone.gemfire.cache.client.internal.GetFunctionAttributeOp;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.internal.ExecuteFunctionNoAckOp;
+import org.apache.geode.cache.client.internal.ExecuteFunctionOp;
+import org.apache.geode.cache.client.internal.GetFunctionAttributeOp;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 /**
  * 
  *
@@ -295,7 +295,7 @@ public class ServerFunctionExecutor extends AbstractExecution {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.execute.AbstractExecution#validateExecution(com.gemstone.gemfire.cache.execute.Function, java.util.Set)
+   * @see org.apache.geode.internal.cache.execute.AbstractExecution#validateExecution(org.apache.geode.cache.execute.Function, java.util.Set)
    */
   @Override
   public void validateExecution(Function function, Set targetMembers) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerRegionFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerRegionFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerRegionFunctionExecutor.java
index 3a445e7..b5bc684 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerRegionFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerRegionFunctionExecutor.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.TXStateProxyImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.ServerRegionProxy;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.TXStateProxyImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 import java.util.Set;
 
@@ -362,7 +362,7 @@ public class ServerRegionFunctionExecutor extends AbstractExecution {
     return new ServerRegionFunctionExecutor(this, argument);
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.execute.AbstractExecution#validateExecution(com.gemstone.gemfire.cache.execute.Function, java.util.Set)
+   * @see org.apache.geode.internal.cache.execute.AbstractExecution#validateExecution(org.apache.geode.cache.execute.Function, java.util.Set)
    */
   @Override
   public void validateExecution(Function function, Set targetMembers) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender.java
index 36c79c0..22b3737 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.io.IOException;
 import java.nio.ByteBuffer;
@@ -23,20 +23,20 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.operations.ExecuteFunctionOperationContext;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.tier.Command;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.security.AuthorizeRequestPP;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.cache.operations.ExecuteFunctionOperationContext;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.tier.Command;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.security.AuthorizeRequestPP;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender65.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender65.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender65.java
index 5ac75c6..31c3fb4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender65.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/ServerToClientFunctionResultSender65.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.io.IOException;
 import java.util.ArrayList;
@@ -22,18 +22,18 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.operations.ExecuteFunctionOperationContext;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.tier.Command;
-import com.gemstone.gemfire.internal.cache.tier.sockets.BaseCommand;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.operations.ExecuteFunctionOperationContext;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.tier.Command;
+import org.apache.geode.internal.cache.tier.sockets.BaseCommand;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 /**
  * 
  * @since GemFire 6.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
index 07be79c..ba2fd79 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Collections;
 import java.util.HashMap;
 import java.util.Set;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/util/FindRestEnabledServersFunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/util/FindRestEnabledServersFunction.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/util/FindRestEnabledServersFunction.java
index 99a1d6c..793f73c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/util/FindRestEnabledServersFunction.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/util/FindRestEnabledServersFunction.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute.util;
+package org.apache.geode.internal.cache.execute.util;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.FunctionAdapter;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.InternalEntity;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.FunctionAdapter;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.InternalEntity;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 /**
 * The FindRestEnabledServersFunction class is a gemfire function that gives details about REST enabled gemfire servers.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extensible.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extensible.java b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extensible.java
index a3796d4..c7f38fe 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extensible.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extensible.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.extension;
+package org.apache.geode.internal.cache.extension;
 
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
 
 /**
  * Provides marker for extensibility and access to {@link ExtensionPoint}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extension.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extension.java b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extension.java
index ced104b..e1d5df6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extension.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/Extension.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.extension;
+package org.apache.geode.internal.cache.extension;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
-import com.gemstone.gemfire.internal.cache.xmlcache.XmlGenerator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.cache.xmlcache.XmlGenerator;
 
 /**
  * Interface used for objects wishing to extend and {@link Extensible} object.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/extension/ExtensionPoint.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/ExtensionPoint.java b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/ExtensionPoint.java
index 0ecf39a..b9ddd42 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/ExtensionPoint.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/ExtensionPoint.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.extension;
+package org.apache.geode.internal.cache.extension;
 
 /**
  * Allows {@link Extensible} objects to add and remove {@link Extension}s.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/extension/SimpleExtensionPoint.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/SimpleExtensionPoint.java b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/SimpleExtensionPoint.java
index 2d88808..14c9193 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/extension/SimpleExtensionPoint.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/extension/SimpleExtensionPoint.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.extension;
+package org.apache.geode.internal.cache.extension;
 
 import java.util.ArrayList;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.internal.util.CollectionUtils;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.internal.util.CollectionUtils;
 
 /**
  * Simple implementation of {@link ExtensionPoint} for easy integration with

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerMap.java
index 8f8be30..1cc4419 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerMap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -23,10 +23,10 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerRegion.java
index db1a783..5bf7065 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerRegion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -23,14 +23,14 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-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 com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.HAEventWrapper;
 
 /**
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerWrapper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerWrapper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerWrapper.java
index d0b831e..fa73789 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HAContainerWrapper.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
 import java.util.Map;
 
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 /**
  * @since GemFire 5.7

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
index 2b8934e..027a1b5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
@@ -14,34 +14,34 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.query.internal.CqQueryVsdStats;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.distributed.DistributedMember;
-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.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.tier.sockets.*;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessageImpl.CqNameToOp;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCondition;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantLock;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableWriteLock;
+package org.apache.geode.internal.cache.ha;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.query.internal.CqQueryVsdStats;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.tier.sockets.*;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessageImpl.CqNameToOp;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.StoppableCondition;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantLock;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableWriteLock;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -3621,7 +3621,7 @@ protected boolean checkEventForRemoval(Long counter, ThreadIdentifier threadid,
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#fromData(java.io.DataInput)
+     * @see org.apache.geode.internal.DataSerializableFixedID#fromData(java.io.DataInput)
      */
     public void fromData(DataInput in) throws IOException,
         ClassNotFoundException {
@@ -3632,14 +3632,14 @@ protected boolean checkEventForRemoval(Long counter, ThreadIdentifier threadid,
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
      */
     public int getDSFID() {
       return DISPATCHED_AND_CURRENT_EVENTS;
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#toData(java.io.DataOutput)
+     * @see org.apache.geode.internal.DataSerializableFixedID#toData(java.io.DataOutput)
      */
     public void toData(DataOutput out) throws IOException {
       synchronized (this) { // fix for bug #41621

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueAttributes.java
index c2ff1a0..190132e 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueAttributes.java
@@ -17,9 +17,9 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueStats.java
index 150c080..4441748 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueueStats.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.internal.cache.ha;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * This class tracks GemFire statistics related to a {@link HARegionQueue}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/QueueRemovalMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/QueueRemovalMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/QueueRemovalMessage.java
index 4ffb4d8..07e6465 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/QueueRemovalMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/QueueRemovalMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,19 +26,19 @@ import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.HARegion;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.HARegion;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * This message is sent to all the nodes in the DistributedSystem. It contains

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ha/ThreadIdentifier.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/ThreadIdentifier.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/ThreadIdentifier.java
index c2f3785..614b09a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/ThreadIdentifier.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/ThreadIdentifier.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.ha;
+package org.apache.geode.internal.cache.ha;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInput;
@@ -23,10 +23,10 @@ import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Arrays;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.EventID;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.EventID;
 
 /**
  * Class identifying a Thread uniquely across the distributed system. It is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLessorDepartureHandler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLessorDepartureHandler.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLessorDepartureHandler.java
index fa323e8..cfbb4e3 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLessorDepartureHandler.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLessorDepartureHandler.java
@@ -15,20 +15,20 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
 import java.util.Set;
 import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.locks.DLockBatch;
-import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockLessorDepartureHandler;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.locks.DLockBatch;
+import org.apache.geode.distributed.internal.locks.DLockGrantor;
+import org.apache.geode.distributed.internal.locks.DLockLessorDepartureHandler;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Handles departure of lessor (lease holder) by sending a message asking

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockBatch.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockBatch.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockBatch.java
index 410aa77..8e7a15f 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockBatch.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockBatch.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-//import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.TXRegionLockRequestImpl;
-import com.gemstone.gemfire.internal.cache.IdentityArrayList;
-import com.gemstone.gemfire.distributed.internal.locks.DLockBatch;
-import com.gemstone.gemfire.distributed.internal.locks.DLockBatchId;
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorId;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+//import org.apache.geode.cache.Region;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.TXRegionLockRequestImpl;
+import org.apache.geode.internal.cache.IdentityArrayList;
+import org.apache.geode.distributed.internal.locks.DLockBatch;
+import org.apache.geode.distributed.internal.locks.DLockBatchId;
+import org.apache.geode.distributed.internal.locks.LockGrantorId;
 
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /** 
  * Adapts multiple TXRegionLockRequests to one DLockBatch for DLock to use.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockId.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockId.java
index e6c355e..067ba78 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockId.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockId.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.distributed.internal.locks.DLockBatchId;
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorId;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.locks.DLockBatchId;
+import org.apache.geode.distributed.internal.locks.LockGrantorId;
+import org.apache.geode.distributed.internal.membership.*;
 
 /** Specifies a set of keys to try-lock within the scope of a region */
 public interface TXLockId extends DLockBatchId {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockIdImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockIdImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockIdImpl.java
index 7ee67c4..3ffaee2 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockIdImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockIdImpl.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
 import java.io.*;
 
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorId;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.locks.LockGrantorId;
+import org.apache.geode.distributed.internal.membership.*;
 
 /** 
  * Identifies a group of transaction locks.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockService.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockService.java
index 18c4caa..6a52d48 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockService.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.distributed.internal.locks.*;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.distributed.internal.locks.*;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockServiceImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockServiceImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockServiceImpl.java
index 6ddd2bc..04963e5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockServiceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockServiceImpl.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -24,16 +24,16 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CommitConflictException;
-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.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorId;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.locks.LockGrantorId;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
 
 /** Provides clean separation of implementation from public facade */
 public class TXLockServiceImpl extends TXLockService {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockToken.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockToken.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockToken.java
index 2d1568e..3d0cada 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockToken.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockToken.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-//import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+//import org.apache.geode.cache.Region;
 import java.io.*;
 
 import org.apache.commons.lang.StringUtils;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockUpdateParticipantsMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockUpdateParticipantsMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockUpdateParticipantsMessage.java
index 8165cea..135e35f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockUpdateParticipantsMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXLockUpdateParticipantsMessage.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor;
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorDestroyedException;
+package org.apache.geode.internal.cache.locks;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.locks.DLockGrantor;
+import org.apache.geode.distributed.internal.locks.LockGrantorDestroyedException;
 import java.io.*;
 import java.util.Set;
 
@@ -37,14 +37,14 @@ import java.util.Set;
  * crashes/departs before or while sending the TXCommitMessage but
  * after making the reservation for the transaction.
  * 
- * @see com.gemstone.gemfire.internal.cache.TXCommitMessage#send(TXLockId)
- * @see com.gemstone.gemfire.internal.cache.TXCommitMessage#updateLockMembers
- * @see com.gemstone.gemfire.distributed.internal.locks.DLockGrantor#getLockBatch(Object)
- * @see com.gemstone.gemfire.distributed.internal.locks.DLockGrantor#updateLockBatch(Object, com.gemstone.gemfire.distributed.internal.locks.DLockBatch)
+ * @see org.apache.geode.internal.cache.TXCommitMessage#send(TXLockId)
+ * @see org.apache.geode.internal.cache.TXCommitMessage#updateLockMembers
+ * @see org.apache.geode.distributed.internal.locks.DLockGrantor#getLockBatch(Object)
+ * @see org.apache.geode.distributed.internal.locks.DLockGrantor#updateLockBatch(Object, org.apache.geode.distributed.internal.locks.DLockBatch)
  * @see TXLockBatch#getBatchId
  * @see TXLessorDepartureHandler
  * @see TXOriginatorRecoveryProcessor
- * @see com.gemstone.gemfire.internal.cache.TXFarSideCMTracker
+ * @see org.apache.geode.internal.cache.TXFarSideCMTracker
  * 
  * @since GemFire 4.1.1
  */



[46/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/ClassInNonExperimentalPackage.java
----------------------------------------------------------------------
diff --git a/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/ClassInNonExperimentalPackage.java b/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/ClassInNonExperimentalPackage.java
index 26499a6..10f6072 100755
--- a/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/ClassInNonExperimentalPackage.java
+++ b/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/ClassInNonExperimentalPackage.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.experimental.nonexperimentalpackage;
+package org.apache.geode.experimental.nonexperimentalpackage;
 
 /**
  * Used by <tt>ExperimentalJUnitTest</tt>. This is a class in an
  * <tt>Experimental</tt> package.
  * 
- * @see com.gemstone.gemfire.annotations.ExperimentalJUnitTest
+ * @see org.apache.geode.annotations.ExperimentalJUnitTest
  */
 public class ClassInNonExperimentalPackage {
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/package-info.java
----------------------------------------------------------------------
diff --git a/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/package-info.java b/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/package-info.java
index 8e76724..20236a6 100755
--- a/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/package-info.java
+++ b/geode-common/src/test/java/org/apache/geode/experimental/nonexperimentalpackage/package-info.java
@@ -18,6 +18,6 @@
  * Used by <tt>ExperimentalJUnitTest</tt>. This is a non-<tt>Experimental</tt> 
  * package.
  * 
- * @see com.gemstone.gemfire.annotations.ExperimentalJUnitTest
+ * @see org.apache.geode.annotations.ExperimentalJUnitTest
  */
-package com.gemstone.gemfire.experimental.nonexperimentalpackage;
+package org.apache.geode.experimental.nonexperimentalpackage;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/build.gradle
----------------------------------------------------------------------
diff --git a/geode-core/build.gradle b/geode-core/build.gradle
index ea1fce2..b2e5a4e 100755
--- a/geode-core/build.gradle
+++ b/geode-core/build.gradle
@@ -135,7 +135,7 @@ sourceSets {
 
 // Creates the version properties file and writes it to the classes dir
 task createVersionPropertiesFile {
-  def propertiesFile = file(generatedResources + "/com/gemstone/gemfire/internal/GemFireVersion.properties");
+  def propertiesFile = file(generatedResources + "/org/apache/geode/internal/GemFireVersion.properties");
   outputs.file propertiesFile
   inputs.dir compileJava.destinationDir
 
@@ -162,22 +162,22 @@ jar {
   from sourceSets.main.output
   from sourceSets.jca.output
   
-  exclude 'com/gemstone/gemfire/management/internal/web/**'
-  exclude 'com/gemstone/gemfire/internal/i18n/StringIdResourceBundle_ja.txt'
-  exclude 'com/gemstone/gemfire/admin/doc-files/ds4_0.dtd'
+  exclude 'org/apache/geode/management/internal/web/**'
+  exclude 'org/apache/geode/internal/i18n/StringIdResourceBundle_ja.txt'
+  exclude 'org/apache/geode/admin/doc-files/ds4_0.dtd'
 }
 
 task webJar (type: Jar, dependsOn: classes) {
   description 'Assembles the jar archive containing the gemfire management web classes.'
   from sourceSets.main.output
   baseName 'geode-web'
-  include 'com/gemstone/gemfire/management/internal/web/**'
+  include 'org/apache/geode/management/internal/web/**'
 }
 
 task raJar (type: Jar, dependsOn: classes) {
   description 'Assembles the jar archive that contains the JCA classes'
   from sourceSets.jca.output
-  exclude 'com/gemstone/gemfire/ra/**'
+  exclude 'org/apache/geode/ra/**'
   archiveName 'ra.jar'
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionFactoryImpl.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionFactoryImpl.java
index 23343ea..d7bcc44 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionFactoryImpl.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionFactoryImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra;
+package org.apache.geode.internal.ra;
 
 import javax.naming.NamingException;
 import javax.naming.Reference;
@@ -22,7 +22,7 @@ import javax.resource.ResourceException;
 import javax.resource.spi.ConnectionManager;
 import javax.resource.spi.ManagedConnectionFactory;
 
-import com.gemstone.gemfire.ra.GFConnectionFactory;
+import org.apache.geode.ra.GFConnectionFactory;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionImpl.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionImpl.java
index de68486..7a69293 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionImpl.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/GFConnectionImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra;
+package org.apache.geode.internal.ra;
 
 import javax.naming.NamingException;
 import javax.naming.Reference;
 import javax.resource.ResourceException;
 
-import com.gemstone.gemfire.internal.ra.spi.JCAManagedConnection;
-import com.gemstone.gemfire.ra.GFConnection;
+import org.apache.geode.internal.ra.spi.JCAManagedConnection;
+import org.apache.geode.ra.GFConnection;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCALocalTransaction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCALocalTransaction.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCALocalTransaction.java
index 19afdb2..c7b2223 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCALocalTransaction.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCALocalTransaction.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra.spi;
+package org.apache.geode.internal.ra.spi;
 
 import javax.resource.ResourceException;
 import javax.resource.spi.LocalTransaction;
@@ -22,14 +22,14 @@ import javax.resource.spi.LocalTransactionException;
 import javax.transaction.SystemException;
 import javax.transaction.TransactionManager;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.TXStateProxy;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.TXStateProxy;
 
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnection.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnection.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnection.java
index 909e3f3..4a9c903 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnection.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnection.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra.spi;
+package org.apache.geode.internal.ra.spi;
 
 import java.io.PrintWriter;
 import java.util.ArrayList;
@@ -36,11 +36,11 @@ import javax.security.auth.Subject;
 import javax.transaction.SystemException;
 import javax.transaction.xa.XAResource;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.ra.GFConnectionImpl;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.ra.GFConnectionImpl;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionFactory.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionFactory.java
index f1b1143..fda8707 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionFactory.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra.spi;
+package org.apache.geode.internal.ra.spi;
 
 import java.io.PrintWriter;
 import java.util.Set;
@@ -26,7 +26,7 @@ import javax.resource.spi.ManagedConnection;
 import javax.resource.spi.ManagedConnectionFactory;
 import javax.security.auth.Subject;
 
-import com.gemstone.gemfire.internal.ra.GFConnectionFactoryImpl;
+import org.apache.geode.internal.ra.GFConnectionFactoryImpl;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionMetaData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionMetaData.java b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionMetaData.java
index e21f33f..6a04ac3 100644
--- a/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionMetaData.java
+++ b/geode-core/src/jca/java/org/apache/geode/internal/ra/spi/JCAManagedConnectionMetaData.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.ra.spi;
+package org.apache.geode.internal.ra.spi;
 
 import javax.resource.ResourceException;
 import javax.resource.spi.ManagedConnectionMetaData;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/jca/ra.xml
----------------------------------------------------------------------
diff --git a/geode-core/src/jca/ra.xml b/geode-core/src/jca/ra.xml
index 78b4579..0e258d7 100644
--- a/geode-core/src/jca/ra.xml
+++ b/geode-core/src/jca/ra.xml
@@ -25,7 +25,7 @@
     <eis-type>GFE JCA</eis-type>
     <version>1.5</version>
     <resourceadapter>
-        <managedconnectionfactory-class>com.gemstone.gemfire.internal.ra.spi.JCAManagedConnectionFactory</managedconnectionfactory-class>
+        <managedconnectionfactory-class>org.apache.geode.internal.ra.spi.JCAManagedConnectionFactory</managedconnectionfactory-class>
                 <config-property>
                     <config-property-name>ProductName</config-property-name>
                     <config-property-type>java.lang.String</config-property-type>
@@ -42,10 +42,10 @@
                     <config-property-value>8.0</config-property-value>
                 </config-property>
         
-        <connectionfactory-interface>com.gemstone.gemfire.ra.GFConnectionFactory</connectionfactory-interface>
-        <connectionfactory-impl-class>com.gemstone.gemfire.internal.ra.GFConnectionFactoryImpl</connectionfactory-impl-class>
-        <connection-interface>com.gemstone.gemfire.ra.GFConnection</connection-interface>
-        <connection-impl-class>com.gemstone.gemfire.internal.ra.GFConnectionImpl</connection-impl-class>
+        <connectionfactory-interface>org.apache.geode.ra.GFConnectionFactory</connectionfactory-interface>
+        <connectionfactory-impl-class>org.apache.geode.internal.ra.GFConnectionFactoryImpl</connectionfactory-impl-class>
+        <connection-interface>org.apache.geode.ra.GFConnection</connection-interface>
+        <connection-impl-class>org.apache.geode.internal.ra.GFConnectionImpl</connection-impl-class>
         <transaction-support>LocalTransaction</transaction-support>
         <reauthentication-support>false</reauthentication-support> 
     </resourceadapter>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/external-overview.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/external-overview.html b/geode-core/src/main/java/external-overview.html
index 6472059..ee2f395 100644
--- a/geode-core/src/main/java/external-overview.html
+++ b/geode-core/src/main/java/external-overview.html
@@ -26,7 +26,7 @@ constructs.</P>
 <P>GemFire's distributed caching allows application access to
 distributed and cached data across multiple physical machines.
 GemFire's main API for accessing distributed data is the {@linkplain
-com.gemstone.gemfire.cache.Region}
+org.apache.geode.cache.Region}
 
 <P>GemFire provides a flexible and powerful API for distributed object
 caching.  The API is particularly well-suited for caching application
@@ -37,7 +37,7 @@ data and data VMs.</P>
 
 <P>A discussion of the Distributed Caching API and GemFire's
 implementation of it can be found {@linkplain
-com.gemstone.gemfire.cache here}.</P>
+org.apache.geode.cache here}.</P>
 
 </BODY>
 </HTML>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/CancelCriterion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/CancelCriterion.java b/geode-core/src/main/java/org/apache/geode/CancelCriterion.java
index 0cb44ca..f0eb160 100644
--- a/geode-core/src/main/java/org/apache/geode/CancelCriterion.java
+++ b/geode-core/src/main/java/org/apache/geode/CancelCriterion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * Abstract cancellation proxy for cancelling an operation, esp. a thread.
@@ -54,7 +54,7 @@ public abstract class CancelCriterion
    * construct an exception indicating the service is shut down.
    */
   public abstract String cancelInProgress();
-//import com.gemstone.gemfire.distributed.internal.DistributionManager;
+//import org.apache.geode.distributed.internal.DistributionManager;
 //    * <p>
 //    * In particular, a {@link DistributionManager} returns a non-null result if
 //    * message distribution has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/CancelException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/CancelException.java b/geode-core/src/main/java/org/apache/geode/CancelException.java
index e896d2f..94fd8b5 100644
--- a/geode-core/src/main/java/org/apache/geode/CancelException.java
+++ b/geode-core/src/main/java/org/apache/geode/CancelException.java
@@ -17,9 +17,9 @@
 /**
  * 
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheRuntimeException;
 
 /**
  * Abstract root class of all GemFire exceptions representing system

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/CanonicalInstantiator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/CanonicalInstantiator.java b/geode-core/src/main/java/org/apache/geode/CanonicalInstantiator.java
index 8317141..d62d873 100644
--- a/geode-core/src/main/java/org/apache/geode/CanonicalInstantiator.java
+++ b/geode-core/src/main/java/org/apache/geode/CanonicalInstantiator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/CopyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/CopyException.java b/geode-core/src/main/java/org/apache/geode/CopyException.java
index 5294368..8ad9c57 100644
--- a/geode-core/src/main/java/org/apache/geode/CopyException.java
+++ b/geode-core/src/main/java/org/apache/geode/CopyException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * Indicates a failure to copy an object.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/CopyHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/CopyHelper.java b/geode-core/src/main/java/org/apache/geode/CopyHelper.java
index f3c2a6a..dd79c0e 100644
--- a/geode-core/src/main/java/org/apache/geode/CopyHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/CopyHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 import java.io.DataInputStream;
 import java.io.IOException;
 import java.io.Serializable;
@@ -25,14 +25,14 @@ import java.math.BigInteger;
 import java.util.Arrays;
 import java.util.UUID;
 
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.WritablePdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxUnreadData;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.WritablePdxInstance;
+import org.apache.geode.pdx.internal.PdxUnreadData;
 
 /**
  * A static helper for optimally creating copies.  Creating copies
@@ -52,8 +52,8 @@ import com.gemstone.gemfire.pdx.internal.PdxUnreadData;
  * @see Cloneable
  * @see Serializable
  * @see DataSerializer
- * @see com.gemstone.gemfire.cache.Cache#setCopyOnRead
- * @see com.gemstone.gemfire.cache.CacheTransactionManager
+ * @see org.apache.geode.cache.Cache#setCopyOnRead
+ * @see org.apache.geode.cache.CacheTransactionManager
  *
  * @since GemFire 4.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/DataSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/DataSerializable.java b/geode-core/src/main/java/org/apache/geode/DataSerializable.java
index ecbb044..d7c60a5 100644
--- a/geode-core/src/main/java/org/apache/geode/DataSerializable.java
+++ b/geode-core/src/main/java/org/apache/geode/DataSerializable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.io.*;
 
@@ -34,7 +34,7 @@ import java.io.*;
  * When possible, GemFire respects the <code>DataSerializable</code>
  * contract to provide optimal object serialization.  For instance, if
  * a <code>DataSerializable</code> object is 
- * {@linkplain com.gemstone.gemfire.cache.Region#put(Object, Object) placed} into a distributed
+ * {@linkplain org.apache.geode.cache.Region#put(Object, Object) placed} into a distributed
  * cache region, its <code>toData</code> method will be used to
  * serialize it when it is sent to another member of the distributed
  * system.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/DataSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/DataSerializer.java b/geode-core/src/main/java/org/apache/geode/DataSerializer.java
index 360069a..224df85 100644
--- a/geode-core/src/main/java/org/apache/geode/DataSerializer.java
+++ b/geode-core/src/main/java/org/apache/geode/DataSerializer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -48,25 +48,25 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.RegionNotFoundException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.ObjToByteArraySerializer;
-import com.gemstone.gemfire.internal.Sendable;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.pdx.PdxInstance;
+import org.apache.geode.admin.RegionNotFoundException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.DSCODE;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.ObjToByteArraySerializer;
+import org.apache.geode.internal.Sendable;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.pdx.PdxInstance;
 
 /**
  * Provides static helper methods for reading and writing
@@ -301,8 +301,8 @@ public abstract class DataSerializer {
    * @return the name of the class in this implementation
    */
   private static String swizzleClassNameForRead(String name) {
-    String oldPackage = "com.gemstone.org.jgroups.stack.tcpserver";
-    String newPackage = "com.gemstone.gemfire.distributed.internal.tcpserver";
+    String oldPackage = "org.apache.org.jgroups.stack.tcpserver";
+    String newPackage = "org.apache.geode.distributed.internal.tcpserver";
     String result = name;
     if (name.startsWith(oldPackage)) {
       result = newPackage + name.substring(oldPackage.length());
@@ -319,8 +319,8 @@ public abstract class DataSerializer {
    * @return the name of the class in this implementation
    */
   private static String swizzleClassNameForWrite(String name) {
-    String oldPackage = "com.gemstone.org.jgroups.stack.tcpserver";
-    String newPackage = "com.gemstone.gemfire.distributed.internal.tcpserver";
+    String oldPackage = "org.apache.org.jgroups.stack.tcpserver";
+    String newPackage = "org.apache.geode.distributed.internal.tcpserver";
     String result = name;
     if (name.startsWith(newPackage)) {
       result = oldPackage + name.substring(newPackage.length());
@@ -369,7 +369,7 @@ public abstract class DataSerializer {
    *
    * @param in the input stream
    * @return the Region instance
-   * @throws com.gemstone.gemfire.cache.CacheClosedException if a cache has not been created or the only
+   * @throws org.apache.geode.cache.CacheClosedException if a cache has not been created or the only
    * created one is closed.
    * @throws RegionNotFoundException if there is no region by this name
    * in the Cache

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/Delta.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/Delta.java b/geode-core/src/main/java/org/apache/geode/Delta.java
index d345b58..de3ef98 100755
--- a/geode-core/src/main/java/org/apache/geode/Delta.java
+++ b/geode-core/src/main/java/org/apache/geode/Delta.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/DeltaSerializationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/DeltaSerializationException.java b/geode-core/src/main/java/org/apache/geode/DeltaSerializationException.java
index 15eb331..dfe2faf 100644
--- a/geode-core/src/main/java/org/apache/geode/DeltaSerializationException.java
+++ b/geode-core/src/main/java/org/apache/geode/DeltaSerializationException.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * This exception wraps any checked exception encountered during invocation of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/ForcedDisconnectException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/ForcedDisconnectException.java b/geode-core/src/main/java/org/apache/geode/ForcedDisconnectException.java
index d4ff966..cd3b90f 100755
--- a/geode-core/src/main/java/org/apache/geode/ForcedDisconnectException.java
+++ b/geode-core/src/main/java/org/apache/geode/ForcedDisconnectException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>ForcedDisconnectException</code> is thrown when a GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireCacheException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireCacheException.java b/geode-core/src/main/java/org/apache/geode/GemFireCacheException.java
index 0a18eeb..7f06d05 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireCacheException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireCacheException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-import com.gemstone.gemfire.cache.CacheException;
+import org.apache.geode.cache.CacheException;
 
 /**
  * An <code>GemFireCacheException</code> is used to wrap a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java b/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
index 3f1a4c4..c1db7d6 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireCheckedException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * This is the abstract superclass of exceptions that are thrown and
@@ -24,7 +24,7 @@ package com.gemstone.gemfire;
  * This class ought to be called <em>GemFireException</em>, but that name
  * is reserved for an older class that extends {@link java.lang.RuntimeException}.
  * 
- * @see com.gemstone.gemfire.GemFireException
+ * @see org.apache.geode.GemFireException
  * @since GemFire 5.1
  */
 public abstract class GemFireCheckedException extends Exception {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireConfigException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireConfigException.java b/geode-core/src/main/java/org/apache/geode/GemFireConfigException.java
index bb5dd5d..7063bce 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireConfigException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireConfigException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>GemFireConfigException</code> is used for failures

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireException.java b/geode-core/src/main/java/org/apache/geode/GemFireException.java
index c334947..142a97c 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * This is the abstract superclass of exceptions that are thrown to
@@ -25,8 +25,8 @@ package com.gemstone.gemfire;
  * <em>ought</em> to be called <code>GemFireRuntimeException</code>;
  * however, the current name is retained for compatibility's sake.
  * 
- * @see com.gemstone.gemfire.GemFireCheckedException
- * @see com.gemstone.gemfire.cache.CacheRuntimeException
+ * @see org.apache.geode.GemFireCheckedException
+ * @see org.apache.geode.cache.CacheRuntimeException
  */
 // Implementation note: This class is abstract so that we are forced
 // to have more specific exception types.  We want to avoid using

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireIOException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireIOException.java b/geode-core/src/main/java/org/apache/geode/GemFireIOException.java
index 4e0c399..583777c 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireIOException.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireIOException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>GemFireIOException</code> is thrown when a 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/GemFireRethrowable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/GemFireRethrowable.java b/geode-core/src/main/java/org/apache/geode/GemFireRethrowable.java
index 82c4092..a6ea18a 100644
--- a/geode-core/src/main/java/org/apache/geode/GemFireRethrowable.java
+++ b/geode-core/src/main/java/org/apache/geode/GemFireRethrowable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * This error is used by GemFire for internal purposes.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/IncompatibleSystemException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/IncompatibleSystemException.java b/geode-core/src/main/java/org/apache/geode/IncompatibleSystemException.java
index 0af1726..997feb3 100644
--- a/geode-core/src/main/java/org/apache/geode/IncompatibleSystemException.java
+++ b/geode-core/src/main/java/org/apache/geode/IncompatibleSystemException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>IncompatibleSystemException</code> is thrown when a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/Instantiator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/Instantiator.java b/geode-core/src/main/java/org/apache/geode/Instantiator.java
index 7aac081..00eb598 100644
--- a/geode-core/src/main/java/org/apache/geode/Instantiator.java
+++ b/geode-core/src/main/java/org/apache/geode/Instantiator.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.InternalInstantiator;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * <code>Instantiator</code> allows classes that implement {@link

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java b/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
index 0681bd2..39fe1ea 100644
--- a/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
+++ b/geode-core/src/main/java/org/apache/geode/InternalGemFireError.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * Indicates that serious error has occurred within the GemFire system.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/InternalGemFireException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/InternalGemFireException.java b/geode-core/src/main/java/org/apache/geode/InternalGemFireException.java
index 8c1598b..a2362f8 100644
--- a/geode-core/src/main/java/org/apache/geode/InternalGemFireException.java
+++ b/geode-core/src/main/java/org/apache/geode/InternalGemFireException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>InternalGemFireException</code> is thrown when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/InvalidDeltaException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/InvalidDeltaException.java b/geode-core/src/main/java/org/apache/geode/InvalidDeltaException.java
index 1cc162e..10d2d48 100755
--- a/geode-core/src/main/java/org/apache/geode/InvalidDeltaException.java
+++ b/geode-core/src/main/java/org/apache/geode/InvalidDeltaException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.io.DataInput;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/InvalidValueException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/InvalidValueException.java b/geode-core/src/main/java/org/apache/geode/InvalidValueException.java
index d7fa1ce..e323431 100644
--- a/geode-core/src/main/java/org/apache/geode/InvalidValueException.java
+++ b/geode-core/src/main/java/org/apache/geode/InvalidValueException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>InvalidValueException</code> is thrown when an attempt is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/InvalidVersionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/InvalidVersionException.java b/geode-core/src/main/java/org/apache/geode/InvalidVersionException.java
index 0f9af70..54813b3 100644
--- a/geode-core/src/main/java/org/apache/geode/InvalidVersionException.java
+++ b/geode-core/src/main/java/org/apache/geode/InvalidVersionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 public class InvalidVersionException extends GemFireException {
   private static final long serialVersionUID = 6342040462194322698L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/LicenseException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/LicenseException.java b/geode-core/src/main/java/org/apache/geode/LicenseException.java
index f41db3a..96f07af 100644
--- a/geode-core/src/main/java/org/apache/geode/LicenseException.java
+++ b/geode-core/src/main/java/org/apache/geode/LicenseException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>LicenseException</code> is thrown when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/LogWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/LogWriter.java b/geode-core/src/main/java/org/apache/geode/LogWriter.java
index 648b9fa..17e23e0 100644
--- a/geode-core/src/main/java/org/apache/geode/LogWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/LogWriter.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 import java.util.logging.Handler;
 
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.i18n.LogWriterI18n;
 
 /**
   * Defines methods available to clients that want to write a log message

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/NoSystemException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/NoSystemException.java b/geode-core/src/main/java/org/apache/geode/NoSystemException.java
index 8490d1a..215e157 100644
--- a/geode-core/src/main/java/org/apache/geode/NoSystemException.java
+++ b/geode-core/src/main/java/org/apache/geode/NoSystemException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>NoSystemException</code> is thrown when a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/OutOfOffHeapMemoryException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/OutOfOffHeapMemoryException.java b/geode-core/src/main/java/org/apache/geode/OutOfOffHeapMemoryException.java
index 25d4b16..2dc105c 100755
--- a/geode-core/src/main/java/org/apache/geode/OutOfOffHeapMemoryException.java
+++ b/geode-core/src/main/java/org/apache/geode/OutOfOffHeapMemoryException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * Indicates that attempts to allocate more objects in off-heap memory has

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/SerializationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/SerializationException.java b/geode-core/src/main/java/org/apache/geode/SerializationException.java
index cfcbae3..592ff38 100644
--- a/geode-core/src/main/java/org/apache/geode/SerializationException.java
+++ b/geode-core/src/main/java/org/apache/geode/SerializationException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-import com.gemstone.gemfire.GemFireIOException;
+import org.apache.geode.GemFireIOException;
 
 /**
  * An exception indicating that a serialization or deserialization failed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/StatisticDescriptor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/StatisticDescriptor.java b/geode-core/src/main/java/org/apache/geode/StatisticDescriptor.java
index e812cec..010565c 100644
--- a/geode-core/src/main/java/org/apache/geode/StatisticDescriptor.java
+++ b/geode-core/src/main/java/org/apache/geode/StatisticDescriptor.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-//import com.gemstone.gemfire.internal.Assert;
-//import com.gemstone.gemfire.internal.FieldInfo;
+//import org.apache.geode.internal.Assert;
+//import org.apache.geode.internal.FieldInfo;
 
 /**
  * Describes an individual statistic whose value is updated by an

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/Statistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/Statistics.java b/geode-core/src/main/java/org/apache/geode/Statistics.java
index 17b5bc0..b8ffc06 100644
--- a/geode-core/src/main/java/org/apache/geode/Statistics.java
+++ b/geode-core/src/main/java/org/apache/geode/Statistics.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-//import com.gemstone.gemfire.distributed.DistributedSystem;
+//import org.apache.geode.distributed.DistributedSystem;
 
 import java.util.function.DoubleSupplier;
 import java.util.function.IntSupplier;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/StatisticsFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/StatisticsFactory.java b/geode-core/src/main/java/org/apache/geode/StatisticsFactory.java
index 3ba1665..4fe13ee 100644
--- a/geode-core/src/main/java/org/apache/geode/StatisticsFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/StatisticsFactory.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-//import com.gemstone.gemfire.distributed.DistributedSystem;
-//import com.gemstone.gemfire.internal.statistics.StatArchiveFormat;
+//import org.apache.geode.distributed.DistributedSystem;
+//import org.apache.geode.internal.statistics.StatArchiveFormat;
 //import java.io.IOException;
 //import java.io.Reader;
 
@@ -27,7 +27,7 @@ package com.gemstone.gemfire;
  * It can also be used to create instances of {@link StatisticDescriptor}
  * and {@link StatisticsType} because it implements {@link StatisticsTypeFactory}.
  * {@link
- * com.gemstone.gemfire.distributed.DistributedSystem} is the only
+ * org.apache.geode.distributed.DistributedSystem} is the only
  * instance of this interface.
  *
  * <P>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/StatisticsType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/StatisticsType.java b/geode-core/src/main/java/org/apache/geode/StatisticsType.java
index a24e0e5..c799cb5 100644
--- a/geode-core/src/main/java/org/apache/geode/StatisticsType.java
+++ b/geode-core/src/main/java/org/apache/geode/StatisticsType.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-//import com.gemstone.gemfire.internal.Assert;
+//import org.apache.geode.internal.Assert;
 //import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/StatisticsTypeFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/StatisticsTypeFactory.java b/geode-core/src/main/java/org/apache/geode/StatisticsTypeFactory.java
index 4569b7e..e35725c 100644
--- a/geode-core/src/main/java/org/apache/geode/StatisticsTypeFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/StatisticsTypeFactory.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-//import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.statistics.StatArchiveFormat;
+//import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.statistics.StatArchiveFormat;
 import java.io.IOException;
 import java.io.Reader;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/SystemConnectException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/SystemConnectException.java b/geode-core/src/main/java/org/apache/geode/SystemConnectException.java
index 01636d3..ed41798 100644
--- a/geode-core/src/main/java/org/apache/geode/SystemConnectException.java
+++ b/geode-core/src/main/java/org/apache/geode/SystemConnectException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>SystemConnectException</code> is thrown when a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/SystemFailure.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/SystemFailure.java b/geode-core/src/main/java/org/apache/geode/SystemFailure.java
index 61d73af..8acf473 100644
--- a/geode-core/src/main/java/org/apache/geode/SystemFailure.java
+++ b/geode-core/src/main/java/org/apache/geode/SystemFailure.java
@@ -17,13 +17,13 @@
 /**
  * 
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.SystemFailureTestHook;
-import com.gemstone.gemfire.internal.admin.remote.RemoteGfManagerAgent;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.SystemFailureTestHook;
+import org.apache.geode.internal.admin.remote.RemoteGfManagerAgent;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Catches and responds to JVM failure
@@ -135,7 +135,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  * returns a non-null result).  
  * <p>
  * A job processing loop is a good candidate, for
- * instance, in com.gemstone.org.jgroups.protocols.UDP#run(), 
+ * instance, in org.apache.org.jgroups.protocols.UDP#run(), 
  * which implements {@link Thread#run}:
  * <p>
  * <pre>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/SystemIsRunningException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/SystemIsRunningException.java b/geode-core/src/main/java/org/apache/geode/SystemIsRunningException.java
index e96ddf4..06dd0c7 100644
--- a/geode-core/src/main/java/org/apache/geode/SystemIsRunningException.java
+++ b/geode-core/src/main/java/org/apache/geode/SystemIsRunningException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>SystemIsRunningException</code> is thrown when an operation

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/ThreadInterruptedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/ThreadInterruptedException.java b/geode-core/src/main/java/org/apache/geode/ThreadInterruptedException.java
index 6c459d3..373cead 100644
--- a/geode-core/src/main/java/org/apache/geode/ThreadInterruptedException.java
+++ b/geode-core/src/main/java/org/apache/geode/ThreadInterruptedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * @deprecated this class is no longer used

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/ToDataException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/ToDataException.java b/geode-core/src/main/java/org/apache/geode/ToDataException.java
index e131596..e602f3c 100644
--- a/geode-core/src/main/java/org/apache/geode/ToDataException.java
+++ b/geode-core/src/main/java/org/apache/geode/ToDataException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>ToDataException</code> is thrown during serialization if

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/UncreatedSystemException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/UncreatedSystemException.java b/geode-core/src/main/java/org/apache/geode/UncreatedSystemException.java
index 4552b86..685e8fc 100644
--- a/geode-core/src/main/java/org/apache/geode/UncreatedSystemException.java
+++ b/geode-core/src/main/java/org/apache/geode/UncreatedSystemException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>UncreatedSystemException</code> is thrown when the specified

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/UnmodifiableException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/UnmodifiableException.java b/geode-core/src/main/java/org/apache/geode/UnmodifiableException.java
index 3a79c3c..640629c 100644
--- a/geode-core/src/main/java/org/apache/geode/UnmodifiableException.java
+++ b/geode-core/src/main/java/org/apache/geode/UnmodifiableException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * A <code>UnmodifiableException</code> is thrown when a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/UnstartedSystemException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/UnstartedSystemException.java b/geode-core/src/main/java/org/apache/geode/UnstartedSystemException.java
index 6a10f08..c390089 100644
--- a/geode-core/src/main/java/org/apache/geode/UnstartedSystemException.java
+++ b/geode-core/src/main/java/org/apache/geode/UnstartedSystemException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire;
+package org.apache.geode;
 
 /**
  * An <code>UnstartedSystemException</code> is thrown when the specified

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AdminConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AdminConfig.java b/geode-core/src/main/java/org/apache/geode/admin/AdminConfig.java
index fd54b2e..ec5ed73 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AdminConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AdminConfig.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.BufferedReader;
 import java.io.File;
@@ -40,7 +40,7 @@ import java.util.Date;
  * running
  * <li> Port=The port you are using to open the monitor port for
  * the instance
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AdminConfig
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystem.java b/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystem.java
index 3cc8926..982c4f1 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystem.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystem.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -30,14 +30,14 @@ import java.util.UUID;
 /**
  * Administrative interface for managing an entire GemFire distributed
  * system.  This interface should not be confused with {@link
- * com.gemstone.gemfire.distributed.DistributedSystem
+ * org.apache.geode.distributed.DistributedSystem
  * DistributedSystem} that represents a connection to a GemFire
  * distributed system.
  *
  * @see AdminDistributedSystemFactory
  *
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface AdminDistributedSystem {
 	
@@ -50,7 +50,7 @@ public interface AdminDistributedSystem {
    * Retrieves display friendly name for this system.  If this administrative
    * VM defined an optional name for its connection to the distributed system,
    * that name will be returned.  Otherwise the returned value will be {@link
-   * com.gemstone.gemfire.admin.AdminDistributedSystem#getId}.
+   * org.apache.geode.admin.AdminDistributedSystem#getId}.
    */
   public String getName();
   
@@ -201,7 +201,7 @@ public interface AdminDistributedSystem {
    * {@linkplain #getCacheVms cache server vms}.
    */
   public SystemMember[] getSystemMemberApplications() 
-  throws com.gemstone.gemfire.admin.AdminException;
+  throws org.apache.geode.admin.AdminException;
 
   /**
    * Display in readable format the latest Alert in this distributed system.
@@ -345,7 +345,7 @@ public interface AdminDistributedSystem {
 
   /**
    * Returns the administrative SystemMember specified by the {@link
-   * com.gemstone.gemfire.distributed.DistributedMember}.
+   * org.apache.geode.distributed.DistributedMember}.
    *
    * @param distributedMember the distributed member to lookup
    * @return administrative SystemMember for that distributed member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystemFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystemFactory.java b/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystemFactory.java
index 49917b6..6f2af1f 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystemFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AdminDistributedSystemFactory.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.admin.internal.DistributedSystemConfigImpl;
-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.InternalDistributedSystem;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LocalLogWriter;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.admin.internal.DistributedSystemConfigImpl;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LocalLogWriter;
 
 import java.util.Properties;
 
@@ -32,7 +32,7 @@ import java.util.Properties;
  * Factory for creating GemFire administration entities. 
  *
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AdminDistributedSystemFactory {
   
@@ -84,8 +84,8 @@ public class AdminDistributedSystemFactory {
    * before {@link DistributedSystem#connect} is when creating a colocated distributed system.
    * <p>
    * Once it has been enabled be careful to only use GemFire APIs from the
-   * <code>com.gemstone.gemfire.admin</code> package. In particular do not create
-   * a {@link com.gemstone.gemfire.cache.Cache} or a normal {@link DistributedSystem}.
+   * <code>org.apache.geode.admin</code> package. In particular do not create
+   * a {@link org.apache.geode.cache.Cache} or a normal {@link DistributedSystem}.
    * @param adminOnly <code>true</code> if this VM should be limited to administration APIs;
    *  <code>false</code> if this VM should allow all GemFire APIs.
    * @throws IllegalStateException if a {@link DistributedSystem}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AdminException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AdminException.java b/geode-core/src/main/java/org/apache/geode/admin/AdminException.java
index cc15b4f..e7d574d 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AdminException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AdminException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * An <code>AdminException</code> is thrown when administration or monitoring
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.GemFireCheckedException;
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AdminException extends GemFireCheckedException {
 private static final long serialVersionUID = 879398950879472021L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AdminXmlException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AdminXmlException.java b/geode-core/src/main/java/org/apache/geode/admin/AdminXmlException.java
index 672c494..e465ddc 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/AdminXmlException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AdminXmlException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Thrown when a problem is encountered while working with
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.admin;
  * @see DistributedSystemConfig#getEntityConfigXMLFile
  *
  * @since GemFire 4.0
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AdminXmlException extends RuntimeAdminException {
   private static final long serialVersionUID = -6848726449157550169L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/Alert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/Alert.java b/geode-core/src/main/java/org/apache/geode/admin/Alert.java
index cf163a2..9519cba 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/Alert.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/Alert.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * An administration alert that is issued by a member of a GemFire
  * distributed system.  It is similar to a {@linkplain
- * com.gemstone.gemfire.i18n.LogWriterI18n log message}.
+ * org.apache.geode.i18n.LogWriterI18n log message}.
  *
  * @see       AlertListener
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface Alert {
   
@@ -38,7 +38,7 @@ public interface Alert {
 
   /** 
    * The name of the {@linkplain
-   * com.gemstone.gemfire.distributed.DistributedSystem#getName
+   * org.apache.geode.distributed.DistributedSystem#getName
    * distributed system}) through which the alert was issued.
    */
   public String getConnectionName();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java b/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
index fb4271d..0791a5f 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AlertLevel.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.admin.Alert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
- * Type-safe enumeration for {@link com.gemstone.gemfire.admin.Alert
+ * Type-safe enumeration for {@link org.apache.geode.admin.Alert
  * Alert} level.
  *
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class AlertLevel implements java.io.Serializable {
   private static final long serialVersionUID = -4752438966587392126L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/AlertListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/AlertListener.java b/geode-core/src/main/java/org/apache/geode/admin/AlertListener.java
index a19f93d..f217817 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/AlertListener.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/AlertListener.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A listener whose callback methods are invoked when an {@link Alert}
  * is received.
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface AlertListener extends java.util.EventListener {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/BackupStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/BackupStatus.java b/geode-core/src/main/java/org/apache/geode/admin/BackupStatus.java
index 6cd7fa4..802d37e 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/BackupStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/BackupStatus.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * The status of a backup operation, returned by
  * {@link AdminDistributedSystem#backupAllMembers(java.io.File,java.io.File)}.
  * 
  * @since GemFire 6.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface BackupStatus {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheDoesNotExistException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheDoesNotExistException.java b/geode-core/src/main/java/org/apache/geode/admin/CacheDoesNotExistException.java
index 8964d79..ac43c1f 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheDoesNotExistException.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheDoesNotExistException.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * An <code>CacheDoesNotExistException</code> is thrown when an attempt
  * is made to get a cache and one does not exist.
  *
  * @since GemFire     3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public class CacheDoesNotExistException extends AdminException {
 private static final long serialVersionUID = -1639933911265729978L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheHealthConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheHealthConfig.java b/geode-core/src/main/java/org/apache/geode/admin/CacheHealthConfig.java
index 11899b1..f2aeb6d 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheHealthConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheHealthConfig.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Provides configuration information relating to the health of a
  * member of a GemFire distributed system that hosts a GemFire {@link
- * com.gemstone.gemfire.cache.Cache Cache}.
+ * org.apache.geode.cache.Cache Cache}.
  *
  * <P>
  *
@@ -40,7 +40,7 @@ package com.gemstone.gemfire.admin;
  * <LI>The number of entries in the Cache {@link #getMaxEventQueueSize
  * event delivery queue} is too large.</LI>
  * 
- * <LI>If one of the regions is configured with {@link com.gemstone.gemfire.cache.LossAction#FULL_ACCESS FULL_ACCESS}
+ * <LI>If one of the regions is configured with {@link org.apache.geode.cache.LossAction#FULL_ACCESS FULL_ACCESS}
  * on role loss.</LI>
  *
  * </UL>
@@ -50,10 +50,10 @@ package com.gemstone.gemfire.admin;
  * 
  * <UL>
  * 
- * <LI>If one of the regions is configured with {@link com.gemstone.gemfire.cache.LossAction#NO_ACCESS NO_ACCESS}
+ * <LI>If one of the regions is configured with {@link org.apache.geode.cache.LossAction#NO_ACCESS NO_ACCESS}
  * on role loss.</LI> 
  * 
- * <LI>If one of the regions is configured with {@link com.gemstone.gemfire.cache.LossAction#LIMITED_ACCESS LIMITED_ACCESS}
+ * <LI>If one of the regions is configured with {@link org.apache.geode.cache.LossAction#LIMITED_ACCESS LIMITED_ACCESS}
  * on role loss.</LI> 
  * 
  * </UL>
@@ -64,7 +64,7 @@ package com.gemstone.gemfire.admin;
  *
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  * */
 public interface CacheHealthConfig {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheServer.java b/geode-core/src/main/java/org/apache/geode/admin/CacheServer.java
index e94402d..0149a05 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheServer.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheServer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A dedicated cache server VM that is managed by the administration

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheServerConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheServerConfig.java b/geode-core/src/main/java/org/apache/geode/admin/CacheServerConfig.java
index 16a402c..fc4ce0f 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheServerConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheServerConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Configuration for a GemFire cache server that is managed by the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheVm.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheVm.java b/geode-core/src/main/java/org/apache/geode/admin/CacheVm.java
index 6d7e482..5bfeddc 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheVm.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheVm.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * A dedicated cache server VM that is managed by the administration
  * API.
  * <p>Note that this may not represent an instance of
- * {@link com.gemstone.gemfire.cache.server.CacheServer}. It is possible for
+ * {@link org.apache.geode.cache.server.CacheServer}. It is possible for
  * a cache VM to be started but for it not to listen for client connections
  * in which case it is not a 
- * {@link com.gemstone.gemfire.cache.server.CacheServer}
+ * {@link org.apache.geode.cache.server.CacheServer}
  * but is an instance of this interface.
  *
  * @since GemFire 5.7
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface CacheVm extends SystemMember, ManagedEntity {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/CacheVmConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/CacheVmConfig.java b/geode-core/src/main/java/org/apache/geode/admin/CacheVmConfig.java
index e5d22de..e7068bc 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/CacheVmConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/CacheVmConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Configuration for a GemFire cache server VM that is managed by the
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.admin;
  * @see AdminDistributedSystem#addCacheVm()
  *
  * @since GemFire 5.7
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface CacheVmConfig extends ManagedEntityConfig {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/ConfigurationParameter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/ConfigurationParameter.java b/geode-core/src/main/java/org/apache/geode/admin/ConfigurationParameter.java
index dd62026..ff9b613 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/ConfigurationParameter.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/ConfigurationParameter.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
 * A single configuration parameter of a {@link SystemMember}.
  *
  * @since GemFire     3.5
  *
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface ConfigurationParameter {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemConfig.java b/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemConfig.java
index 5ef389f..a5b0342 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemConfig.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
-import com.gemstone.gemfire.admin.internal.InetAddressUtil;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.admin.internal.InetAddressUtil;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 
 /**
@@ -37,7 +37,7 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
  *
  * Detailed descriptions of many of these configuration attributes can
  * be found in the {@link
- * com.gemstone.gemfire.distributed.DistributedSystem
+ * org.apache.geode.distributed.DistributedSystem
  * DistributedSystem} class.  Note that the default values of these
  * configuration attributes can be specified using Java system
  * properties.
@@ -57,7 +57,7 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
  * the {@link #clone} method.
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
 */
 public interface DistributedSystemConfig extends Cloneable {
 
@@ -295,7 +295,7 @@ public interface DistributedSystemConfig extends Cloneable {
 
   /**
    * Returns the name of the XML file that specifies the configuration
-   * of the {@linkplain com.gemstone.gemfire.admin.ManagedEntity
+   * of the {@linkplain org.apache.geode.admin.ManagedEntity
    * managed entities} administered by the
    * <code>DistributedSystem</code>.  The XML file must conform to a
    * <a href="doc-files/ds5_0.dtd">dtd</a>.
@@ -511,7 +511,7 @@ public interface DistributedSystemConfig extends Cloneable {
    * Returns the name of the log file to which informational messages
    * are written.
    *
-   * @see com.gemstone.gemfire.i18n.LogWriterI18n
+   * @see org.apache.geode.i18n.LogWriterI18n
    */
   public String getLogFile();
 
@@ -519,7 +519,7 @@ public interface DistributedSystemConfig extends Cloneable {
    * Sets the name of the log file to which informational messages
    * are written.
    *
-   * @see com.gemstone.gemfire.i18n.LogWriterI18n
+   * @see org.apache.geode.i18n.LogWriterI18n
    */
   public void setLogFile(String logFile);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemHealthConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemHealthConfig.java b/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemHealthConfig.java
index 5ece6cd..d9416ce 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemHealthConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/DistributedSystemHealthConfig.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Provides configuration information relating to the health of an
@@ -48,7 +48,7 @@ package com.gemstone.gemfire.admin;
  *
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  * */
 public interface DistributedSystemHealthConfig {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/admin/DistributionLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/DistributionLocator.java b/geode-core/src/main/java/org/apache/geode/admin/DistributionLocator.java
index 541a3e2..da8864c 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/DistributionLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/DistributionLocator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.admin;
+package org.apache.geode.admin;
 
 /**
  * Represents a single distribution locator server, of which a
@@ -26,7 +26,7 @@ package com.gemstone.gemfire.admin;
  * @see DistributionLocatorConfig
  *
  * @since GemFire 3.5
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
+ * @deprecated as of 7.0 use the <code><a href="{@docRoot}/org/apache/geode/management/package-summary.html">management</a></code> package instead
  */
 public interface DistributionLocator extends ManagedEntity {
   



[05/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey1.java
index 6761aa0..3b58c7a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey1.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey2.java
index 4948373..e2da09b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapStringKey2.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapUUIDKey.java
index 98db26c..e8bb0f3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapUUIDKey.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntry.java
index 76be874..3d64421 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeap.java
index eb4955f..6837d02 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapIntKey.java
index 5a00707..4c3b17f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapIntKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapLongKey.java
index 0c3d112..9fa0ec8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapLongKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapObjectKey.java
index 82796d8..2a65614 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapObjectKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey1.java
index ced02db..e1fa0da 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey1.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey2.java
index 75090a1..463c3c7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapStringKey2.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapUUIDKey.java
index 0423cfa..683b9c5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryHeapUUIDKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeap.java
index 6a02e94..3ef11ba 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapIntKey.java
index 6771cfa..75527a2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapIntKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapLongKey.java
index 3a60770..4e0d84d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapLongKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapObjectKey.java
index 46dac77..556dc35 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapObjectKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey1.java
index af1ca29..fa0e2c1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey1.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey2.java
index 3b582bf..ec817bd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapStringKey2.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapUUIDKey.java
index 00b3014..03fb158 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskRegionEntryOffHeapUUIDKey.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntry.java
index dd9239e..062e1e7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntry.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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 org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeap.java
index cebc28a..bc7b32e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapIntKey.java
index 28e0fec..e388fd3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapIntKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapLongKey.java
index 447379f..cb73848 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapLongKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapObjectKey.java
index b8000ae..862ab77 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapObjectKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey1.java
index e7df382..9d2557f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey1.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey2.java
index f5a5884..04ecfe5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapStringKey2.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapUUIDKey.java
index 932faf1..1bed6ab 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryHeapUUIDKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeap.java
index 6963620..9f29bbb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapIntKey.java
index ccaab68..9834662 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapIntKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapLongKey.java
index f5a0c23..1168713 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapLongKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapObjectKey.java
index 0e12075..be2f617 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapObjectKey.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey1.java
index e031ae8..5d43e59 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey1.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey2.java
index 52d14f7..669a327 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapStringKey2.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapUUIDKey.java
index c320869..06aab18 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinLRURegionEntryOffHeapUUIDKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntry.java
index 47aad77..b98ed19 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeap.java
index 1da7d30..cd5dd32 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapIntKey.java
index 4b51769..c4d5f5b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapIntKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapLongKey.java
index 160532f..db200af 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapLongKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapObjectKey.java
index 85697cc..c5edf08 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapObjectKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey1.java
index 9926071..c8f526b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey1.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey2.java
index fd7e9e6..ea07c5b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapStringKey2.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU



[61/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/controllers/PulseControllerJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/controllers/PulseControllerJUnitTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/controllers/PulseControllerJUnitTest.java
deleted file mode 100644
index 06d7f3d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/controllers/PulseControllerJUnitTest.java
+++ /dev/null
@@ -1,816 +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 com.vmware.geode.tools.pulse.controllers;
-
-import static org.hamcrest.Matchers.contains;
-import static org.hamcrest.Matchers.*;
-import static org.junit.Assert.*;
-import static org.mockito.Matchers.anyInt;
-import static org.mockito.Matchers.anyString;
-import static org.mockito.Mockito.doReturn;
-import static org.powermock.api.mockito.PowerMockito.spy;
-import static org.powermock.api.mockito.PowerMockito.when;
-import static org.springframework.test.web.servlet.request.MockMvcRequestBuilders.*;
-import static org.springframework.test.web.servlet.result.MockMvcResultMatchers.*;
-
-import java.io.File;
-import java.security.Principal;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.UUID;
-import javax.servlet.ServletContextListener;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.vmware.geode.tools.pulse.internal.PulseAppListener;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import org.apache.geode.test.junit.categories.UnitTest;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConfig;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-
-import org.apache.commons.collections.buffer.CircularFifoBuffer;
-import org.junit.Before;
-import org.junit.Rule;
-import org.junit.Test;
-import org.junit.experimental.categories.Category;
-import org.junit.rules.TemporaryFolder;
-import org.junit.runner.RunWith;
-import org.mockito.Mockito;
-import org.powermock.core.classloader.annotations.PowerMockIgnore;
-import org.powermock.core.classloader.annotations.PrepareForTest;
-import org.powermock.modules.junit4.PowerMockRunner;
-import org.powermock.modules.junit4.PowerMockRunnerDelegate;
-import org.springframework.beans.factory.annotation.Autowired;
-import org.springframework.http.MediaType;
-import org.springframework.test.context.ContextConfiguration;
-import org.springframework.test.context.junit4.SpringJUnit4ClassRunner;
-import org.springframework.test.context.web.WebAppConfiguration;
-import org.springframework.test.web.servlet.MockMvc;
-import org.springframework.test.web.servlet.setup.MockMvcBuilders;
-import org.springframework.web.context.WebApplicationContext;
-
-import org.apache.geode.test.junit.categories.IntegrationTest;
-
-@Category(IntegrationTest.class)
-@PrepareForTest(Repository.class)
-@RunWith(PowerMockRunner.class)
-@PowerMockRunnerDelegate(SpringJUnit4ClassRunner.class)
-@WebAppConfiguration
-@ContextConfiguration("classpath*:mvc-dispatcher-servlet.xml")
-@PowerMockIgnore("*.IntegrationTest")
-public class PulseControllerJUnitTest {
-
-  private static final String PRINCIPAL_USER = "test-user";
-
-  private static final String MEMBER_ID = "member1";
-  private static final String MEMBER_NAME = "localhost-server";
-  private static final String CLUSTER_NAME = "mock-cluster";
-  private static final String REGION_NAME = "mock-region";
-  private static final String REGION_PATH = "/" + REGION_NAME;
-  private static final String REGION_TYPE = "PARTITION";
-  private static final String AEQ_LISTENER = "async-event-listener";
-  private static final String CLIENT_NAME = "client-1";
-  private static final String PHYSICAL_HOST_NAME = "physical-host-1";
-  private static final String GEMFIRE_VERSION = "1.0.0";
-
-  private static final Principal principal;
-
-  static {
-    principal = () -> PRINCIPAL_USER;
-  }
-
-  @Rule
-  public TemporaryFolder tempFolder = new TemporaryFolder();
-
-  @Autowired
-  private WebApplicationContext wac;
-
-  private MockMvc mockMvc;
-
-  private Cluster cluster;
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  @Before
-  public void setup() throws Exception {
-    this.mockMvc = MockMvcBuilders.webAppContextSetup(this.wac).build();
-
-
-    cluster = Mockito.spy(Cluster.class);
-
-    Cluster.Region region = new Cluster.Region();
-    region.setName(REGION_NAME);
-    region.setFullPath(REGION_PATH);
-    region.setRegionType(REGION_TYPE);
-    region.setMemberCount(1);
-    region.setMemberName(new ArrayList<String>() {{
-      add(MEMBER_NAME);
-    }});
-    region.setPutsRate(12.31D);
-    region.setGetsRate(27.99D);
-    Cluster.RegionOnMember regionOnMember = new Cluster.RegionOnMember();
-    regionOnMember.setRegionFullPath(REGION_PATH);
-    regionOnMember.setMemberName(MEMBER_NAME);
-    region.setRegionOnMembers(new ArrayList<Cluster.RegionOnMember>() {{
-      add(regionOnMember);
-    }});
-    cluster.addClusterRegion(REGION_PATH, region);
-
-    Cluster.Member member = new Cluster.Member();
-    member.setId(MEMBER_ID);
-    member.setName(MEMBER_NAME);
-    member.setUptime(1L);
-    member.setHost(PHYSICAL_HOST_NAME);
-    member.setGemfireVersion(GEMFIRE_VERSION);
-    member.setCpuUsage(55.77123D);
-
-    member.setMemberRegions(new HashMap<String, Cluster.Region>() {{
-      put(REGION_NAME, region);
-    }});
-
-    Cluster.AsyncEventQueue aeq = new Cluster.AsyncEventQueue();
-    aeq.setAsyncEventListener(AEQ_LISTENER);
-    member.setAsyncEventQueueList(new ArrayList() {{
-      add(aeq);
-    }});
-
-    Cluster.Client client = new Cluster.Client();
-    client.setId("100");
-    client.setName(CLIENT_NAME);
-    client.setUptime(1L);
-    member.setMemberClientsHMap(new HashMap<String, Cluster.Client>() {{
-      put(CLIENT_NAME, client);
-    }});
-
-    cluster.setMembersHMap(new HashMap() {{
-      put(MEMBER_NAME, member);
-    }});
-    cluster.setPhysicalToMember(new HashMap() {{
-      put(PHYSICAL_HOST_NAME, new ArrayList() {{
-        add(member);
-      }});
-    }});
-    cluster.setServerName(CLUSTER_NAME);
-    cluster.setMemoryUsageTrend(new CircularFifoBuffer() {{
-      add(1);
-      add(2);
-      add(3);
-    }});
-    cluster.setWritePerSecTrend(new CircularFifoBuffer() {{
-      add(1.29);
-      add(2.3);
-      add(3.0);
-    }});
-    cluster.setThroughoutReadsTrend(new CircularFifoBuffer() {{
-      add(1);
-      add(2);
-      add(3);
-    }});
-    cluster.setThroughoutWritesTrend(new CircularFifoBuffer() {{
-      add(4);
-      add(5);
-      add(6);
-    }});
-
-    Repository repo = Mockito.spy(Repository.class);
-
-    // Set up a partial mock for some static methods
-    spy(Repository.class);
-    when(Repository.class, "get").thenReturn(repo);
-    doReturn(cluster).when(repo).getCluster();
-
-    PulseConfig config = new PulseConfig();
-    File tempQueryLog = tempFolder.newFile("query_history.log");
-    config.setQueryHistoryFileName(tempQueryLog.toString());
-    doReturn(config).when(repo).getPulseConfig();
-
-    PulseController.pulseVersion.setPulseVersion("not empty");
-    PulseController.pulseVersion.setPulseBuildId("not empty");
-    PulseController.pulseVersion.setPulseBuildDate("not empty");
-    PulseController.pulseVersion.setPulseSourceDate("not empty");
-    PulseController.pulseVersion.setPulseSourceRevision("not empty");
-    PulseController.pulseVersion.setPulseSourceRepository("not empty");
-  }
-
-  @Test
-  public void pulseUpdateForClusterDetails() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterDetails\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterDetails.userName").value(PRINCIPAL_USER))
-        .andExpect(jsonPath("$.ClusterDetails.totalHeap").value(0D))
-        .andExpect(jsonPath("$.ClusterDetails.clusterName").value(CLUSTER_NAME))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterDiskThroughput() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterDiskThroughput\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterDiskThroughput.currentThroughputWrites").value(0D))
-        .andExpect(jsonPath("$.ClusterDiskThroughput.throughputReads", contains(1, 2, 3)))
-        .andExpect(jsonPath("$.ClusterDiskThroughput.currentThroughputReads").value(0D))
-        .andExpect(jsonPath("$.ClusterDiskThroughput.throughputWrites", contains(4, 5, 6)))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterGCPauses() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterJVMPauses\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterJVMPauses.currentGCPauses").value(0))
-        .andExpect(jsonPath("$.ClusterJVMPauses.gCPausesTrend").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterKeyStatistics() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterKeyStatistics\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterKeyStatistics.readPerSecTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterKeyStatistics.queriesPerSecTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterKeyStatistics.writePerSecTrend", contains(1.29, 2.3, 3.0)))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterMember() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterMembers\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterMembers.members[0].serverGroups[0]").value("Default"))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].cpuUsage").value(55.77D))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].clients").value(1))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].heapUsage").value(0))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].currentHeapUsage").value(0))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].isManager").value(false))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].threads").value(0))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].memberId").value(MEMBER_ID))
-        .andExpect(jsonPath("$.ClusterMembers.members[0].redundancyZones[0]").value("Default"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterMembersRGraph() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterMembersRGraph\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterMembersRGraph.memberCount").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.data").isEmpty())
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.name").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.id").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].id").value(PHYSICAL_HOST_NAME))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].name").value(PHYSICAL_HOST_NAME))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.loadAvg").value(0D))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.sockets").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.threads").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.cpuUsage").value(0D))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.memoryUsage").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.hostStatus").value("Normal"))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].data.$type").value("hostNormalNode"))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].id").value(MEMBER_ID))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gemfireVersion").value(GEMFIRE_VERSION))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.memoryUsage").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.cpuUsage").value(55.77D))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.regions").value(1))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.host").value(PHYSICAL_HOST_NAME))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.port").value("-"))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.clients").value(1))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gcPauses").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.numThreads").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.nodeType").value("memberNormalNode"))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.$type").value("memberNormalNode"))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gatewaySender").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].data.gatewayReceiver").value(0))
-        .andExpect(jsonPath("$.ClusterMembersRGraph.clustor.children[0].children[0].children").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterMemoryUsage() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterMemoryUsage\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterMemoryUsage.currentMemoryUsage").value(0))
-        .andExpect(jsonPath("$.ClusterMemoryUsage.memoryUsageTrend", containsInAnyOrder(1, 2, 3)))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterRegion() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterRegion\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterRegion.clusterName").value(CLUSTER_NAME))
-        .andExpect(jsonPath("$.ClusterRegion.userName").value(PRINCIPAL_USER))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].regionPath").value(REGION_PATH))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].diskReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryUsage").value("0.0000"))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].getsRate").value(27.99D))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].wanEnabled").value(false))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memberCount").value(1))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memberNames[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memberNames[0].id").value(MEMBER_ID))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].emptyNodes").value(0))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].type").value(REGION_TYPE))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].isEnableOffHeapMemory").value("OFF"))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].putsRate").value(12.31D))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].totalMemory").value(0))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].entryCount").value(0))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].compressionCodec").value("NA"))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].name").value(REGION_NAME))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].systemRegionEntryCount").value(0))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].persistence").value("OFF"))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegion.region[0].diskWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegion.region[0].memoryWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegion.region[0].dataUsage").value(0))
-        .andExpect(jsonPath("$.ClusterRegion.region[0].entrySize").value("0.0000"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterRegions() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterRegions\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].regionPath").value(REGION_PATH))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].diskReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryUsage").value("0.0000"))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].getsRate").value(27.99D))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].wanEnabled").value(false))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberCount").value(1))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberNames[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memberNames[0].id").value(MEMBER_ID))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].emptyNodes").value(0))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].type").value(REGION_TYPE))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].isEnableOffHeapMemory").value("OFF"))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].putsRate").value(12.31D))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].totalMemory").value(0))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].entryCount").value(0))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].compressionCodec").value("NA"))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].name").value(REGION_NAME))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].systemRegionEntryCount").value(0))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].persistence").value("OFF"))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].diskWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].memoryWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].dataUsage").value(0))
-        .andExpect(jsonPath("$.ClusterRegions.regions[0].entrySize").value("0.0000"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterSelectedRegion() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterSelectedRegion\":{\"regionFullPath\":\"" + REGION_PATH + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.lruEvictionRate").value(0D))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.getsRate").value(27.99D))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.emptyNodes").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.type").value(REGION_TYPE))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.isEnableOffHeapMemory").value("OFF"))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.path").value(REGION_PATH))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].cpuUsage").value(55.77D))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].clients").value(1))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].heapUsage").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].currentHeapUsage").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].isManager").value(false))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].threads").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].memberId").value(MEMBER_ID))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.members[0].uptime").value("0 Hours 0 Mins 1 Secs"))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.diskWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.dataUsage").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.regionPath").value(REGION_PATH))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.diskReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryUsage").value("0.0000"))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.wanEnabled").value(false))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memberCount").value(1))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.putsRate").value(12.31D))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.totalMemory").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.entryCount").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.compressionCodec").value("NA"))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.name").value(REGION_NAME))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.systemRegionEntryCount").value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.persistence").value("OFF"))
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.memoryWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegion.selectedRegion.entrySize").value("0.0000"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterSelectedRegionsMember() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterSelectedRegionsMember\":{\"regionFullPath\":\"" + REGION_PATH + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.diskReadsTrend", MEMBER_NAME).isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.regionFullPath", MEMBER_NAME).value(REGION_PATH))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.entryCount", MEMBER_NAME).value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.accessor", MEMBER_NAME).value("True"))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memberName", MEMBER_NAME).value(MEMBER_NAME))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memoryReadsTrend", MEMBER_NAME).isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.diskWritesTrend", MEMBER_NAME).isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.memoryWritesTrend", MEMBER_NAME).isEmpty())
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.selectedRegionsMembers.%s.entrySize", MEMBER_NAME).value(0))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.clusterName").value(CLUSTER_NAME))
-        .andExpect(jsonPath("$.ClusterSelectedRegionsMember.userName").value(PRINCIPAL_USER))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForClusterWANInfo() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"ClusterWANInfo\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.ClusterWANInfo.connectedClusters").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberAsynchEventQueues() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberAsynchEventQueues\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.isAsyncEventQueuesPresent").value(true))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchTimeInterval").value(0))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchConflationEnabled").value(false))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].queueSize").value(0))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].senderType").value(false))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].asyncEventListener").value(AEQ_LISTENER))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].batchSize").value(0))
-        .andExpect(jsonPath("$.MemberAsynchEventQueues.asyncEventQueues[0].primary").value(false))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberClients() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberClients\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberClients.name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].puts").value(0))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].cpuUsage").value("0.0000"))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].clientId").value("100"))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].queueSize").value(0))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].clientCQCount").value(0))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].name").value(CLIENT_NAME))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].isConnected").value("No"))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].threads").value(0))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].isSubscriptionEnabled").value("No"))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].gets").value(0))
-        .andExpect(jsonPath("$.MemberClients.memberClients[0].uptime").value("0 Hours 0 Mins 1 Secs"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberDetails() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberDetails\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberDetails.name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.MemberDetails.offHeapUsedSize").value(0))
-        .andExpect(jsonPath("$.MemberDetails.diskStorageUsed").value(0D))
-        .andExpect(jsonPath("$.MemberDetails.regionsCount").value(1))
-        .andExpect(jsonPath("$.MemberDetails.clusterName").value(CLUSTER_NAME))
-        .andExpect(jsonPath("$.MemberDetails.name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.MemberDetails.threads").value(0))
-        .andExpect(jsonPath("$.MemberDetails.clusterId").isNotEmpty())
-        .andExpect(jsonPath("$.MemberDetails.numClients").value(1))
-        .andExpect(jsonPath("$.MemberDetails.userName").value(PRINCIPAL_USER))
-        .andExpect(jsonPath("$.MemberDetails.offHeapFreeSize").value(0))
-        .andExpect(jsonPath("$.MemberDetails.memberId").value(MEMBER_ID))
-        .andExpect(jsonPath("$.MemberDetails.status").value("Normal"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberDiskThroughput() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberDiskThroughput\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberDiskThroughput.throughputWritesTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberDiskThroughput.throughputReadsTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberDiskThroughput.throughputWrites").value(0D))
-        .andExpect(jsonPath("$.MemberDiskThroughput.throughputReads").value(0D))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberGatewayHub() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberGatewayHub\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberGatewayHub.isGatewayReceiver").value(false))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchTimeInterval").value(0))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchConflationEnabled").value(false))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].queueSize").value(0))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].senderType").value(false))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].asyncEventListener").value(AEQ_LISTENER))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].batchSize").value(0))
-        .andExpect(jsonPath("$.MemberGatewayHub.asyncEventQueues[0].primary").value(false))
-        .andExpect(jsonPath("$.MemberGatewayHub.isGatewaySender").value(false))
-        .andExpect(jsonPath("$.MemberGatewayHub.regionsInvolved").isEmpty())
-        .andExpect(jsonPath("$.MemberGatewayHub.gatewaySenders").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberGCPauses() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberGCPauses\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberGCPauses.gcPausesCount").value(0))
-        .andExpect(jsonPath("$.MemberGCPauses.gcPausesTrend").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberHeapUsage() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberHeapUsage\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberHeapUsage.heapUsageTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberHeapUsage.currentHeapUsage").value(0))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberKeyStatistics() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberKeyStatistics\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberKeyStatistics.readPerSecTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberKeyStatistics.cpuUsageTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberKeyStatistics.memoryUsageTrend").isEmpty())
-        .andExpect(jsonPath("$.MemberKeyStatistics.writePerSecTrend").isEmpty())
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMemberRegions() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MemberRegions\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MemberRegions.name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].fullPath").value(REGION_PATH))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].entryCount").value(0))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].name").value(REGION_NAME))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].diskStoreName").value(""))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].gatewayEnabled").value(false))
-        .andExpect(jsonPath("$.MemberRegions.memberRegions[0].entrySize").value("0.0000"))
-        .andExpect(jsonPath("$.MemberRegions.memberId").value(MEMBER_ID))
-        .andExpect(jsonPath("$.MemberRegions.status").value("Normal"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForMembersList() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"MembersList\":{\"memberName\":\"" + MEMBER_NAME + "\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.MembersList.clusterMembers[0].name").value(MEMBER_NAME))
-        .andExpect(jsonPath("$.MembersList.clusterMembers[0].memberId").value(MEMBER_ID))
-        .andExpect(jsonPath("$.MembersList.clusterName").value(CLUSTER_NAME))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForPulseVersion() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"PulseVersion\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.PulseVersion.sourceDate").value("not empty"))
-        .andExpect(jsonPath("$.PulseVersion.sourceRepository").value("not empty"))
-        .andExpect(jsonPath("$.PulseVersion.pulseVersion").value("not empty"))
-        .andExpect(jsonPath("$.PulseVersion.sourceRevision").value("not empty"))
-        .andExpect(jsonPath("$.PulseVersion.buildId").value("not empty"))
-        .andExpect(jsonPath("$.PulseVersion.buildDate").value("not empty"))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForQueryStatistics() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"QueryStatistics\":\"{}\"}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.QueryStatistics.queriesList").isEmpty())
-        .andExpect(jsonPath("$.QueryStatistics.connectedFlag").value(false))
-        .andExpect(jsonPath("$.QueryStatistics.connectedErrorMsg").value(""))
-    ;
-  }
-
-  @Test
-  public void pulseUpdateForSystemAlerts() throws Exception {
-    this.mockMvc.perform(post("/pulseUpdate")
-        .param("pulseData", "{\"SystemAlerts\":{\"pageNumber\":\"1\"}}")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.SystemAlerts.pageNumber").value(1))
-        .andExpect(jsonPath("$.SystemAlerts.connectedFlag").value(false))
-        .andExpect(jsonPath("$.SystemAlerts.connectedErrorMsg").value(""))
-        .andExpect(jsonPath("$.SystemAlerts.systemAlerts").isEmpty())
-    ;
-  }
-
-  @Test
-  public void authenticateUserNotLoggedIn() throws Exception {
-    this.mockMvc.perform(get("/authenticateUser")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.isUserLoggedIn").value(false));
-  }
-
-  @Test
-  public void authenticateUserLoggedIn() throws Exception {
-    this.mockMvc.perform(get("/authenticateUser")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.isUserLoggedIn").value(true));
-  }
-
-  @Test
-  public void pulseVersion() throws Exception {
-    this.mockMvc.perform(get("/pulseVersion")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.pulseVersion").isNotEmpty())
-        .andExpect(jsonPath("$.buildId").isNotEmpty())
-        .andExpect(jsonPath("$.buildDate").isNotEmpty())
-        .andExpect(jsonPath("$.sourceDate").isNotEmpty())
-        .andExpect(jsonPath("$.sourceRevision").isNotEmpty())
-        .andExpect(jsonPath("$.sourceRepository").isNotEmpty())
-    ;
-  }
-
-  @Test
-  public void clearAlerts() throws Exception {
-    this.mockMvc.perform(get("/clearAlerts")
-        .param("alertType", "1")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.pageNumber").value(1))
-        .andExpect(jsonPath("$.systemAlerts").isEmpty())
-        .andExpect(jsonPath("$.connectedFlag").value(false))
-        .andExpect(jsonPath("$.status").value("deleted"))
-    ;
-  }
-
-  @Test
-  public void acknowledgeAlert() throws Exception {
-    this.mockMvc.perform(get("/acknowledgeAlert")
-        .param("alertId", "1")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.status").value("deleted"));
-  }
-
-  @Test
-  public void dataBrowserRegions() throws Exception {
-    this.mockMvc.perform(get("/dataBrowserRegions")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.clusterName").value(CLUSTER_NAME))
-        .andExpect(jsonPath("$.connectedFlag").value(false))
-        .andExpect(jsonPath("$.clusterRegions[0].fullPath").value(REGION_PATH))
-        .andExpect(jsonPath("$.clusterRegions[0].regionType").value(REGION_TYPE))
-    ;
-  }
-
-  @Test
-  public void dataBrowserQuery() throws Exception {
-    doReturn(mapper.createObjectNode().put("foo", "bar")).when(cluster).executeQuery(anyString(), anyString(), anyInt());
-
-    this.mockMvc.perform(get("/dataBrowserQuery")
-        .param("query", "SELECT * FROM " + REGION_PATH)
-        .param("members", MEMBER_NAME)
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.foo").value("bar"))
-    ;
-  }
-
-  @Test
-  public void dataBrowserQueryHistory() throws Exception {
-    dataBrowserQuery();
-
-    this.mockMvc.perform(get("/dataBrowserQueryHistory")
-        .param("action", "view")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.queryHistory[0].queryText").value("\"SELECT * FROM " + REGION_PATH + "\""))
-    ;
-  }
-
-  @Test
-  public void pulseProductSupport() throws Exception {
-    this.mockMvc.perform(get("/pulseProductSupport")
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.product").value("gemfire"))
-    ;
-  }
-
-  @Test
-  public void getQueryStatisticsGridModel() throws Exception {
-    this.mockMvc.perform(get("/getQueryStatisticsGridModel")
-        .principal(principal)
-        .accept(MediaType.parseMediaType(MediaType.APPLICATION_JSON_UTF8_VALUE)))
-        .andExpect(status().isOk())
-        .andExpect(jsonPath("$.columnNames", containsInAnyOrder("Query",
-            "NumExecution",
-            "TotalExecutionTime(ns)",
-            "NumExecutionsInProgress",
-            "NumTimesCompiled",
-            "NumTimesGlobalIndexLookup",
-            "NumRowsModified",
-            "ParseTime(ms)",
-            "BindTime(ms)",
-            "OptimizeTime(ms)",
-            "RoutingInfoTime(ms)",
-            "GenerateTime(ms)",
-            "TotalCompilationTime(ms)",
-            "ExecutionTime(ns)",
-            "ProjectionTime(ns)",
-            "RowsModificationTime(ns)",
-            "QNNumRowsSeen",
-            "QNMsgSendTime(ns)",
-            "QNMsgSerTime(ns)",
-            "QNRespDeSerTime(ns)")))
-    ;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemFireDistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemFireDistributedSystem.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemFireDistributedSystem.java
deleted file mode 100644
index 4b25a8d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemFireDistributedSystem.java
+++ /dev/null
@@ -1,324 +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 com.vmware.geode.tools.pulse.testbed;
-
-import java.io.IOException;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-
-import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
-
-
-/**
- * 
- * TODO
- * 0. SystemAlerts
- * 1. Operations like member-up/down/crash, region create/destroy [7.5 scope]
- * 2. Read events like member-up/down/crash, region create/destroy [7.5 scope]
- * 3. PropFile Writing
- * 4. Link to other remote systems, topology - multi-cluster [7.5] 
- * 
- *
- */
-public class GemFireDistributedSystem {
-  
-  private static final String SERVERS = "servers";
-  private static final String LOCATORS_NAME = LOCATORS;
-  private static final String PEERS = "peers";
-  private static final String HOSTS = "hosts";
-  private static final String REGIONS = "regions";
-  private static final String CLIENTS = "clients";
-  private static final String SEP = ".";
-  private static final String FUNCTIONS = null;
-  private static final String CQS = null;
-  
-  
-  List<Server> servers = new ArrayList<Server>();
-  List<Client> clients = new ArrayList<Client>();
-  List<Locator> locators = new ArrayList<Locator>();
-  List<Peer> peers = new ArrayList<Peer>();
-  List<Host> hosts = new ArrayList<Host>();
-  List<Region> regions = new ArrayList<Region>();
-  List<Function> functions = new ArrayList<Function>();
-  List<CQ> cqs = new ArrayList<CQ>();
-  String dsName = null;
-  
-  public GemFireDistributedSystem(String name,Properties pr){
-    PropFileHelper propertiesFile = new PropFileHelper(pr);
-    this.dsName = name;
-    readGemfireDS(propertiesFile);
-  }
-  
-  public GemFireDistributedSystem(String name,String fileName) throws IOException{
-    PropFileHelper propertiesFile = new PropFileHelper(fileName);
-    this.dsName = name;
-    readGemfireDS(propertiesFile);
-  }
-  
-  private void readGemfireDS(PropFileHelper propertiesFile) {
-    String serverStrings[] = propertiesFile.readValues(dsName + SEP + SERVERS);
-    System.out.println("Servers = " + serverStrings.length);
-    for(String serverName : serverStrings){
-      Server server = new Server();
-      server.init(propertiesFile,dsName,serverName);
-      servers.add(server);
-    }  
-    
-    String clientStrings[] = propertiesFile.readValues(dsName + SEP + CLIENTS);
-    System.out.println("Clients = " + clientStrings.length);
-    for(String clientName : clientStrings){
-      Client client = new Client();
-      client.init(propertiesFile,dsName,clientName);
-      clients.add(client);
-    }  
-    
-    String locatorStrings[] = propertiesFile.readValues(dsName + SEP + LOCATORS);
-    System.out.println("Locators = " + locatorStrings.length);
-    for(String locatorName : locatorStrings){
-      Locator locator = new Locator();
-      locator.init(propertiesFile,dsName,locatorName);
-      locators.add(locator);
-    }
-    
-    String peerStrings[] = propertiesFile.readValues(dsName + SEP + PEERS);
-    System.out.println("Peers = " + peerStrings.length);
-    for(String peerName : peerStrings){
-      Peer peer = new Peer();
-      peer.init(propertiesFile,dsName,peerName);
-      peers.add(peer);
-    }
-    
-    String hostsStrings[] = propertiesFile.readValues(dsName + SEP + HOSTS);
-    for(String hostName : hostsStrings){
-      Host host = new Host();
-      host.init(propertiesFile,dsName,hostName);
-      hosts.add(host);
-    }
-    
-    String regionsStrings[] = propertiesFile.readValues(dsName + SEP + REGIONS);
-    for(String regionName : regionsStrings){
-      Region region = new Region();
-      region.init(propertiesFile,dsName,regionName);
-      regions.add(region);
-    }
-    
-    String functionStrings[] = propertiesFile.readValues(dsName + SEP + FUNCTIONS);
-    for(String functionName : functionStrings){
-      Function function = new Function();
-      function.init(propertiesFile,dsName,functionName);
-      functions.add(function);
-    }    
-    
-    String cqStrings[] = propertiesFile.readValues(dsName + SEP + CQS);
-    for(String cqName : cqStrings){
-      CQ cq = new CQ();
-      cq.init(propertiesFile,dsName,cqName);
-      cqs.add(cq);
-    }
-    
-  }
-  
-  public List<Region> getRegions(String memberName) {    
-    List<Region> list = new ArrayList<Region>();
-    for(Region r : regions){
-      if(r.getMembers().contains(memberName))
-          list.add(r);
-    }
-    return list;
-   }
-  
-  public Region getRegion(String regionName) {
-    Region r = null;
-    for (Region rn : getRegions()) {
-      if (rn.getName().equals(regionName)) {
-        r = rn;
-        break;
-      }
-    }
-    return r;
-  }
-
-  public List<Region> getRegions() {
-   return regions;
-  }
-  
-  public List<Function> getFunction() {
-    return functions;
-  }
-  
-  public List<CQ> getCQs() {
-    return cqs;
-  }
-  
-  public List<Server> getServers(){
-    return servers;    
-  }
-  
-  public List<Client> getClients(){
-    return clients;
-  }
-  
-  public List<Peer> getPeers(){
-    return peers;    
-  }
-  
-  public List<Locator> getLocators(){
-    return locators;    
-  }
-  
-  public List<Host> getPhysicalHosts(){
-    return hosts;    
-  }
-  
-  public static class Base{
-    protected Map<String,String> properties=null;
-    protected String name;
-    
-    public void init(PropFileHelper propertiesFile, String dsName, String name) {
-      this.name = name;      
-      String leadingkey = dsName + SEP + name;
-      Map<String,String> map = propertiesFile.readObject(leadingkey);
-      map.put("name",name);
-      this.properties = map;
-    }
-    
-    public String getName(){
-      return properties.get("name");
-    }
-    
-    public String key(String string) {
-      return properties.get(string);
-    }
-    
-    public int keyInt(String string) {
-      String str = properties.get(string);
-      try{
-        int index = Integer.parseInt(str);
-        return index;
-      }catch(Exception e){
-        return -1;
-      }
-    }
-    
-    public List<String> values(String string) {
-      String values= properties.get(string);
-      String array[] = values.split(",");
-      List<String> list = new ArrayList<String>();
-      for(String s:array)
-        list.add(s);
-      return list;
-    }
-    
-  }
-  
-  public static class Host extends Base{
-    
-  }
-  
-  public static class Server extends Base{
-    public String toString(){
-      return properties.get("name") + "[on host=" + properties.get("host");
-    }
-    
-    public String getHost(){
-      return properties.get("host");
-    }
-  }
-  
-  public static class Client extends Base{
-    public String toString(){
-      return properties.get("name") ;//+ "[on host=" + properties.get("host");
-    }
-    
-    public String getHost(){
-      return properties.get("host");
-    }
-  }
-  
-  public static class Locator extends Base{
-    public String getHost(){
-      return properties.get("host");
-    }
-  }
-  
-  public static class Peer extends Base{
-
-    public String getHost(){
-      return properties.get("host");
-    }
-  }
-  
-  public static class Region extends Base{
-    public String toString(){
-      return properties.get("name") + "[type=" + properties.get("type");
-    }
-    
-    public String getType(){
-      return key("type");
-    }
-    
-    public int getEntryCount(){
-      return keyInt("entryCount");
-    }
-    
-    public List<String> getWanSenders(){
-      return values("wanSenders");
-    }
-    
-    public List<String> getMembers(){
-      return values("members");
-    }
-    
-  }
-  
-  public static class WanSender extends Base{
-    
-  }
-
-  public static class Function extends Base{
-    public String getMemberId(){
-      return key("memberId");
-    }    
-  }
-  
-  public static class CQ extends Base{
-    public String getQuery(){
-      return key("query");
-    }    
-    
-    public String getClient(){
-      return key("client");
-    }
-  }
-  
-  public static class SystemAlert extends Base{
-    //TODO
-  }
-  
-  public static void main(String[] args) throws IOException {
-    
-    GemFireDistributedSystem ds = new GemFireDistributedSystem("t1", "config/testbed.properties");
-    System.out.println("Servers = " + ds.getServers());    
-    System.out.println("Regions = " + ds.getRegions());
-    System.out.println("Clients = " + ds.getClients());
-  } 
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemfireTopology.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemfireTopology.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemfireTopology.java
deleted file mode 100644
index 6470195..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/GemfireTopology.java
+++ /dev/null
@@ -1,24 +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 com.vmware.geode.tools.pulse.testbed;
-
-public class GemfireTopology {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropFileHelper.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropFileHelper.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropFileHelper.java
deleted file mode 100644
index 1892292..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropFileHelper.java
+++ /dev/null
@@ -1,115 +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 com.vmware.geode.tools.pulse.testbed;
-
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Properties;
-
-public class PropFileHelper {
-  
-  private String filePath=null;
-  private Properties pr=null;
-  
-  public PropFileHelper(String filePath) throws FileNotFoundException, IOException{
-    this.filePath = filePath;
-    pr = new Properties();
-    pr.load(new FileInputStream(new File(this.filePath)));
-  }
-  
-  public PropFileHelper(Properties pr2) {
-    this.pr =pr2;
-  }
-
-  public String[] readValues(String property){
-    return readValues(property,",");
-  }
-  
-  public String[] readValues(String property, String separator){
-    String value = readKey(property);
-    if(value!=null){
-      String[] array = value.split(separator);
-      return array;
-    }else{
-      return new String[0];
-    }
-  }
-  
-  public String readKey(String key){
-    String value = pr.getProperty(key);
-    if(value!=null)
-      return value.trim();
-    else return value;
-  }
-  
-  public Map<String,String> readObject(String leadingkey){
-    Map<String,String> map = new HashMap<String,String>();
-    String leadingKeyString = leadingkey+"."; 
-    for(Object keyObject : pr.keySet()){
-      String key = (String)keyObject;
-      String value = readKey(key);
-      if(key.startsWith(leadingKeyString)){
-        String innerProp = key.substring(leadingKeyString.length());
-        /* inner object stuff
-        if(checkForMultipleValues){
-          if(innerProp.contains(separator)){
-            String array[] = readValues(key);
-          }
-        }else*/
-        {
-          //System.out.println("Adding prop with key " + innerProp + " k=" + leadingkey);
-          map.put(innerProp, value);
-        }      
-      }
-    }    
-    return map;
-  }
-  
-  public static void main(String[] args) {
-    
-    Properties pr = new Properties();
-    pr.put("topologies", "t1,t2");
-    pr.put("t1.id", "1");
-    pr.put("t2.id", "2");
-    
-    pr.put("t1.prop1", "prop11");
-    pr.put("t1.prop2", "prop12");
-    pr.put("t1.prop3", "prop13");
-    pr.put("t2.prop1", "1");
-    pr.put("t2.prop2", "2");
-    pr.put("t2.prop3", "3");
-    
-    PropFileHelper helper = new PropFileHelper(pr);
-    String topologies[] = helper.readValues("topologies");
-    for(String topology : topologies){
-      Map<String,String> topologyMap = helper.readObject(topology);
-      System.out.println(topologyMap);
-    }
-    
-  }
-
-  public Properties getProperties() {
-    return pr;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropMockDataUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropMockDataUpdater.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropMockDataUpdater.java
deleted file mode 100644
index 007be75..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/PropMockDataUpdater.java
+++ /dev/null
@@ -1,513 +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 com.vmware.geode.tools.pulse.testbed;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.Alert;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.Client;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.GatewayReceiver;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.GatewaySender;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.Member;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.Region;
-import com.vmware.geode.tools.pulse.internal.data.IClusterUpdater;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Locator;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Peer;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Server;
-
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Date;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Map.Entry;
-import java.util.Random;
-import java.util.ResourceBundle;
-
-public class PropMockDataUpdater implements IClusterUpdater {
-  private static final int MAX_HOSTS = 40;
-  private static final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-  private final ResourceBundle resourceBundle = Repository.get().getResourceBundle();
-  private static final int POLL_INTERVAL = 5000;
-  public static final int MAX_SAMPLE_SIZE = 180;
-  public static final int ALERTS_MAX_SIZE = 1000;
-  public static final int PAGE_ALERTS_MAX_SIZE = 100;
-
-  private Cluster cluster= null;
-  private TestBed testbed;
-  private final String testbedFile = System.getProperty("pulse.propMockDataUpdaterFile");;
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public PropMockDataUpdater(Cluster cluster) {
-    this.cluster = cluster;
-    try {
-      loadPropertiesFile();
-    } catch (FileNotFoundException e) {
-      throw new RuntimeException(e);
-    } catch (IOException e) {
-      throw new RuntimeException(e);
-    }
-  }
-
-  private void loadPropertiesFile() throws FileNotFoundException, IOException{
-    this.testbed = new TestBed(testbedFile,true);
-  }
-
-  /**
-   * function used for updating Cluster data
-   * for Mock
-   */
-  @Override
-  public boolean updateData() {
-    cluster.setConnectedFlag(true);
-    Random r = new Random(System.currentTimeMillis());
-    long totalHeapSize = Math.abs(r.nextInt(3200 - 2048) + 2048);
-    cluster.setTotalHeapSize(totalHeapSize);
-    long usedHeapSize  = Math.abs(r.nextInt(2048));
-    cluster.setUsedHeapSize(usedHeapSize);
-    double writePerSec = Math.abs(r.nextInt(100));
-    cluster.setWritePerSec(writePerSec);
-
-    //propfile
-    cluster.setSubscriptionCount(testbed.getRootDs().getClients().size());
-    cluster.setRegisteredCQCount((long) testbed.getRootDs().getCQs().size());
-    cluster.setRunningFunctionCount(testbed.getRootDs().getFunction().size());
-
-
-    cluster.setClusterId( Math.abs(r.nextInt(100)));
-    cluster.getWritePerSecTrend().add(writePerSec);
-    cluster.setDiskWritesRate(writePerSec);
-
-    long garbageCollectionCount = Math.abs(r.nextInt(100));
-    cluster.setGarbageCollectionCount(garbageCollectionCount);
-    cluster.getGarbageCollectionTrend().add(garbageCollectionCount);
-
-    long readPerSec = Math.abs(r.nextInt(100));
-    cluster.setReadPerSec(readPerSec);
-    cluster.getReadPerSecTrend().add(readPerSec);
-
-    long diskReadsRate = readPerSec;cluster.setDiskReadsRate(diskReadsRate);
-    cluster.setDiskReadsRate(readPerSec);
-    long queriesPerSec = Math.abs(r.nextInt(100));
-    cluster.setQueriesPerSec(queriesPerSec);
-    cluster.getQueriesPerSecTrend().add(queriesPerSec);
-
-    long loadPerSec = Math.abs(r.nextInt(100));
-    cluster.setLoadPerSec(loadPerSec);
-    cluster.setTotalHeapSize(totalHeapSize);
-    long totalBytesOnDisk = totalHeapSize;
-    cluster.setTotalBytesOnDisk(totalBytesOnDisk);
-
-    cluster.getTotalBytesOnDiskTrend().add(totalBytesOnDisk);
-
-    cluster.getMemoryUsageTrend().add(usedHeapSize);
-    cluster.getThroughoutWritesTrend().add(writePerSec);
-
-    cluster.setMemberCount(0);
-
-    Map<String,Cluster.Member>  membersHMap = cluster.getMembersHMap();
-    List<Cluster.Region> regionsList = (List<Cluster.Region>)cluster.getClusterRegions().values();
-    Map<String, Boolean> wanInformation = cluster.getWanInformation();
-
-    // Create 3 members first time around
-    int locatorCount=0;
-    if (membersHMap.size() == 0) {
-      for(Locator locator : testbed.getRootDs().getLocators()){
-        String id = "(Launcher_Locator-1099-13-40-24-5368)-"+locatorCount++;
-        String name = locator.getName();
-        membersHMap.put(id+name, initializeMember(id,name, true, true, true, false, locator.getHost()));
-      }
-      cluster.setLocatorCount(testbed.getRootDs().getLocators().size());
-
-      int serverCount=0;
-      for(Server server : testbed.getRootDs().getServers()){
-        String id = "(Launcher_Server-1099-13-40-24-5368)-"+serverCount++;
-        String name = server.getName();
-        membersHMap.put(id+name, initializeMember(id,name, false, true, false, true, server.getHost()));
-      }
-      cluster.setServerCount(testbed.getRootDs().getServers().size());
-
-      int peerCount=0;
-      for(Peer peer : testbed.getRootDs().getPeers()){
-        String id = "(Launcher_Peer-1099-13-40-24-5368)-"+peerCount++;
-        String name = peer.getName();
-        membersHMap.put( id+name, initializeMember(id,name, false, true, false, false, peer.getHost()));
-      }
-
-      for(Entry<String, Member> memberSet : membersHMap.entrySet())
-      {
-        HashMap<String,Cluster.Region> memberRegions = new HashMap<String,Cluster.Region>();
-        HashMap<String,Cluster.Client> memberClientsHM = new HashMap<String,Cluster.Client>();
-
-        Random randomGenerator = new Random();
-
-        //Read from property file
-        int randomInt = (randomGenerator.nextInt(5)) + 1;
-        List<com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Region> thisMemberRegions = testbed.getRootDs().getRegions(memberSet.getValue().getName());
-
-        int regionExists = 0;
-        int index=0;
-        for (com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Region thisMemberRegion : thisMemberRegions) {
-          Region region = initMemberRegion(index++,thisMemberRegion.getName(),memberSet.getValue().getName(),
-              thisMemberRegion.getEntryCount(),thisMemberRegion.getType(), thisMemberRegion.getMembers().size()); //read from property file
-          if (regionsList.size() > 0) {
-            for (Region clusterRegion : regionsList) {
-              if ((region.getName()).equals(clusterRegion.getName())) {
-                clusterRegion.getMemberName().add(memberSet.getValue().getName());
-                //clusterRegion.memberCount = clusterRegion.memberCount + 1;
-                //int mcount = clusterRegion.getMemberCount() + 1;
-                //clusterRegion.setMemberCount(mcount);
-                regionExists = 1;
-                break;
-              }
-            }
-            if (regionExists == 0){
-              regionsList.add(region);
-            }
-          } else{
-            regionsList.add(region);
-          }
-          memberRegions.put(region.getFullPath(),region);
-          //totalRegionCount = regionsList.size();
-          cluster.setTotalRegionCount(regionsList.size());
-        }
-        membersHMap.get(memberSet.getKey()).setMemberRegions(memberRegions);
-
-        if (memberSet.getValue().isCache()) {
-          Client client = initMemberClient(0, memberSet.getValue().getHost()); //read from prop File
-          memberClientsHM.put(client.getId(), client);
-          randomInt = randomGenerator.nextInt(10);
-          for (int y = 1; y < randomInt; y++) {
-            Client newClient = initMemberClient(y, memberSet.getValue()
-                .getHost());
-            memberClientsHM.put(newClient.getId(), newClient);
-          }
-          membersHMap.get(memberSet.getKey()).updateMemberClientsHMap(memberClientsHM);
-          /*clientConnectionCount = clientConnectionCount
-              + membersHMap.get(memberSet.getKey()).getMemberClientsHMap().size();*/
-          long clientConnectionCount = cluster.getClientConnectionCount() + membersHMap.get(memberSet.getKey()).getMemberClientsHMap().size();
-          cluster.setClientConnectionCount(clientConnectionCount);
-        }
-
-      }
-    }
-    wanInformation.clear(); //read from property file
-    int wanInfoSize = Math.abs(r.nextInt(10));
-    wanInfoSize++;
-    for (int i = 0; i < wanInfoSize; i++) {
-      String name = "Mock Cluster" + i;
-      Boolean value = false;
-      if (i % 2 == 0){
-        value = true;
-      }
-      wanInformation.put(name, value);
-    }
-    //memberCount = membersHMap.size();
-    cluster.setMemberCount(membersHMap.size());
-
-    totalHeapSize = 0;
-    for(Entry<String, Member> memberSet : membersHMap.entrySet())
-    {
-      refresh(membersHMap.get(memberSet.getKey()));
-      Member member = membersHMap.get(memberSet.getKey());
-      totalHeapSize += member.getCurrentHeapSize();
-    }
-
-    for (Region region : regionsList) {
-      region.setGetsRate((Math.abs(r.nextInt(100))) + 1);
-      region.setPutsRate((Math.abs(r.nextInt(100))) +1);
-      region.getGetsPerSecTrend().add(region.getGetsRate());
-      region.getPutsPerSecTrend().add(region.getPutsRate());
-    }
-
-    return true;
-  }
-
-
-  private Region initMemberRegion(int count, String regionName, String memName, int entryCount, String type, int memberCount) {
-    Region memberRegion = new Region();
-    memberRegion.setName(regionName);
-    memberRegion.setFullPath("/"+regionName);
-    Random randomGenerator = new Random();
-    memberRegion.setSystemRegionEntryCount(entryCount);
-    // memberRegion.setEntrySize("N/A");
-    memberRegion.setEntrySize(Math.abs(randomGenerator.nextInt(10)));
-    memberRegion.setDiskStoreName("ABC");
-    memberRegion.setScope("DISTRIBUTED_NO_ACK");
-    memberRegion.setDiskSynchronous(true);
-    memberRegion.setRegionType(type);
-    if(type.contains("PERSISTENT"))
-      memberRegion.setPersistentEnabled(true);
-    else
-      memberRegion.setPersistentEnabled(false);
-    if (count % 2 == 0){
-      memberRegion.setWanEnabled(true);
-    }
-    else{
-      memberRegion.setWanEnabled(false);
-    }
-    memberRegion.setWanEnabled(true);
-    /*memberRegion.setSystemRegionEntryCount(Long.valueOf(String.valueOf(Math
-        .abs(randomGenerator.nextInt(100)))));*/
-    memberRegion.getMemberName().add(memName);
-    memberRegion.setMemberCount(memberCount);
-    return memberRegion;
-  }
-
-
-  private Client initMemberClient(int count, String host) {
-
-    Client memberClient = new Client();
-    Random r = new Random(System.currentTimeMillis());
-    memberClient.setName("Name_" + count);
-    long processCpuTime = (long) (r.nextDouble() * 100);
-    memberClient.setProcessCpuTime(processCpuTime);
-    memberClient.setCpuUsage(0);
-    memberClient.setGets(Math.abs(r.nextInt(100)));
-    memberClient.setHost(host);
-    memberClient.setId(String.valueOf(1000 + count));
-    memberClient.setPuts(Math.abs(r.nextInt(100)));
-    memberClient.setCpus(Math.abs(r.nextInt(20)));
-    memberClient.setQueueSize(Math.abs(r.nextInt(100)));
-    if ((count % 2) == 0){
-      memberClient.setStatus("up");
-    }
-    else{
-      memberClient.setStatus("down");
-    }
-    memberClient.setThreads(Math.abs(r.nextInt(100)));
-    memberClient
-        .setUptime(Math.abs(System.currentTimeMillis() - r.nextLong()));
-
-    return memberClient;
-  }
-
-  private Member initializeMember(String id, String name, boolean manager,
-      boolean isCache, boolean isLocator, boolean isServer, String host) {
-    Member m = new Member();
-
-    m.setId(id);
-    m.setName(name);
-
-    //m.setHost(getHostName(System.currentTimeMillis()));
-    m.setHost(host);
-
-    m.setMaxHeapSize(247);
-
-    Random r = new Random(System.currentTimeMillis());
-
-    m.setCache(isCache);
-    m.setLocator(isLocator);
-    m.setServer(isServer);
-    m.setManager(manager);
-
-    m.setLoadAverage((double) Math.abs(r.nextInt(100)));
-    m.setNumThreads(Math.abs(r.nextInt(100)));
-    m.setGarbageCollectionCount((long) Math.abs(r.nextInt(100)));
-    m.getGarbageCollectionSamples().add(m.getGarbageCollectionCount());
-
-    m.setTotalFileDescriptorOpen((long) Math.abs(r.nextInt(100)));
-    m.setTotalDiskUsage(Math.abs(r.nextInt(100)));
-
-
-    m.setThroughputWrites(Math.abs(r.nextInt(10)));
-    m.getThroughputWritesTrend().add(m.getThroughputWrites());
-
-    GatewayReceiver gatewayReceiver = m.getGatewayReceiver();
-    String port  = cluster.getPort();
-    if(port==null || "".equals(port))
-      port = "1099";
-    gatewayReceiver.setListeningPort(Integer.parseInt(port));
-    gatewayReceiver.setLinkThroughput(Math.abs(r.nextInt(10)));
-    gatewayReceiver.setAvgBatchProcessingTime((long) Math.abs(r.nextInt(10)));
-    gatewayReceiver.setId(String.valueOf(Math.abs(r.nextInt(10))));
-    gatewayReceiver.setQueueSize(Math.abs(r.nextInt(10)));
-    gatewayReceiver.setStatus(true);
-    gatewayReceiver.setBatchSize(Math.abs(r.nextInt(10)));
-
-    int gatewaySenderCount = Math.abs(r.nextInt(10));
-
-    List<GatewaySender> list = m.getGatewaySenderList();
-
-    for (int i = 0; i < gatewaySenderCount; i++) {
-      list.add(createGatewaySenderCount(r));
-    }
-
-    Map<String, List<Member>> physicalToMember = cluster.getPhysicalToMember();
-
-    List<Cluster.Member> memberArrList = physicalToMember.get(m.getHost());
-    if (memberArrList != null){
-      memberArrList.add(m);
-    }
-    else {
-      ArrayList<Cluster.Member> memberList = new ArrayList<Cluster.Member>();
-      memberList.add(m);
-      physicalToMember.put(m.getHost(), memberList);
-    }
-    int memberCount = cluster.getMemberCount();memberCount++;cluster.setMemberCount(memberCount);
-    return m;
-  }
-
-  private GatewaySender createGatewaySenderCount(Random r) {
-
-    GatewaySender gatewaySender = new GatewaySender();
-
-    gatewaySender.setBatchSize(Math.abs(r.nextInt(10)));
-    gatewaySender.setId(String.valueOf(Math.abs(r.nextInt(10))));
-    gatewaySender.setLinkThroughput(Math.abs(r.nextInt(10)));
-    gatewaySender.setPersistenceEnabled(true);
-    gatewaySender.setPrimary(true);
-    gatewaySender.setQueueSize(Math.abs(r.nextInt(10)));
-    gatewaySender.setSenderType(false);
-    gatewaySender.setStatus(true);
-
-    return gatewaySender;
-  }
-
-  /*
-  private String getHostName(long rndSeed) {
-    Random rnd = new Random(rndSeed);
-    String hName = null;
-
-    int index = Math.abs(rnd.nextInt(MAX_HOSTS));
-
-    ArrayList<String> hostNames = cluster.getHostNames();
-
-    if (hostNames.size() <= index) {
-      hName = "host" + hostNames.size();
-      hostNames.add(hName);
-    } else {
-      hName = hostNames.get(index);
-    }
-
-    Map<String, ArrayList<Member>> physicalToMember = cluster.getPhysicalToMember();
-
-    ArrayList<Member> memberArrList = physicalToMember.get(hName);
-    if (memberArrList != null) {
-      if (memberArrList.size() > 4){
-        hName = getHostName(rndSeed + rnd.nextLong());
-      }
-    }
-    return hName;
-  }*/
-
-  private void refresh(Member m) {
-    if(LOGGER.infoEnabled()){
-      LOGGER.info(resourceBundle.getString("LOG_MSG_REFRESHING_MEMBER_DATA")+" : " + m.getName());
-    }
-
-    Random r = new Random(System.currentTimeMillis());
-
-    m.setUptime(System.currentTimeMillis());
-    m.setQueueBacklog("" + Math.abs(r.nextInt(500)));
-    m.setCurrentHeapSize(Math.abs(r.nextInt(Math.abs((int) m.getMaxHeapSize()))));
-    m.setTotalDiskUsage(Math.abs(r.nextInt(100)));
-
-    double cpuUsage = r.nextDouble() * 100;
-    m.getCpuUsageSamples().add(cpuUsage);
-    m.setCpuUsage(cpuUsage);
-
-    m.getHeapUsageSamples().add(m.getCurrentHeapSize());
-    m.setLoadAverage((double) Math.abs(r.nextInt(100)));
-    m.setNumThreads(Math.abs(r.nextInt(100)));
-    m.setGarbageCollectionCount((long) Math.abs(r.nextInt(100)));
-    m.getGarbageCollectionSamples().add(m.getGarbageCollectionCount());
-
-    m.setTotalFileDescriptorOpen((long) Math.abs(r.nextInt(100)));
-
-    m.setThroughputWrites(Math.abs(r.nextInt(10)));
-    m.getThroughputWritesTrend().add(m.getThroughputWrites());
-
-    m.setGetsRate(Math.abs(r.nextInt(5000)));
-    m.getGetsPerSecond().add(m.getGetsRate());
-
-    m.setPutsRate(Math.abs(r.nextInt(5000)));
-    m.getPutsPerSecond().add(m.getPutsRate());
-
-    Alert[] alerts = cluster.getAlertsList();
-    List<Alert> alertsList = Arrays.asList(alerts);
-
-    if (r.nextBoolean()) {
-      // Generate alerts
-      if (r.nextBoolean()) {
-        if (r.nextInt(10) > 5) {
-          alertsList.add(createAlert(Alert.SEVERE, m.getName(), alertsList.size()));
-          if(alertsList.size() > ALERTS_MAX_SIZE){
-            alertsList.remove(0);
-          }
-        }
-      }
-
-      if (r.nextBoolean()) {
-        if (r.nextInt(10) > 5) {
-          alertsList.add(createAlert(Alert.ERROR, m.getName(), alertsList.size()));
-          if(alertsList.size() > ALERTS_MAX_SIZE){
-            alertsList.remove(0);
-          }
-        }
-      }
-
-      if (r.nextBoolean()) {
-        if (r.nextInt(10) > 5) {
-          alertsList.add(createAlert(Alert.WARNING, m.getName(), alertsList.size()));
-          if(alertsList.size() > ALERTS_MAX_SIZE){
-            alertsList.remove(0);
-          }
-        }
-      }
-    }
-  }
-
-  private Alert createAlert(int sev, String memberName, int index) {
-
-    Alert alert = new Alert();
-    alert.setSeverity(sev);
-    alert.setId(index);
-    alert.setMemberName(memberName);
-    alert.setTimestamp(new Date());
-
-    switch (sev) {
-    case Alert.SEVERE:
-      alert.setDescription(PulseConstants.ALERT_DESC_SEVERE);
-      break;
-    case Alert.ERROR:
-      alert.setDescription(PulseConstants.ALERT_DESC_ERROR);
-      break;
-    case Alert.WARNING:
-      alert.setDescription(PulseConstants.ALERT_DESC_WARNING);
-      break;
-    }
-    return alert;
-  }
-
-  @Override
-  public ObjectNode executeQuery(String queryText, String members, int limit) {
-    // TODO for Sushant/Sachin - Add implementation for MockUpdater for Automation
-    return null;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/TestBed.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/TestBed.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/TestBed.java
deleted file mode 100644
index ba04c32..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/TestBed.java
+++ /dev/null
@@ -1,84 +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 com.vmware.geode.tools.pulse.testbed;
-
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.Properties;
-
-public class TestBed {
-  
-  private String fileName=null;
-  PropFileHelper propertiesFile =null;
-  GemFireDistributedSystem ds = null;
-
-  public TestBed(){
-    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-    InputStream inputStream = classLoader.getResourceAsStream("testbed.properties");
-    Properties properties = new Properties();
-    try {
-      properties.load(inputStream);
-    } catch (IOException e) {
-      e.printStackTrace();
-      throw new RuntimeException(e);
-    }
-    propertiesFile = new PropFileHelper(properties);
-    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
-  }
-
-  public TestBed(String fileName) throws FileNotFoundException, IOException{
-    this.fileName = fileName;
-    propertiesFile = new PropFileHelper(fileName);
-    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
-  }
-  
-  
-  public TestBed(String fileName,boolean flag) throws FileNotFoundException, IOException{    
-//    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-//    InputStream inputStream = classLoader.getResourceAsStream("testbed.properties");
-//    System.out.println("Inputstream : " + inputStream);
-    Properties properties = new Properties();
-    try {
-      properties.load(new FileInputStream(new File(fileName)));
-    } catch (IOException e) {
-      e.printStackTrace();
-      throw new RuntimeException(e);
-    }    
-    this.fileName = fileName;
-    propertiesFile = new PropFileHelper(properties);
-    ds = new GemFireDistributedSystem("t1", propertiesFile.getProperties());
-  }
-  
-  
-  public String getBrowserForDriver(){
-    return propertiesFile.readKey("browser");
-  }
-  
-  public String getBrowserVersionForDriver(String browser){
-    return propertiesFile.readKey("browserVersion");
-  }
-  
-  public GemFireDistributedSystem getRootDs(){
-    return ds;
-  }  
-
-}
\ No newline at end of file


[50/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
index bf6dfb4..5521f1b 100644
--- a/README.md
+++ b/README.md
@@ -61,8 +61,8 @@ Write a client application:
 _HelloWorld.java_
 
     import java.util.Map;
-    import com.gemstone.gemfire.cache.Region;
-    import com.gemstone.gemfire.cache.client.*;
+    import org.apache.geode.cache.Region;
+    import org.apache.geode.cache.client.*;
 
     public class HelloWorld {
       public static void main(String[] args) throws Exception {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/conf/cache-peer.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/conf/cache-peer.xml b/extensions/geode-modules-assembly/release/conf/cache-peer.xml
index 84fb67a..0480dca 100755
--- a/extensions/geode-modules-assembly/release/conf/cache-peer.xml
+++ b/extensions/geode-modules-assembly/release/conf/cache-peer.xml
@@ -37,7 +37,7 @@
       <entry-idle-time>
         <expiration-attributes timeout="0" action="invalidate">
           <custom-expiry>
-            <class-name>com.gemstone.gemfire.modules.util.SessionCustomExpiry</class-name>
+            <class-name>org.apache.geode.modules.util.SessionCustomExpiry</class-name>
           </custom-expiry>
         </expiration-attributes>
       </entry-idle-time>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/conf/cache-server.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/conf/cache-server.xml b/extensions/geode-modules-assembly/release/conf/cache-server.xml
index 67ccbd1..d67b456 100755
--- a/extensions/geode-modules-assembly/release/conf/cache-server.xml
+++ b/extensions/geode-modules-assembly/release/conf/cache-server.xml
@@ -60,7 +60,7 @@
       <entry-idle-time>
         <expiration-attributes timeout="0" action="invalidate">
           <custom-expiry>
-            <class-name>com.gemstone.gemfire.modules.util.SessionCustomExpiry</class-name>
+            <class-name>org.apache.geode.modules.util.SessionCustomExpiry</class-name>
           </custom-expiry>
         </expiration-attributes>
       </entry-idle-time>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-7/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-7/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-7/context-fragment.xml
index 72faee2..b7ad94e 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-7/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-7/context-fragment.xml
@@ -1,9 +1,9 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <remove:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"/>
+    <remove:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"/>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat7DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat7DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:true}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-8/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-8/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-8/context-fragment.xml
index 72faee2..b7ad94e 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-8/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-cs-tomcat-8/context-fragment.xml
@@ -1,9 +1,9 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <remove:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"/>
+    <remove:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"/>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat7DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat7DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:true}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-cs/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-cs/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-cs/context-fragment.xml
index fac3044..5b1f233 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-cs/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-cs/context-fragment.xml
@@ -1,7 +1,7 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:true}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-cs/server-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-cs/server-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-cs/server-fragment.xml
index c4adc66..2ffccf6 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-cs/server-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-cs/server-fragment.xml
@@ -1,7 +1,7 @@
 <?xml version='1.0' encoding='utf-8'?>
 <Server>
 
-    <add:Listener className="com.gemstone.gemfire.modules.session.catalina.ClientServerCacheLifecycleListener"
+    <add:Listener className="org.apache.geode.modules.session.catalina.ClientServerCacheLifecycleListener"
       cache-xml-file="${cache.configuration.file:cache-client.xml}"
       criticalHeapPercentage="${critical.heap.percentage:0.0}"
       evictionHeapPercentage="${eviction.heap.percentage:80.0}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-7/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-7/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-7/context-fragment.xml
index 155aa2a..252fa8f 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-7/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-7/context-fragment.xml
@@ -1,9 +1,9 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <remove:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"/>
+    <remove:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"/>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat7DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat7DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:false}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-8/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-8/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-8/context-fragment.xml
index 155aa2a..252fa8f 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-8/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-p2p-tomcat-8/context-fragment.xml
@@ -1,9 +1,9 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <remove:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"/>
+    <remove:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"/>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat7DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat7DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:false}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-p2p/context-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-p2p/context-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-p2p/context-fragment.xml
index 2b3d25c..ddf2d31 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-p2p/context-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-p2p/context-fragment.xml
@@ -1,7 +1,7 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <Context>
 
-    <add:Manager className="com.gemstone.gemfire.modules.session.catalina.Tomcat6DeltaSessionManager"
+    <add:Manager className="org.apache.geode.modules.session.catalina.Tomcat6DeltaSessionManager"
       enableDebugListener="${enable.debug.listener:false}"
       enableGatewayReplication="${enable.gateway.replication:false}"
       enableLocalCache="${enable.local.cache:false}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-assembly/release/tcserver/geode-p2p/server-fragment.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-assembly/release/tcserver/geode-p2p/server-fragment.xml b/extensions/geode-modules-assembly/release/tcserver/geode-p2p/server-fragment.xml
index cf7dc0d..478ee37 100644
--- a/extensions/geode-modules-assembly/release/tcserver/geode-p2p/server-fragment.xml
+++ b/extensions/geode-modules-assembly/release/tcserver/geode-p2p/server-fragment.xml
@@ -1,7 +1,7 @@
 <?xml version='1.0' encoding='utf-8'?>
 <Server>
 
-    <add:Listener className="com.gemstone.gemfire.modules.session.catalina.PeerToPeerCacheLifecycleListener"
+    <add:Listener className="org.apache.geode.modules.session.catalina.PeerToPeerCacheLifecycleListener"
       cache-xml-file="${cache.configuration.file:cache-peer.xml}"
       criticalHeapPercentage="${critical.heap.percentage:0.0}"
       evictionHeapPercentage="${eviction.heap.percentage:80.0}"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/EnumType.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/EnumType.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/EnumType.java
index 1e66412..0a8218e 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/EnumType.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/EnumType.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
+package org.apache.geode.modules.hibernate;
 
 import java.io.Serializable;
 
@@ -30,7 +30,7 @@ import org.hibernate.HibernateException;
  * e.g. a typical enum configuration should look like this:
  * <pre>
  * &lt;property name="myEnum"&gt;
- *   &lt;type name="<b>com.gemstone.gemfire.modules.hibernate.EnumType</b>"&gt;
+ *   &lt;type name="<b>org.apache.geode.modules.hibernate.EnumType</b>"&gt;
  *     &lt;param name="enumClass"&gt;com.mycompany.MyEntity$MyEnum&lt;/param&gt;
  *     &lt;param name="type"&gt;12&lt;/param&gt;
  *   &lt;/type&gt;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCache.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCache.java
index 7548061..134bbf6 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCache.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCache.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
+package org.apache.geode.modules.hibernate;
 
 import java.util.Map;
 
@@ -22,11 +22,11 @@ import org.hibernate.cache.Cache;
 import org.hibernate.cache.CacheException;
 import org.hibernate.cache.Timestamper;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.internal.cache.LocalRegion;
 
 public class GemFireCache implements Cache {
   private Region region;
@@ -77,7 +77,7 @@ public class GemFireCache implements Cache {
           "GemFireCache: retrieved: " + key + "-->" + value);
       return value;
     }
-    catch (com.gemstone.gemfire.cache.CacheException e) {
+    catch (org.apache.geode.cache.CacheException e) {
       throw new CacheException(e);
     }
   }
@@ -171,7 +171,7 @@ public class GemFireCache implements Cache {
       GemFireCacheProvider.getLogger().debug(
           "GemFireCache: put " + key + "-->" + value);
     }
-    catch (com.gemstone.gemfire.cache.CacheException e) {
+    catch (org.apache.geode.cache.CacheException e) {
       throw new CacheException(e);
     }
   }
@@ -195,7 +195,7 @@ public class GemFireCache implements Cache {
     catch (EntryNotFoundException e) {
       // We can silently ignore this
     }
-    catch (com.gemstone.gemfire.cache.CacheException e) {
+    catch (org.apache.geode.cache.CacheException e) {
       throw new CacheException(e);
     }
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheListener.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheListener.java
index e684c7d..0738f36 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheListener.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheListener.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
+package org.apache.geode.modules.hibernate;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.util.CacheListenerAdapter;
 
 public class GemFireCacheListener extends CacheListenerAdapter implements
     Declarable {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheProvider.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheProvider.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheProvider.java
index b6db20a..2ccb5c0 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheProvider.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireCacheProvider.java
@@ -14,17 +14,17 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
-
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.modules.util.CreateRegionFunction;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
+package org.apache.geode.modules.hibernate;
+
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.modules.util.CreateRegionFunction;
+import org.apache.geode.modules.util.RegionConfiguration;
 import org.apache.logging.log4j.Logger;
 import org.hibernate.cache.Cache;
 import org.hibernate.cache.CacheException;
@@ -39,7 +39,7 @@ public class GemFireCacheProvider implements CacheProvider {
 
   private static final Logger logger = LogService.getLogger();
 
-  protected com.gemstone.gemfire.cache.Cache _cache;
+  protected org.apache.geode.cache.Cache _cache;
 
   private DistributedLockService distributedLockService;
 
@@ -175,7 +175,7 @@ public class GemFireCacheProvider implements CacheProvider {
         this.distributedLockService = existing;
       }
     } 
-    catch (com.gemstone.gemfire.cache.CacheException e) {
+    catch (org.apache.geode.cache.CacheException e) {
       throw new CacheException(e);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireQueryCacheFactory.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireQueryCacheFactory.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireQueryCacheFactory.java
index c019436..fba1d9f 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireQueryCacheFactory.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireQueryCacheFactory.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
+package org.apache.geode.modules.hibernate;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireRegionFactory.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireRegionFactory.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireRegionFactory.java
index 31e4551..088d0b1 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireRegionFactory.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/GemFireRegionFactory.java
@@ -14,18 +14,18 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.modules.hibernate.internal.*;
-import com.gemstone.gemfire.modules.util.Banner;
+package org.apache.geode.modules.hibernate;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.modules.hibernate.internal.*;
+import org.apache.geode.modules.util.Banner;
 import org.hibernate.cache.*;
 import org.hibernate.cache.access.AccessType;
 import org.hibernate.cfg.Settings;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/Access.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/Access.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/Access.java
index 86c6786..a14f7ac 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/Access.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/Access.java
@@ -14,12 +14,12 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerOperationException;
 import org.hibernate.cache.CacheException;
 import org.hibernate.cache.EntityRegion;
 import org.hibernate.cache.access.EntityRegionAccessStrategy;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ClientServerRegionFactoryDelegate.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ClientServerRegionFactoryDelegate.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ClientServerRegionFactoryDelegate.java
index f493e99..bbe3917 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ClientServerRegionFactoryDelegate.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ClientServerRegionFactoryDelegate.java
@@ -14,24 +14,24 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
-
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.modules.util.BootstrappingFunction;
-import com.gemstone.gemfire.modules.util.CreateRegionFunction;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
+package org.apache.geode.modules.hibernate.internal;
+
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.modules.util.BootstrappingFunction;
+import org.apache.geode.modules.util.CreateRegionFunction;
+import org.apache.geode.modules.util.RegionConfiguration;
 
 import java.util.*;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
 
 public class ClientServerRegionFactoryDelegate extends RegionFactoryDelegate {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/CollectionAccess.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/CollectionAccess.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/CollectionAccess.java
index f1898d8..d921ade 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/CollectionAccess.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/CollectionAccess.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.io.Serializable;
 import java.lang.reflect.Field;
@@ -29,11 +29,11 @@ import org.hibernate.cache.entry.CollectionCacheEntry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerOperationException;
 
 public class CollectionAccess implements
     CollectionRegionAccessStrategy {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityRegionWriter.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityRegionWriter.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityRegionWriter.java
index 5a4e5e1..d4f6f2f 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityRegionWriter.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityRegionWriter.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 
 import java.util.Properties;
@@ -22,10 +22,10 @@ import java.util.Properties;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.util.CacheWriterAdapter;
 
 public class EntityRegionWriter extends CacheWriterAdapter implements Declarable {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersion.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersion.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersion.java
index d5d63d2..9851d29 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersion.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersion.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import org.hibernate.cache.access.SoftLock;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersionImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersionImpl.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersionImpl.java
index 5f7971c..ad866a6 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersionImpl.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityVersionImpl.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityWrapper.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityWrapper.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityWrapper.java
index ab92dea..a829de6 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityWrapper.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/EntityWrapper.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
 
 public class EntityWrapper implements DataSerializable {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireBaseRegion.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireBaseRegion.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireBaseRegion.java
index 9e77a98..022187a 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireBaseRegion.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireBaseRegion.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -32,17 +32,17 @@ import org.hibernate.cache.Timestamper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory;
-import com.gemstone.gemfire.modules.util.ModuleStatistics;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.modules.hibernate.GemFireRegionFactory;
+import org.apache.geode.modules.util.ModuleStatistics;
 
 public class GemFireBaseRegion implements Region {
 
   /**
    * the backing region
    */
-  protected final com.gemstone.gemfire.cache.Region<Object, EntityWrapper> region;
+  protected final org.apache.geode.cache.Region<Object, EntityWrapper> region;
 
   /**
    * to determine if the operation should be forwarded to server
@@ -57,7 +57,7 @@ public class GemFireBaseRegion implements Region {
   
   protected final ModuleStatistics stats;
   
-  public GemFireBaseRegion(com.gemstone.gemfire.cache.Region<Object, EntityWrapper> region,
+  public GemFireBaseRegion(org.apache.geode.cache.Region<Object, EntityWrapper> region,
       boolean isClient, CacheDataDescription metadata, GemFireRegionFactory regionFactory) {
     this.region = region;
     this.isClientRegion = isClient;
@@ -68,7 +68,7 @@ public class GemFireBaseRegion implements Region {
 
   }
 
-  public com.gemstone.gemfire.cache.Region<Object, EntityWrapper> getGemFireRegion() {
+  public org.apache.geode.cache.Region<Object, EntityWrapper> getGemFireRegion() {
     return this.region;
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireCollectionRegion.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireCollectionRegion.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireCollectionRegion.java
index 620a332..5cb53ea 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireCollectionRegion.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireCollectionRegion.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import org.hibernate.cache.CacheDataDescription;
 import org.hibernate.cache.CacheException;
@@ -24,8 +24,8 @@ import org.hibernate.cache.access.CollectionRegionAccessStrategy;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.hibernate.GemFireRegionFactory;
 
 public class GemFireCollectionRegion extends GemFireBaseRegion implements CollectionRegion {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireEntityRegion.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireEntityRegion.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireEntityRegion.java
index 22ac466..0f514a4 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireEntityRegion.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireEntityRegion.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -36,11 +36,11 @@ import org.hibernate.cache.access.EntityRegionAccessStrategy;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory;
-import com.gemstone.gemfire.modules.util.ModuleStatistics;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.modules.hibernate.GemFireRegionFactory;
+import org.apache.geode.modules.util.ModuleStatistics;
 
 public class GemFireEntityRegion extends GemFireBaseRegion implements EntityRegion {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireQueryResultsRegion.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireQueryResultsRegion.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireQueryResultsRegion.java
index ce06b85..28c9095 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireQueryResultsRegion.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/GemFireQueryResultsRegion.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.util.Collections;
 import java.util.Map;
@@ -26,8 +26,8 @@ import org.hibernate.cache.TimestampsRegion;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
 
 public class GemFireQueryResultsRegion implements QueryResultsRegion, TimestampsRegion {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/KeyWrapper.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/KeyWrapper.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/KeyWrapper.java
index 8496631..dc8793f 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/KeyWrapper.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/KeyWrapper.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,8 +23,8 @@ import java.io.Serializable;
 
 import org.hibernate.cache.CacheKey;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
 
 /**
  * wraps {@link CacheKey}, and implements equals and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/NonStrictReadWriteAccess.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/NonStrictReadWriteAccess.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/NonStrictReadWriteAccess.java
index ad617e4..d6e9968 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/NonStrictReadWriteAccess.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/NonStrictReadWriteAccess.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import org.hibernate.cache.CacheException;
 import org.hibernate.cache.access.SoftLock;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadOnlyAccess.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadOnlyAccess.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadOnlyAccess.java
index 6f54067..e99210f 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadOnlyAccess.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadOnlyAccess.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import org.hibernate.cache.CacheException;
 import org.hibernate.cache.access.SoftLock;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadWriteAccess.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadWriteAccess.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadWriteAccess.java
index 3c80174..5597c97 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadWriteAccess.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/ReadWriteAccess.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 import org.hibernate.cache.CacheException;
 import org.slf4j.Logger;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/RegionFactoryDelegate.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/RegionFactoryDelegate.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/RegionFactoryDelegate.java
index 82a74b7..1891528 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/RegionFactoryDelegate.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/RegionFactoryDelegate.java
@@ -14,24 +14,24 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.modules.hibernate.GemFireCacheProvider;
-import com.gemstone.gemfire.modules.util.BootstrappingFunction;
-import com.gemstone.gemfire.modules.util.CreateRegionFunction;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.modules.hibernate.GemFireCacheProvider;
+import org.apache.geode.modules.util.BootstrappingFunction;
+import org.apache.geode.modules.util.CreateRegionFunction;
+import org.apache.geode.modules.util.RegionConfiguration;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 import java.util.Iterator;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 public class RegionFactoryDelegate  {
 
@@ -94,7 +94,7 @@ public class RegionFactoryDelegate  {
     regionConfig.setRegionName(regionName);
     regionConfig.setRegionAttributesId(regionType);
     regionConfig.setCacheWriterName(EntityRegionWriter.class.getCanonicalName());
-    com.gemstone.gemfire.cache.RegionFactory<Object, EntityWrapper> rFactory = this.cache
+    org.apache.geode.cache.RegionFactory<Object, EntityWrapper> rFactory = this.cache
         .createRegionFactory(RegionShortcut.valueOf(regionType));
     rFactory.setCacheWriter(new EntityRegionWriter());
     if (isLocalRegion) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/TransactionalAccess.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/TransactionalAccess.java b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/TransactionalAccess.java
index f12eab9..c8ec670 100644
--- a/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/TransactionalAccess.java
+++ b/extensions/geode-modules-hibernate/src/main/java/org/apache/geode/modules/hibernate/internal/TransactionalAccess.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.modules.hibernate.internal;
+package org.apache.geode.modules.hibernate.internal;
 
 public class TransactionalAccess extends Access {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Event.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Event.java b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Event.java
index 962c083..39eec22 100644
--- a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Event.java
+++ b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Event.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules;
+package org.apache.geode.modules;
 
 import java.util.Date;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/HibernateJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/HibernateJUnitTest.java b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/HibernateJUnitTest.java
index 223a33b..a9d6c64 100644
--- a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/HibernateJUnitTest.java
+++ b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/HibernateJUnitTest.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules;
-
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.modules.Owner.Status;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+package org.apache.geode.modules;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.modules.Owner.Status;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import org.hibernate.Query;
 import org.hibernate.Session;
 import org.hibernate.SessionFactory;
@@ -45,7 +45,7 @@ import java.util.List;
 import java.util.Properties;
 import java.util.logging.Level;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.assertEquals;
 
 @Category(IntegrationTest.class)
@@ -87,7 +87,7 @@ public class HibernateJUnitTest {
     cfg.setProperty("hibernate.hbm2ddl.auto", "update");
 
     cfg.setProperty("hibernate.cache.region.factory_class",
-        "com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory");
+        "org.apache.geode.modules.hibernate.GemFireRegionFactory");
     cfg.setProperty("hibernate.show_sql", "true");
     cfg.setProperty("hibernate.cache.use_query_cache", "true");
     //cfg.setProperty("gemfire.mcast-port", AvailablePort.getRandomAvailablePort(AvailablePort.JGROUPS)+"");
@@ -382,7 +382,7 @@ public class HibernateJUnitTest {
     cfg.setProperty("hibernate.hbm2ddl.auto", "update");
 
     cfg.setProperty("hibernate.cache.region.factory_class",
-        "com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory");
+        "org.apache.geode.modules.hibernate.GemFireRegionFactory");
     cfg.setProperty("hibernate.show_sql", "true");
     cfg.setProperty("hibernate.cache.use_query_cache", "true");
     cfg.setProperty(DistributionConfig.GEMFIRE_PREFIX + STATISTIC_SAMPLING_ENABLED, "true");

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Owner.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Owner.java b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Owner.java
index 8df6635..772f131 100644
--- a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Owner.java
+++ b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Owner.java
@@ -13,7 +13,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules;
+package org.apache.geode.modules;
 
 import java.util.ArrayList;
 import java.util.Collections;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Person.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Person.java b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Person.java
index 559363d..c98bb81 100644
--- a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Person.java
+++ b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/Person.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules;
+package org.apache.geode.modules;
 
 import java.util.HashSet;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/SecondVMTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/SecondVMTest.java b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/SecondVMTest.java
index bcfeab4..cdc8e07 100644
--- a/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/SecondVMTest.java
+++ b/extensions/geode-modules-hibernate/src/test/java/org/apache/geode/modules/SecondVMTest.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules;
+package org.apache.geode.modules;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.io.IOException;
 import java.util.Iterator;
@@ -30,13 +30,13 @@ import org.junit.experimental.categories.Category;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 
 @Category(IntegrationTest.class)
 @Ignore("Can this test be deleted?")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Event.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Event.hbm.xml b/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Event.hbm.xml
index 3ec08c9..2473641 100644
--- a/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Event.hbm.xml
+++ b/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Event.hbm.xml
@@ -19,7 +19,7 @@
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">
 
-<hibernate-mapping package="com.gemstone.gemfire.modules">
+<hibernate-mapping package="org.apache.geode.modules">
 	<class name="Event" table="EVENTS">
 		<cache usage="read-write"/>
 		<id name="id" column="EVENT_ID">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Person.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Person.hbm.xml b/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Person.hbm.xml
index 7c28734..2105b1d 100644
--- a/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Person.hbm.xml
+++ b/extensions/geode-modules-hibernate/src/test/resources/org/apache/geode/modules/Person.hbm.xml
@@ -19,7 +19,7 @@
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">
 
-<hibernate-mapping package="com.gemstone.gemfire.modules">
+<hibernate-mapping package="org.apache.geode.modules">
     <class name="Person" table="PERSON">
         <cache usage="read-write"/>
         <id name="id" column="PERSON_ID">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/AbstractSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/AbstractSessionCache.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/AbstractSessionCache.java
index 965a97f..7f2aedf 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/AbstractSessionCache.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/AbstractSessionCache.java
@@ -15,12 +15,12 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
+package org.apache.geode.modules.session.internal.common;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionStatistics;
-import com.gemstone.gemfire.modules.session.internal.filter.util.TypeAwareMap;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionStatistics;
+import org.apache.geode.modules.session.internal.filter.util.TypeAwareMap;
+import org.apache.geode.modules.util.RegionConfiguration;
 
 import java.util.Map;
 import javax.servlet.http.HttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/CacheProperty.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/CacheProperty.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/CacheProperty.java
index e26281e..3588022 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/CacheProperty.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/CacheProperty.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
+package org.apache.geode.modules.session.internal.common;
 
 /**
  * Used to define cache properties

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/ClientServerSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/ClientServerSessionCache.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/ClientServerSessionCache.java
index a23888c..5cb9543 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/ClientServerSessionCache.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/ClientServerSessionCache.java
@@ -15,21 +15,21 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
-
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.modules.util.BootstrappingFunction;
-import com.gemstone.gemfire.modules.util.CreateRegionFunction;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.RegionStatus;
+package org.apache.geode.modules.session.internal.common;
+
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.modules.util.BootstrappingFunction;
+import org.apache.geode.modules.util.CreateRegionFunction;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.RegionStatus;
 
 import java.util.List;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/PeerToPeerSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/PeerToPeerSessionCache.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/PeerToPeerSessionCache.java
index 878adaa..684ee81 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/PeerToPeerSessionCache.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/PeerToPeerSessionCache.java
@@ -15,20 +15,20 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.modules.session.catalina.callback.LocalSessionCacheLoader;
-import com.gemstone.gemfire.modules.session.catalina.callback.LocalSessionCacheWriter;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.RegionHelper;
-import com.gemstone.gemfire.modules.util.TouchPartitionedRegionEntriesFunction;
-import com.gemstone.gemfire.modules.util.TouchReplicatedRegionEntriesFunction;
+package org.apache.geode.modules.session.internal.common;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.modules.session.catalina.callback.LocalSessionCacheLoader;
+import org.apache.geode.modules.session.catalina.callback.LocalSessionCacheWriter;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.RegionHelper;
+import org.apache.geode.modules.util.TouchPartitionedRegionEntriesFunction;
+import org.apache.geode.modules.util.TouchReplicatedRegionEntriesFunction;
 
 import java.util.Map;
 import javax.servlet.http.HttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionCache.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionCache.java
index 7562dff..be8252c 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionCache.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionCache.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
+package org.apache.geode.modules.session.internal.common;
 
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.Region;
 
 import javax.servlet.http.HttpSession;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionExpirationCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionExpirationCacheListener.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionExpirationCacheListener.java
index 648e711..eccbd49 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionExpirationCacheListener.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/common/SessionExpirationCacheListener.java
@@ -15,12 +15,12 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.common;
+package org.apache.geode.modules.session.internal.common;
 
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.util.CacheListenerAdapter;
 
 import java.util.Properties;
 import javax.servlet.http.HttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/Constants.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/Constants.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/Constants.java
index 4ce8733..807da1d 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/Constants.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/Constants.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 /**
  * Various constant values used through the app
@@ -25,6 +25,6 @@ public class Constants {
   public static String GEMFIRE_SESSION_REQUEST = "_gemfire_session_request_";
 
   public static String SESSION_STATISTICS_MBEAN_NAME =
-      "com.gemstone:type=SessionStatistics,name=sessionStatistics";
+      "org.apache:type=SessionStatistics,name=sessionStatistics";
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/DummySessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/DummySessionManager.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/DummySessionManager.java
index 9628912..ce4f649 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/DummySessionManager.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/DummySessionManager.java
@@ -15,9 +15,9 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.AbstractSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.attributes.AbstractSessionAttributes;
 
 import java.util.HashMap;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireHttpSession.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireHttpSession.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireHttpSession.java
index 88380c6..0bf4c4a 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireHttpSession.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireHttpSession.java
@@ -15,15 +15,15 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Delta;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.AbstractSessionAttributes;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.SessionAttributes;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Delta;
+import org.apache.geode.Instantiator;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.modules.session.internal.filter.attributes.AbstractSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.attributes.SessionAttributes;
 
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
@@ -39,7 +39,7 @@ import javax.servlet.ServletContext;
 import javax.servlet.http.HttpSession;
 import javax.servlet.http.HttpSessionContext;
 
-import com.gemstone.gemfire.modules.util.ClassLoaderObjectInputStream;
+import org.apache.geode.modules.util.ClassLoaderObjectInputStream;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionException.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionException.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionException.java
index 3ce81be..895bcaf 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionException.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionException.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 /**
  * Exception class for Gemfire Session Cache specific exceptions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionManager.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionManager.java
index 272f3c8..f6378be 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionManager.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/GemfireSessionManager.java
@@ -15,29 +15,29 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
-
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.modules.session.bootstrap.AbstractCache;
-import com.gemstone.gemfire.modules.session.bootstrap.ClientServerCache;
-import com.gemstone.gemfire.modules.session.bootstrap.LifecycleTypeAdapter;
-import com.gemstone.gemfire.modules.session.bootstrap.PeerToPeerCache;
-import com.gemstone.gemfire.modules.session.internal.common.CacheProperty;
-import com.gemstone.gemfire.modules.session.internal.common.ClientServerSessionCache;
-import com.gemstone.gemfire.modules.session.internal.common.PeerToPeerSessionCache;
-import com.gemstone.gemfire.modules.session.internal.common.SessionCache;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.AbstractSessionAttributes;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.DeltaQueuedSessionAttributes;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.DeltaSessionAttributes;
-import com.gemstone.gemfire.modules.session.internal.filter.attributes.ImmediateSessionAttributes;
-import com.gemstone.gemfire.modules.session.internal.filter.util.TypeAwareMap;
-import com.gemstone.gemfire.modules.session.internal.jmx.SessionStatistics;
-import com.gemstone.gemfire.modules.util.RegionHelper;
+package org.apache.geode.modules.session.internal.filter;
+
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.modules.session.bootstrap.AbstractCache;
+import org.apache.geode.modules.session.bootstrap.ClientServerCache;
+import org.apache.geode.modules.session.bootstrap.LifecycleTypeAdapter;
+import org.apache.geode.modules.session.bootstrap.PeerToPeerCache;
+import org.apache.geode.modules.session.internal.common.CacheProperty;
+import org.apache.geode.modules.session.internal.common.ClientServerSessionCache;
+import org.apache.geode.modules.session.internal.common.PeerToPeerSessionCache;
+import org.apache.geode.modules.session.internal.common.SessionCache;
+import org.apache.geode.modules.session.internal.filter.attributes.AbstractSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.attributes.DeltaQueuedSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.attributes.DeltaSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.attributes.ImmediateSessionAttributes;
+import org.apache.geode.modules.session.internal.filter.util.TypeAwareMap;
+import org.apache.geode.modules.session.internal.jmx.SessionStatistics;
+import org.apache.geode.modules.util.RegionHelper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/ListenerEventType.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/ListenerEventType.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/ListenerEventType.java
index b040dda..cfb2d49 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/ListenerEventType.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/ListenerEventType.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 /**
  * Enumeration of all possible event types which can be listened for.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/SessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/SessionManager.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/SessionManager.java
index 9d8996c..c59624c 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/SessionManager.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/SessionManager.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import javax.servlet.http.HttpSession;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractDeltaSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractDeltaSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractDeltaSessionAttributes.java
index f46495d..0d36932 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractDeltaSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractDeltaSessionAttributes.java
@@ -15,11 +15,11 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Delta;
-import com.gemstone.gemfire.InvalidDeltaException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Delta;
+import org.apache.geode.InvalidDeltaException;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractSessionAttributes.java
index c4af041..4c4564c 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/AbstractSessionAttributes.java
@@ -15,11 +15,11 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.modules.session.internal.filter.GemfireHttpSession;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.modules.session.internal.filter.GemfireHttpSession;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaEvent.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaEvent.java
index 4c248dd..2bffadc 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaEvent.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaEvent.java
@@ -15,12 +15,12 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.modules.session.internal.filter.GemfireHttpSession;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.modules.session.internal.filter.GemfireHttpSession;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaQueuedSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaQueuedSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaQueuedSessionAttributes.java
index cb4f673..faa849d 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaQueuedSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaQueuedSessionAttributes.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Instantiator;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 



[57/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/BaseServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/BaseServiceTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/BaseServiceTest.java
deleted file mode 100644
index 29fae16..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/BaseServiceTest.java
+++ /dev/null
@@ -1,254 +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 com.vmware.geode.tools.pulse.tests.junit;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import org.apache.geode.test.junit.categories.UITest;
-import com.google.gson.JsonObject;
-import com.vmware.geode.tools.pulse.internal.json.JSONObject;
-import org.apache.http.HttpEntity;
-import org.apache.http.client.methods.CloseableHttpResponse;
-import org.apache.http.client.methods.HttpUriRequest;
-import org.apache.http.client.methods.RequestBuilder;
-import org.apache.http.cookie.Cookie;
-import org.apache.http.impl.client.BasicCookieStore;
-import org.apache.http.impl.client.CloseableHttpClient;
-import org.apache.http.impl.client.HttpClients;
-import org.apache.http.util.EntityUtils;
-import org.junit.After;
-import org.junit.Assert;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.experimental.categories.Category;
-
-import java.io.BufferedReader;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.net.URI;
-import java.util.List;
-import java.util.Properties;
-
-
-/**
- * Base class to be extended by other JUnit test classes. This class defines and automatically invokes test for testing server login-logout so no need to add
- * this test in each sub-class. It also provides doLogin(), doLogout() and print error functionality as protected
- * functions.
- *
- * <b>Sub-classes should ensure that they call doLogin() in @BeforeClass and doLogout() in @AfterClass otherwise tests will fail.</b>
- *
- *
- */
-@Ignore
-@Category(UITest.class)
-public abstract class BaseServiceTest {
-
-  protected static Properties propsForJUnit = new Properties();
-  protected static String strHost = null;
-  protected static String strPort = null;
-  protected static String LOGIN_URL;
-  protected static String LOGOUT_URL;
-  protected static String IS_AUTHENTICATED_USER_URL;
-  protected static String PULSE_UPDATE_URL;
-
-  protected static final String PULSE_UPDATE_PARAM = "pulseData";
-  protected static final String PULSE_UPDATE_1_VALUE = "{'ClusterSelectedRegion':{'regionFullPath':'/GlobalVilage_2/GlobalVilage_9'}}";
-  protected static final String PULSE_UPDATE_2_VALUE = "{'ClusterSelectedRegion':{'regionFullPath':'/Rubbish'}}";
-
-  protected static final String PULSE_UPDATE_3_VALUE = "{'ClusterSelectedRegionsMember':{'regionFullPath':'/GlobalVilage_2/GlobalVilage_9'}}";
-  protected static final String PULSE_UPDATE_4_VALUE = "{'ClusterSelectedRegionsMember':{'regionFullPath':'/Rubbish'}}";
-
-  protected static final String PULSE_UPDATE_5_VALUE = "{'MemberGatewayHub':{'memberName':'pnq-visitor1'}}";
-  protected static final String PULSE_UPDATE_6_VALUE = "{'MemberGatewayHub':{'memberName':'pnq-visitor2'}}";
-  protected static CloseableHttpClient httpclient = null;
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  @BeforeClass
-  public static void beforeClass() throws Exception {
-    InputStream stream = BaseServiceTest.class.getClassLoader().getResourceAsStream("pulse.properties");
-
-    try {
-      propsForJUnit.load(stream);
-    } catch (Exception exProps) {
-      System.out.println("BaseServiceTest :: Error loading properties from pulse.properties in classpath");
-    }
-    strHost = propsForJUnit.getProperty("pulse.host");
-    strPort = propsForJUnit.getProperty("pulse.port");
-    System.out.println(
-        "BaseServiceTest :: Loaded properties from classpath. Checking properties for hostname. Hostname found = " + strHost);
-    LOGIN_URL = "http://" + strHost + ":" + strPort + "/pulse/j_spring_security_check";
-    LOGOUT_URL = "http://" + strHost + ":" + strPort + "/pulse/clusterLogout";
-    IS_AUTHENTICATED_USER_URL = "http://" + strHost + ":" + strPort + "/pulse/authenticateUser";
-    PULSE_UPDATE_URL = "http://" + strHost + ":" + strPort + "/pulse/pulseUpdate";
-
-  }
-  /**
-  *
-  * @throws java.lang.Exception
-  */
-  @Before
-  public void setUp() throws Exception {
-    doLogout();
-    System.out.println("BaseServiceTest :: Setup done");
-  }
-
-  /**
-  *
-  * @throws java.lang.Exception
-  */
-  @After
-  public void tearDown() throws Exception {
-    doLogin();
-    System.out.println("BaseServiceTest :: Teardown done");
-  }
-
-  /**
-   * Login to pulse server and setup httpClient for tests
-   * To be called from setupBeforeClass in each test class
-   */
-  protected static void doLogin() throws Exception {
-    System.out.println("BaseServiceTest ::  Executing doLogin with user : admin, password : admin.");
-
-    CloseableHttpResponse loginResponse = null;
-    try{
-      BasicCookieStore cookieStore = new BasicCookieStore();
-      httpclient = HttpClients.custom().setDefaultCookieStore(cookieStore).build();
-      HttpUriRequest login = RequestBuilder.post().setUri(new URI(LOGIN_URL))
-        .addParameter("j_username", "admin").addParameter("j_password", "admin")
-        .build();
-      loginResponse = httpclient.execute(login);
-      try {
-           HttpEntity entity = loginResponse.getEntity();
-           EntityUtils.consume(entity);
-           System.out.println("BaseServiceTest :: HTTP request status : " + loginResponse.getStatusLine());
-
-           List<Cookie> cookies = cookieStore.getCookies();
-           if (cookies.isEmpty()) {
-           } else {
-               for (int i = 0; i < cookies.size(); i++) {
-               }
-           }
-      } finally {
-         if(loginResponse != null)
-           loginResponse.close();
-      }
-    } catch(Exception failed) {
-      logException(failed);
-      throw failed;
-    }
-
-    System.out.println("BaseServiceTest ::  Executed doLogin");
-  }
-
-  /**
-   * Logout to pulse server and close httpClient
-   * To be called from setupAfterClass in each test class
-   */
-  protected static void doLogout() throws Exception {
-    System.out.println("BaseServiceTest ::  Executing doLogout with user : admin, password : admin.");
-    if(httpclient != null){
-      CloseableHttpResponse logoutResponse = null;
-      try{
-        HttpUriRequest logout = RequestBuilder.get().setUri(new URI(LOGOUT_URL))
-            .build();
-        logoutResponse = httpclient.execute(logout);
-        try {
-             HttpEntity entity = logoutResponse.getEntity();
-             EntityUtils.consume(entity);
-        } finally {
-           if(logoutResponse != null)
-             logoutResponse.close();
-           httpclient.close();
-           httpclient = null;
-        }
-      } catch(Exception failed) {
-        logException(failed);
-        throw failed;
-      }
-      System.out.println("BaseServiceTest ::  Executed doLogout");
-    } else{
-      System.out.println("BaseServiceTest ::  User NOT logged-in");
-    }
-  }
-
-  /**
-   * Print exception string to system.out
-   *
-   * @param failed
-   */
-  protected static void logException(Exception failed){
-    StringWriter sw = new StringWriter();
-    PrintWriter pw = new PrintWriter(sw);
-    failed.printStackTrace(pw);
-    System.out.println("BaseServiceTest :: Logging exception details : " + sw.getBuffer().toString());
-  }
-
-  /**
-  *
-  * Tests that service returns json object
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
-  */
-  @Test
-  public void testServerLoginLogout() {
-      System.out.println("BaseServiceTest ::  ------TESTCASE BEGIN : SERVER LOGIN-LOGOUT------");
-      try{
-          doLogin();
-
-          HttpUriRequest pulseupdate = RequestBuilder.get()
-            .setUri(new URI(IS_AUTHENTICATED_USER_URL))
-            .build();
-          CloseableHttpResponse response = httpclient.execute(pulseupdate);
-          try {
-            HttpEntity entity = response.getEntity();
-
-            System.out.println("BaseServiceTest :: HTTP request status : " + response.getStatusLine());
-
-            BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-            StringWriter sw = new StringWriter();
-            PrintWriter pw = new PrintWriter(sw);
-            String sz = null;
-            while((sz = respReader.readLine()) != null){
-              pw.print(sz);
-            }
-            String jsonResp = sw.getBuffer().toString();
-            System.out.println("BaseServiceTest :: JSON response returned : " + jsonResp);
-            EntityUtils.consume(entity);
-
-            JsonNode jsonObj = mapper.readTree(jsonResp);
-            boolean isUserLoggedIn = jsonObj.get("isUserLoggedIn").booleanValue();
-            Assert.assertNotNull("BaseServiceTest :: Server returned null response in 'isUserLoggedIn'", isUserLoggedIn);
-            Assert.assertTrue("BaseServiceTest :: User login failed for this username, password", (isUserLoggedIn == true));
-          } finally {
-            response.close();
-          }
-
-          doLogout();
-      } catch(Exception failed) {
-          logException(failed);
-          Assert.fail("Exception ! ");
-      }
-      System.out.println("BaseServiceTest ::  ------TESTCASE END : SERVER LOGIN-LOGOUT------");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
deleted file mode 100644
index 22adcaf..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
+++ /dev/null
@@ -1,340 +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 com.vmware.geode.tools.pulse.tests.junit;
-
-import java.io.BufferedReader;
-import java.io.InputStreamReader;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.net.URI;
-
-import org.apache.http.HttpEntity;
-import org.apache.http.client.methods.CloseableHttpResponse;
-import org.apache.http.client.methods.HttpUriRequest;
-import org.apache.http.client.methods.RequestBuilder;
-import org.apache.http.util.EntityUtils;
-import org.junit.*;
-
-import com.vmware.geode.tools.pulse.internal.json.JSONArray;
-import com.vmware.geode.tools.pulse.internal.json.JSONObject;
-
-/**
- * JUnit Tests for ClusterSelectedRegionService in the back-end server for region detail page
- *
- *
- */
-@Ignore
-public class ClusterSelectedRegionServiceTest extends BaseServiceTest {
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @BeforeClass
-  public static void setUpBeforeClass() throws Exception {
-    doLogin();
-    System.out.println("\n\nClusterSelectedRegionServiceTest :: Setup done");
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @AfterClass
-  public static void tearDownAfterClass() throws Exception {
-    doLogout();
-    System.out.println("ClusterSelectedRegionServiceTest :: Teardown done");
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @Override
-  @Before
-  public void setUp() throws Exception {
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @Override
-  @After
-  public void tearDown() throws Exception {
-  }
-
-  /**
-   * Tests that service returns json object
-   *
-   */
-  @Test
-  public void testResponseNotNull() {
-    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR CLUSTER REGIONS------");
-    if(httpclient != null){
-        try{
-            HttpUriRequest pulseupdate = RequestBuilder.post()
-                .setUri(new URI(PULSE_UPDATE_URL))
-                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
-                .build();
-            CloseableHttpResponse response = httpclient.execute(pulseupdate);
-            try {
-              HttpEntity entity = response.getEntity();
-
-              System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
-              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-              StringWriter sw = new StringWriter();
-              PrintWriter pw = new PrintWriter(sw);
-              String sz = null;
-              while((sz = respReader.readLine()) != null){
-                pw.print(sz);
-              }
-              String jsonResp = sw.getBuffer().toString();
-              System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
-              EntityUtils.consume(entity);
-
-              JSONObject jsonObj = new JSONObject(jsonResp);
-              Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion", jsonObj.getJSONObject("ClusterSelectedRegion"));
-            } finally {
-              response.close();
-            }
-        } catch(Exception failed) {
-          logException(failed);
-          Assert.fail("Exception ! ");
-        }
-    } else {
-      Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
-    }
-    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR CLUSTER REGIONS------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same logged in user
-  *
-  */
-  @Test
-  public void testResponseUsername() {
-    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGIONS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
-               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion", clusterSelectedRegionObj);
-               String szUser = clusterSelectedRegionObj.getString("userName");
-               Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned wrong user name. Expected was admin. Server returned = " + szUser, szUser, "admin");
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGIONS------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseRegionPathMatches() {
-    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : REGION PATH IN RESPONSE CHECK FOR CLUSTER REGIONS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
-               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion",clusterSelectedRegionObj);
-               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
-               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for selectedRegion",jsonObjRegion);
-               Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'path' of region",jsonObjRegion.has("path"));
-               String szPath = jsonObjRegion.getString("path");
-               Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned wrong region path. Expected region path = /GlobalVilage_2/GlobalVilage_9 , actual region path = " + szPath, szPath, "/GlobalVilage_2/GlobalVilage_9");
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : REGION PATH IN RESPONSE CHECK FOR CLUSTER REGIONS------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseNonExistentRegion() {
-    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NON-EXISTENT REGION CHECK FOR CLUSTER REGIONS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_2_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
-               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion",clusterSelectedRegionObj);
-               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
-               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for selectedRegion",jsonObjRegion);
-               Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return error on non-existent region",jsonObjRegion.has("errorOnRegion"));
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NON-EXISTENT REGION CHECK FOR CLUSTER REGIONS------\n");
-  }
-
-  /**
-  *
-  * Tests that service returns json object
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseMemerberCount() {
-   System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : MISMATCHED MEMBERCOUNT FOR REGION CHECK FOR CLUSTER REGIONS------");
-   if(httpclient != null){
-       try{
-           HttpUriRequest pulseupdate = RequestBuilder.post()
-               .setUri(new URI(PULSE_UPDATE_URL))
-               .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
-               .build();
-           CloseableHttpResponse response = httpclient.execute(pulseupdate);
-           try {
-             HttpEntity entity = response.getEntity();
-
-             System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
-
-             BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-             StringWriter sw = new StringWriter();
-             PrintWriter pw = new PrintWriter(sw);
-             String sz = null;
-             while((sz = respReader.readLine()) != null){
-               pw.print(sz);
-             }
-             String jsonResp = sw.getBuffer().toString();
-             System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
-             EntityUtils.consume(entity);
-
-             JSONObject jsonObj = new JSONObject(jsonResp);
-             JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
-             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null ClusterSelectedRegion",clusterSelectedRegionObj);
-             JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
-             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null for selectedRegion",jsonObjRegion);
-             Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'memberCount' of region",jsonObjRegion.has("memberCount"));
-             int memberCount = jsonObjRegion.getInt("memberCount");
-             Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'members' of region",jsonObjRegion.has("members"));
-             JSONArray arrMembers = jsonObjRegion.getJSONArray("members");
-             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response in selectedRegion",arrMembers);
-             int members = arrMembers.length();
-             Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned mismatched member count and region members", members, memberCount);
-           } finally {
-             response.close();
-           }
-       } catch(Exception failed) {
-         logException(failed);
-         Assert.fail("Exception ! ");
-       }
-   } else {
-     Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
-   }
-   System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : MISMATCHED MEMBERCOUNT FOR REGION CHECK FOR CLUSTER REGIONS------\n");
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
deleted file mode 100644
index 54b96ba..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
+++ /dev/null
@@ -1,354 +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 com.vmware.geode.tools.pulse.tests.junit;
-
-import java.io.BufferedReader;
-import java.io.InputStreamReader;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.net.URI;
-import java.util.Iterator;
-
-import org.apache.http.HttpEntity;
-import org.apache.http.client.methods.CloseableHttpResponse;
-import org.apache.http.client.methods.HttpUriRequest;
-import org.apache.http.client.methods.RequestBuilder;
-import org.apache.http.util.EntityUtils;
-import org.junit.*;
-
-import com.vmware.geode.tools.pulse.internal.json.JSONObject;
-
-/**
- * JUnit Tests for ClusterSelectedRegionsMemberService in the back-end server for region detail page
- *
- *
- */
-@Ignore
-public class ClusterSelectedRegionsMemberServiceTest  extends BaseServiceTest {
-
-  /**
-   * @throws java.lang.Exception
-   *
-   */
-  @BeforeClass
-  public static void setUpBeforeClass() throws Exception {
-    doLogin();
-    System.out.println("\n\nClusterSelectedRegionsMemberServiceTest :: Setup done");
-  }
-
-  /**
-   * @throws java.lang.Exception
-   *
-   */
-  @AfterClass
-  public static void tearDownAfterClass() throws Exception {
-    doLogout();
-    System.out.println("ClusterSelectedRegionsMemberServiceTest :: Teardown done");
-  }
-
-  /**
-   * @throws java.lang.Exception
-   */
-  @Override
-  @Before
-  public void setUp() throws Exception {
-    System.out.println("running setup -- ClusterSelectedRegionsMemberServiceTest");
-  }
-
-  /**
-   * @throws java.lang.Exception
-   */
-  @Override
-  @After
-  public void tearDown() throws Exception {
-    System.out.println("running teardown -- ClusterSelectedRegionsMemberServiceTest");
-  }
-
-  /**
-   * Tests that service returns json object
-   *
-   */
-  @Test
-  public void testResponseNotNull() {
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-    if(httpclient != null){
-        try{
-            HttpUriRequest pulseupdate = RequestBuilder.post()
-                .setUri(new URI(PULSE_UPDATE_URL))
-                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
-                .build();
-            CloseableHttpResponse response = httpclient.execute(pulseupdate);
-            try {
-              HttpEntity entity = response.getEntity();
-
-              System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
-
-              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-              StringWriter sw = new StringWriter();
-              PrintWriter pw = new PrintWriter(sw);
-              String sz = null;
-              while((sz = respReader.readLine()) != null){
-                pw.print(sz);
-              }
-              String jsonResp = sw.getBuffer().toString();
-              System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
-              EntityUtils.consume(entity);
-
-              JSONObject jsonObj = new JSONObject(jsonResp);
-              Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember", jsonObj.getJSONObject("ClusterSelectedRegionsMember"));
-            } finally {
-              response.close();
-            }
-        } catch(Exception failed) {
-          logException(failed);
-          Assert.fail("Exception ! ");
-        }
-    } else {
-      Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
-    }
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-  }
-
-  /**
-  *
-  * Tests that response is for same logged in user
-  *
-  */
-  @Test
-  public void testResponseUsername() {
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember", clusterSelectedRegionObj);
-               Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'userName' in request",clusterSelectedRegionObj.has("userName"));
-               String szUser = clusterSelectedRegionObj.getString("userName");
-               Assert.assertEquals("ClusterSelectedRegionsMemberServiceTest :: Server returned wrong user name. Expected was admin. Server returned = " + szUser, szUser, "admin");
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  *
-  */
-  @Test
-  public void testResponseRegionOnMemberInfoMatches() {
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : MEMBER INFO RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
-               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for selectedRegionsMembers",jsonObjRegion);
-               Iterator<String> itrMemberNames = jsonObjRegion.keys();
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null region on member info", itrMemberNames);
-               while(itrMemberNames.hasNext()){
-                 String szMemberName = itrMemberNames.next();
-                 Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null member name", szMemberName);
-                 Assert.assertTrue("Server did not return member details",jsonObjRegion.has(szMemberName));
-                 JSONObject jsonMemberObj = jsonObjRegion.getJSONObject(szMemberName);
-
-                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'regionFullPath' of region on member",jsonMemberObj.has("regionFullPath"));
-                 String szPath = jsonMemberObj.getString("regionFullPath");
-                 Assert.assertEquals("ClusterSelectedRegionsMemberServiceTest :: Server returned wrong region path for region on member", szPath, "/GlobalVilage_2/GlobalVilage_9");
-               }
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : MEMBER INFO RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  *
-  */
-  @Test
-  public void testResponseNonExistentRegion() {
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NON-EXISTENT REGION CHECK FOR CLUSTER REGION MEMBERS------");
-     if(httpclient != null){
-         try{
-           System.out.println("Test for non-existent region : /Rubbish");
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_4_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
-               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null for selectedRegionsMembers",jsonObjRegion);
-               Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return error on non-existent region",jsonObjRegion.has("errorOnRegion"));
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NON-EXISTENT REGION CHECK FOR CLUSTER REGION MEMBERS------");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  *
-  */
-  @Test
-  public void testResponseRegionOnMemberAccessor() {
-    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : ACCESSOR RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
-               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for selectedRegionsMembers",jsonObjRegion);
-               Iterator<String> itrMemberNames = jsonObjRegion.keys();
-               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null region on member info", itrMemberNames);
-               while(itrMemberNames.hasNext()){
-                 String szMemberName = itrMemberNames.next();
-                 Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null member name", szMemberName);
-                 Assert.assertTrue("Server did not return member details",jsonObjRegion.has(szMemberName));
-                 JSONObject jsonMemberObj = jsonObjRegion.getJSONObject(szMemberName);
-
-                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'accessor' of region on member",jsonMemberObj.has("accessor"));
-                 String szAccessor = jsonMemberObj.getString("accessor");
-                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server returned non-boolean value for accessor attribute", ((szAccessor.equalsIgnoreCase("True"))
-                         || (szAccessor.equalsIgnoreCase("False"))) );
-               }
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
-     }
-     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : ACCESSOR RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
deleted file mode 100644
index 0a2fe0a..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
+++ /dev/null
@@ -1,412 +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 com.vmware.geode.tools.pulse.tests.junit;
-
-import java.io.BufferedReader;
-import java.io.InputStreamReader;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.net.URI;
-
-import org.apache.http.HttpEntity;
-import org.apache.http.client.methods.CloseableHttpResponse;
-import org.apache.http.client.methods.HttpUriRequest;
-import org.apache.http.client.methods.RequestBuilder;
-import org.apache.http.util.EntityUtils;
-import org.junit.*;
-
-import com.vmware.geode.tools.pulse.internal.json.JSONArray;
-import com.vmware.geode.tools.pulse.internal.json.JSONObject;
-
-/**
- * JUnit Tests for MemberGatewayHubService in the back-end server for region detail page
- *
- *
- */
-@Ignore
-public class MemberGatewayHubServiceTest extends BaseServiceTest {
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @BeforeClass
-  public static void setUpBeforeClass() throws Exception {
-    doLogin();
-    System.out.println("\n\nMemberGatewayHubServiceTest :: Setup done");
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @AfterClass
-  public static void tearDownAfterClass() throws Exception {
-    doLogout();
-    System.out.println("MemberGatewayHubServiceTest :: Teardown done");
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @Override
-  @Before
-  public void setUp() throws Exception {
-  }
-
-  /**
-   *
-   * @throws java.lang.Exception
-   */
-  @Override
-  @After
-  public void tearDown() throws Exception {
-  }
-
-  /**
-   * Tests that service returns json object
-   *
-   */
-  @Test
-  public void testResponseNotNull() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE --------");
-    if(httpclient != null){
-        try{
-            HttpUriRequest pulseupdate = RequestBuilder.post()
-                .setUri(new URI(PULSE_UPDATE_URL))
-                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
-                .build();
-            CloseableHttpResponse response = httpclient.execute(pulseupdate);
-            try {
-              HttpEntity entity = response.getEntity();
-
-              System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-              StringWriter sw = new StringWriter();
-              PrintWriter pw = new PrintWriter(sw);
-              String sz = null;
-              while((sz = respReader.readLine()) != null){
-                pw.print(sz);
-              }
-              String jsonResp = sw.getBuffer().toString();
-              System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-              EntityUtils.consume(entity);
-
-              JSONObject jsonObj = new JSONObject(jsonResp);
-              Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", jsonObj.getJSONObject("MemberGatewayHub"));
-            } finally {
-              response.close();
-            }
-        } catch(Exception failed) {
-          logException(failed);
-          Assert.fail("Exception ! ");
-        }
-    } else {
-      Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-    }
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
- /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseIsGatewaySender() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : IS GATEWAY SENDER IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
-               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
-               Assert.assertEquals("MemberGatewayHubServiceTest :: Server returned wrong value for 'isGatewaySender'. Expected 'isGatewaySender' = true, actual 'isGatewaySender' = " + boolIsGatewaySender, boolIsGatewaySender, true);
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-     }
-     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : IS GATEWAY SENDER IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseGatewaySenderCount() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : GATEWAY SENDER COUNT IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
-               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'gatewaySenders' for member", memberGatewayHubObj.has("gatewaySenders"));
-               JSONArray arrGatewaySender = memberGatewayHubObj.getJSONArray("gatewaySenders");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'gatewaySenders'", arrGatewaySender);
-               Assert.assertTrue( "MemberGatewayHubServiceTest :: Server returned mis-matched values for 'isGatewaySender' and gateway senders array count", ((boolIsGatewaySender && (arrGatewaySender.length() > 0)) || ((! boolIsGatewaySender) && (arrGatewaySender.length() == 0))) );
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-     }
-     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : GATEWAY SENDER COUNT IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseGatewaySenderProperties() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : GATEWAY SENDER PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
-               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'gatewaySenders' for member", memberGatewayHubObj.has("gatewaySenders"));
-               JSONArray arrGatewaySender = memberGatewayHubObj.getJSONArray("gatewaySenders");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'gatewaySenders'", arrGatewaySender);
-               Assert.assertTrue( "MemberGatewayHubServiceTest :: Server returned mis-matched values for 'isGatewaySender' and gateway senders array count", ((boolIsGatewaySender && (arrGatewaySender.length() > 0)) || ((! boolIsGatewaySender) && (arrGatewaySender.length() == 0))) );
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'remoteDSId' for member", ((JSONObject)arrGatewaySender.get(0)).has("remoteDSId"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'eventsExceedingAlertThreshold' for member", ((JSONObject)arrGatewaySender.get(0)).has("eventsExceedingAlertThreshold"));
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-     }
-     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : GATEWAY SENDER PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseAsyncEventQueueProperties() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : ASYNC EVENT QUEUE PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventQueues' for member", memberGatewayHubObj.has("asyncEventQueues"));
-               JSONArray arrAsyncEventQueues = memberGatewayHubObj.getJSONArray("asyncEventQueues");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'asyncEventQueues'", arrAsyncEventQueues);
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'id' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("id"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'primary' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("primary"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'senderType' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("senderType"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchSize' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchSize"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchTimeInterval' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchTimeInterval"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchConflationEnabled' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchConflationEnabled"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventListener' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("asyncEventListener"));
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'queueSize' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("queueSize"));
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-     }
-     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : ASYNC EVENT QUEUE PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
-  /**
-  *
-  * Tests that response is for same region
-  *
-  * Test method for {@link com.vmware.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
-  *
-  */
-  @Test
-  public void testResponseNoAsyncEventQueues() {
-    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : NO ASYNC EVENT QUEUES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
-     if(httpclient != null){
-         try{
-             HttpUriRequest pulseupdate = RequestBuilder.post()
-                 .setUri(new URI(PULSE_UPDATE_URL))
-                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_6_VALUE)
-                 .build();
-             CloseableHttpResponse response = httpclient.execute(pulseupdate);
-             try {
-               HttpEntity entity = response.getEntity();
-
-               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
-
-               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
-               StringWriter sw = new StringWriter();
-               PrintWriter pw = new PrintWriter(sw);
-               String sz = null;
-               while((sz = respReader.readLine()) != null){
-                 pw.print(sz);
-               }
-               String jsonResp = sw.getBuffer().toString();
-               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
-               EntityUtils.consume(entity);
-
-               JSONObject jsonObj = new JSONObject(jsonResp);
-               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
-
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventQueues' for member", memberGatewayHubObj.has("asyncEventQueues"));
-               JSONArray arrAsyncEventQueues = memberGatewayHubObj.getJSONArray("asyncEventQueues");
-               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'asyncEventQueues'", arrAsyncEventQueues);
-               Assert.assertTrue("MemberGatewayHubServiceTest :: Server returned non-empty array for member 'pnq-visitor2' which has no event queues", (arrAsyncEventQueues.length() == 0));
-             } finally {
-               response.close();
-             }
-         } catch(Exception failed) {
-           logException(failed);
-           Assert.fail("Exception ! ");
-         }
-     } else {
-       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
-     }
-     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : NO ASYNC EVENT QUEUES PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
-  }
-
-
-}


[49/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaSessionAttributes.java
index 8cc9866..85723ec 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/DeltaSessionAttributes.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Instantiator;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/ImmediateSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/ImmediateSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/ImmediateSessionAttributes.java
index 15936ba..15dd522 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/ImmediateSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/ImmediateSessionAttributes.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Instantiator;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/QueuedSessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/QueuedSessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/QueuedSessionAttributes.java
index 8d20b43..e1aeb0b 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/QueuedSessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/QueuedSessionAttributes.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Instantiator;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/SessionAttributes.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/SessionAttributes.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/SessionAttributes.java
index b3b0cef..a882712 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/SessionAttributes.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/attributes/SessionAttributes.java
@@ -15,10 +15,10 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.attributes;
+package org.apache.geode.modules.session.internal.filter.attributes;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.modules.session.internal.filter.GemfireHttpSession;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.modules.session.internal.filter.GemfireHttpSession;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/NamedThreadFactory.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/NamedThreadFactory.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/NamedThreadFactory.java
index 7491cf0..dbd5894 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/NamedThreadFactory.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/NamedThreadFactory.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.util;
+package org.apache.geode.modules.session.internal.filter.util;
 
 import java.lang.Thread.UncaughtExceptionHandler;
 import java.util.concurrent.ThreadFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/ThreadLocalSession.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/ThreadLocalSession.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/ThreadLocalSession.java
index 996b1fd..13af79c 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/ThreadLocalSession.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/ThreadLocalSession.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.util;
+package org.apache.geode.modules.session.internal.filter.util;
 
 import javax.servlet.http.HttpSession;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/TypeAwareMap.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/TypeAwareMap.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/TypeAwareMap.java
index 705bafd..7000033 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/TypeAwareMap.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/filter/util/TypeAwareMap.java
@@ -15,9 +15,9 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter.util;
+package org.apache.geode.modules.session.internal.filter.util;
 
-import com.gemstone.gemfire.modules.session.internal.common.CacheProperty;
+import org.apache.geode.modules.session.internal.common.CacheProperty;
 
 import java.util.HashMap;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatistics.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatistics.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatistics.java
index 9f945da..5fba0a5 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatistics.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatistics.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.jmx;
+package org.apache.geode.modules.session.internal.jmx;
 
 import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicLong;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatisticsMXBean.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatisticsMXBean.java b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatisticsMXBean.java
index 33cfc3e..c219e3a 100644
--- a/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatisticsMXBean.java
+++ b/extensions/geode-modules-session-internal/src/main/java/org/apache/geode/modules/session/internal/jmx/SessionStatisticsMXBean.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.modules.session.internal.jmx;
+package org.apache.geode.modules.session.internal.jmx;
 
 /**
  * MXBean interface to retrieve Session statistics

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/build.gradle
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/build.gradle b/extensions/geode-modules-session/build.gradle
index 191b251..f068dde 100644
--- a/extensions/geode-modules-session/build.gradle
+++ b/extensions/geode-modules-session/build.gradle
@@ -33,7 +33,7 @@ dependencies {
 
 jar {
   manifest {
-    attributes 'Main-Class': 'com.gemstone.gemfire.modules.session.installer.Installer'
+    attributes 'Main-Class': 'org.apache.geode.modules.session.installer.Installer'
   }
   baseName = 'geode-modules-session'
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionCachingFilter.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionCachingFilter.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionCachingFilter.java
index c644235..ed1ffab 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionCachingFilter.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionCachingFilter.java
@@ -15,13 +15,13 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.filter;
+package org.apache.geode.modules.session.filter;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.modules.session.internal.filter.GemfireHttpSession;
-import com.gemstone.gemfire.modules.session.internal.filter.GemfireSessionManager;
-import com.gemstone.gemfire.modules.session.internal.filter.SessionManager;
-import com.gemstone.gemfire.modules.session.internal.filter.util.ThreadLocalSession;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.modules.session.internal.filter.GemfireHttpSession;
+import org.apache.geode.modules.session.internal.filter.GemfireSessionManager;
+import org.apache.geode.modules.session.internal.filter.SessionManager;
+import org.apache.geode.modules.session.internal.filter.util.ThreadLocalSession;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionListener.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionListener.java
index 7973bc5..929740b 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionListener.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/filter/SessionListener.java
@@ -15,9 +15,9 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.filter;
+package org.apache.geode.modules.session.filter;
 
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
index 1d16494..2343c5b 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/Installer.java
@@ -15,13 +15,13 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer;
+package org.apache.geode.modules.session.installer;
 
-import com.gemstone.gemfire.modules.session.installer.args.Argument;
-import com.gemstone.gemfire.modules.session.installer.args.ArgumentProcessor;
-import com.gemstone.gemfire.modules.session.installer.args.ArgumentValues;
-import com.gemstone.gemfire.modules.session.installer.args.UnknownArgumentHandler;
-import com.gemstone.gemfire.modules.session.installer.args.UsageException;
+import org.apache.geode.modules.session.installer.args.Argument;
+import org.apache.geode.modules.session.installer.args.ArgumentProcessor;
+import org.apache.geode.modules.session.installer.args.ArgumentValues;
+import org.apache.geode.modules.session.installer.args.UnknownArgumentHandler;
+import org.apache.geode.modules.session.installer.args.UsageException;
 import org.w3c.dom.Document;
 import org.w3c.dom.Element;
 import org.w3c.dom.Node;
@@ -45,10 +45,10 @@ import java.io.OutputStream;
 public class Installer {
 
   private static final String GEMFIRE_FILTER_CLASS =
-      "com.gemstone.gemfire.modules.session.filter.SessionCachingFilter";
+      "org.apache.geode.modules.session.filter.SessionCachingFilter";
 
   private static final String GEMFIRE_LISTENER_CLASS =
-      "com.gemstone.gemfire.modules.session.filter.SessionListener";
+      "org.apache.geode.modules.session.filter.SessionListener";
 
   private ArgumentValues argValues;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/JarClassLoader.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/JarClassLoader.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/JarClassLoader.java
index 986ddce..4ddb278 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/JarClassLoader.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/JarClassLoader.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer;
+package org.apache.geode.modules.session.installer;
 
 import java.io.Closeable;
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/Argument.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/Argument.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/Argument.java
index 1125c1b..82ed232 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/Argument.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/Argument.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 import java.util.ArrayList;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentHandler.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentHandler.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentHandler.java
index 97c8108..28887d8 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentHandler.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentHandler.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 /**
  * Interface specifying the requirements for objects wiching to be able to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentProcessor.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentProcessor.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentProcessor.java
index 04ecfab..4ed3061 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentProcessor.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentProcessor.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 import java.util.ArrayList;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentValues.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentValues.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentValues.java
index cd412da..22ab124 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentValues.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/ArgumentValues.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 import java.util.ArrayList;
 import java.util.LinkedHashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/URLArgumentHandler.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/URLArgumentHandler.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/URLArgumentHandler.java
index bb4b53a..78082ce 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/URLArgumentHandler.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/URLArgumentHandler.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 import java.io.File;
 import java.net.MalformedURLException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UnknownArgumentHandler.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UnknownArgumentHandler.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UnknownArgumentHandler.java
index 4d52f62..968a008 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UnknownArgumentHandler.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UnknownArgumentHandler.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 /**
  * Interface defining unknown argument handlers, given the opportunity to either

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UsageException.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UsageException.java b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UsageException.java
index 0879417..21dc9c3 100644
--- a/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UsageException.java
+++ b/extensions/geode-modules-session/src/main/java/org/apache/geode/modules/session/installer/args/UsageException.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.installer.args;
+package org.apache.geode.modules.session.installer.args;
 
 /**
  * Invalid usage exception.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/installer/InstallerJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/installer/InstallerJUnitTest.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/installer/InstallerJUnitTest.java
index 98e5aac..272e6de 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/installer/InstallerJUnitTest.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/installer/InstallerJUnitTest.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.installer;
+package org.apache.geode.modules.session.installer;
 
 import static org.junit.Assert.*;
 
@@ -23,8 +23,8 @@ import java.io.File;
 import java.io.FileInputStream;
 import java.io.InputStream;
 
-import com.gemstone.gemfire.internal.FileUtil;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.internal.FileUtil;
+import org.apache.geode.test.junit.categories.UnitTest;
 
 import org.apache.commons.io.IOUtils;
 import org.junit.Rule;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/AbstractListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/AbstractListener.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/AbstractListener.java
index f9dbb62..de0d1c3 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/AbstractListener.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/AbstractListener.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import java.util.ArrayList;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/BasicServlet.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/BasicServlet.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/BasicServlet.java
index 5804317..32ddc42 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/BasicServlet.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/BasicServlet.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import java.io.IOException;
 import javax.servlet.ServletConfig;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/Callback.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/Callback.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/Callback.java
index fa5b64f..044a364 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/Callback.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/Callback.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import javax.servlet.ServletException;
 import javax.servlet.http.HttpServletRequest;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CallbackServlet.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CallbackServlet.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CallbackServlet.java
index 3050280..89287b2 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CallbackServlet.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CallbackServlet.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import java.io.IOException;
 import javax.servlet.ServletException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CommonTests.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CommonTests.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CommonTests.java
index 51c3dec..c1677a1 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CommonTests.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/CommonTests.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import static org.junit.Assert.*;
 
@@ -33,7 +33,7 @@ import javax.servlet.http.HttpServletResponse;
 import javax.servlet.http.HttpSession;
 import javax.servlet.http.HttpSessionAttributeListener;
 
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
 import com.mockrunner.mock.web.MockHttpServletRequest;
 import com.mockrunner.mock.web.MockHttpServletResponse;
 import com.mockrunner.mock.web.MockHttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionAttributeListenerImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionAttributeListenerImpl.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionAttributeListenerImpl.java
index 6d5679a..e2f268f 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionAttributeListenerImpl.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionAttributeListenerImpl.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import javax.servlet.http.HttpSessionAttributeListener;
 import javax.servlet.http.HttpSessionBindingEvent;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionBindingListenerImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionBindingListenerImpl.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionBindingListenerImpl.java
index ce25cb6..0aedcbb 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionBindingListenerImpl.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionBindingListenerImpl.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import java.io.Serializable;
 import javax.servlet.http.HttpSessionBindingEvent;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl.java
index 55510a6..08eacfb 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl.java
@@ -15,9 +15,9 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
 
 import javax.servlet.http.HttpSession;
 import javax.servlet.http.HttpSessionEvent;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl2.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl2.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl2.java
index bccd83f..fbe68b1 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl2.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/HttpSessionListenerImpl2.java
@@ -15,9 +15,9 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
 
 import javax.servlet.http.HttpSession;
 import javax.servlet.http.HttpSessionEvent;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/MyServletTester.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/MyServletTester.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/MyServletTester.java
index 09c9536..294df73 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/MyServletTester.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/MyServletTester.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import org.eclipse.jetty.servlet.ServletTester;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/RendezvousManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/RendezvousManager.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/RendezvousManager.java
index acb5a1b..39e00f9 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/RendezvousManager.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/RendezvousManager.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestAttributeListenerImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestAttributeListenerImpl.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestAttributeListenerImpl.java
index 35ff756..1f73df1 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestAttributeListenerImpl.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestAttributeListenerImpl.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import javax.servlet.ServletRequestAttributeEvent;
 import javax.servlet.ServletRequestAttributeListener;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestListenerImpl.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestListenerImpl.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestListenerImpl.java
index 5e007dd..a32793d 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestListenerImpl.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/ServletRequestListenerImpl.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
 import javax.servlet.ServletRequestEvent;
 import javax.servlet.ServletRequestListener;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationIntegrationJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationIntegrationJUnitTest.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationIntegrationJUnitTest.java
index da56735..7333c9f 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationIntegrationJUnitTest.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationIntegrationJUnitTest.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.internal.filter;
-
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
-import com.gemstone.gemfire.modules.session.junit.PerTestClassLoaderRunner;
-import com.gemstone.gemfire.test.junit.categories.FlakyTest;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+package org.apache.geode.modules.session.internal.filter;
+
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.modules.session.junit.PerTestClassLoaderRunner;
+import org.apache.geode.test.junit.categories.FlakyTest;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import org.apache.jasper.servlet.JspServlet;
 import org.eclipse.jetty.http.HttpTester;
 import org.eclipse.jetty.servlet.FilterHolder;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationJUnitTest.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationJUnitTest.java
index 280169d..1d60795 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationJUnitTest.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationJUnitTest.java
@@ -15,11 +15,11 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import com.mockrunner.mock.web.MockFilterConfig;
 import com.mockrunner.mock.web.WebMockObjectFactory;
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationLocalCacheJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationLocalCacheJUnitTest.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationLocalCacheJUnitTest.java
index 1d65311..8f24459 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationLocalCacheJUnitTest.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/internal/filter/SessionReplicationLocalCacheJUnitTest.java
@@ -15,11 +15,11 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.internal.filter;
+package org.apache.geode.modules.session.internal.filter;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.modules.session.filter.SessionCachingFilter;
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.modules.session.filter.SessionCachingFilter;
+import org.apache.geode.test.junit.categories.IntegrationTest;
 import com.mockrunner.mock.web.MockFilterConfig;
 import com.mockrunner.mock.web.WebMockObjectFactory;
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/ChildFirstClassLoader.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/ChildFirstClassLoader.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/ChildFirstClassLoader.java
index dd4441b..95ca509 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/ChildFirstClassLoader.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/ChildFirstClassLoader.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.junit;
+package org.apache.geode.modules.session.junit;
 
 import java.net.URL;
 import java.net.URLClassLoader;
@@ -53,7 +53,7 @@ public class ChildFirstClassLoader extends URLClassLoader {
       throws ClassNotFoundException {
     Class c = null;
 
-    if (name.startsWith("com.gemstone")) {
+    if (name.startsWith("org.apache")) {
       // First, check if the class has already been loaded
       c = findLoadedClass(name);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/NamedRunner.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/NamedRunner.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/NamedRunner.java
index e717c9a..fea9833 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/NamedRunner.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/NamedRunner.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.junit;
+package org.apache.geode.modules.session.junit;
 
 import org.junit.runner.notification.RunNotifier;
 import org.junit.runners.BlockJUnit4ClassRunner;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/PerTestClassLoaderRunner.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/PerTestClassLoaderRunner.java b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/PerTestClassLoaderRunner.java
index c56a259..e2f7f51 100644
--- a/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/PerTestClassLoaderRunner.java
+++ b/extensions/geode-modules-session/src/test/java/org/apache/geode/modules/session/junit/PerTestClassLoaderRunner.java
@@ -15,7 +15,7 @@
 * limitations under the License.
 */
 
-package com.gemstone.gemfire.modules.session.junit;
+package org.apache.geode.modules.session.junit;
 
 /**
  * Licensed to the Apache Software Foundation (ASF) under one or more

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-session/src/test/resources/org/apache/geode/modules/session/installer/InstallerJUnitTest.web.xml.expected
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-session/src/test/resources/org/apache/geode/modules/session/installer/InstallerJUnitTest.web.xml.expected b/extensions/geode-modules-session/src/test/resources/org/apache/geode/modules/session/installer/InstallerJUnitTest.web.xml.expected
index d28adb3..1b23f2f 100644
--- a/extensions/geode-modules-session/src/test/resources/org/apache/geode/modules/session/installer/InstallerJUnitTest.web.xml.expected
+++ b/extensions/geode-modules-session/src/test/resources/org/apache/geode/modules/session/installer/InstallerJUnitTest.web.xml.expected
@@ -17,7 +17,7 @@ limitations under the License.
 --><web-app xmlns="http://java.sun.com/xml/ns/j2ee" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" version="3.0" xsi:schemaLocation="http://java.sun.com/xml/ns/j2ee  http://java.sun.com/xml/ns/javaee/web-app_3_0.xsd">
   <filter>
         <filter-name>gemfire-session-filter</filter-name>
-        <filter-class>com.gemstone.gemfire.modules.session.filter.SessionCachingFilter</filter-class>
+        <filter-class>org.apache.geode.modules.session.filter.SessionCachingFilter</filter-class>
         <init-param>
             <param-name>cache-type</param-name>
             <param-value>peer-to-peer</param-value>
@@ -37,7 +37,7 @@ limitations under the License.
     <url-pattern>/*</url-pattern>
   </filter-mapping>
     <listener>
-        <listener-class>com.gemstone.gemfire.modules.session.filter.SessionListener</listener-class>
+        <listener-class>org.apache.geode.modules.session.filter.SessionListener</listener-class>
     </listener>
 
   <servlet>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat7/src/main/java/org/apache/geode/modules/session/catalina/Tomcat7DeltaSessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat7/src/main/java/org/apache/geode/modules/session/catalina/Tomcat7DeltaSessionManager.java b/extensions/geode-modules-tomcat7/src/main/java/org/apache/geode/modules/session/catalina/Tomcat7DeltaSessionManager.java
index 8776c16..fc3c5a2 100644
--- a/extensions/geode-modules-tomcat7/src/main/java/org/apache/geode/modules/session/catalina/Tomcat7DeltaSessionManager.java
+++ b/extensions/geode-modules-tomcat7/src/main/java/org/apache/geode/modules/session/catalina/Tomcat7DeltaSessionManager.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.LifecycleException;
 import org.apache.catalina.LifecycleListener;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat7/src/test/java/org/apache/geode/modules/session/Tomcat7SessionsJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat7/src/test/java/org/apache/geode/modules/session/Tomcat7SessionsJUnitTest.java b/extensions/geode-modules-tomcat7/src/test/java/org/apache/geode/modules/session/Tomcat7SessionsJUnitTest.java
index e7970d7..ba4408b 100644
--- a/extensions/geode-modules-tomcat7/src/test/java/org/apache/geode/modules/session/Tomcat7SessionsJUnitTest.java
+++ b/extensions/geode-modules-tomcat7/src/test/java/org/apache/geode/modules/session/Tomcat7SessionsJUnitTest.java
@@ -14,10 +14,10 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import com.gemstone.gemfire.modules.session.catalina.Tomcat7DeltaSessionManager;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.modules.session.catalina.Tomcat7DeltaSessionManager;
+import org.apache.geode.test.junit.categories.UnitTest;
 import org.junit.BeforeClass;
 import org.junit.experimental.categories.Category;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession8.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession8.java b/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession8.java
index 0b9f58f..b0ca21d 100644
--- a/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession8.java
+++ b/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/DeltaSession8.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -41,19 +41,19 @@ import org.apache.catalina.session.StandardSession;
 import org.apache.juli.logging.Log;
 import org.apache.juli.logging.LogFactory;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Delta;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.modules.gatewaydelta.GatewayDelta;
-import com.gemstone.gemfire.modules.gatewaydelta.GatewayDeltaEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionAttributeEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionAttributeEventBatch;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionDestroyAttributeEvent;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionUpdateAttributeEvent;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Delta;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.modules.gatewaydelta.GatewayDelta;
+import org.apache.geode.modules.gatewaydelta.GatewayDeltaEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionAttributeEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionAttributeEventBatch;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionDestroyAttributeEvent;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionUpdateAttributeEvent;
 
 
 @SuppressWarnings("serial")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/Tomcat8DeltaSessionManager.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/Tomcat8DeltaSessionManager.java b/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/Tomcat8DeltaSessionManager.java
index 25bb847..e5aa1ac 100644
--- a/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/Tomcat8DeltaSessionManager.java
+++ b/extensions/geode-modules-tomcat8/src/main/java/org/apache/geode/modules/session/catalina/Tomcat8DeltaSessionManager.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 import org.apache.catalina.Context;
 import org.apache.catalina.LifecycleException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat8.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat8.java b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat8.java
index 39c4311..58b9df1 100644
--- a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat8.java
+++ b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/EmbeddedTomcat8.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
 import java.io.File;
 import java.net.MalformedURLException;
@@ -41,7 +41,7 @@ import org.apache.catalina.valves.ValveBase;
 import org.apache.juli.logging.Log;
 import org.apache.juli.logging.LogFactory;
 
-import com.gemstone.gemfire.modules.session.catalina.JvmRouteBinderValve;
+import org.apache.geode.modules.session.catalina.JvmRouteBinderValve;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/TestSessionsTomcat8Base.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/TestSessionsTomcat8Base.java b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/TestSessionsTomcat8Base.java
index f8604bf..7e7eef3 100644
--- a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/TestSessionsTomcat8Base.java
+++ b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/TestSessionsTomcat8Base.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 import static org.junit.Assert.*;
 
 import java.beans.PropertyChangeEvent;
@@ -35,11 +35,11 @@ import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.Test;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
-import com.gemstone.gemfire.test.dunit.VM;
-import com.gemstone.gemfire.test.dunit.internal.JUnit4DistributedTestCase;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.session.catalina.DeltaSessionManager;
+import org.apache.geode.test.dunit.VM;
+import org.apache.geode.test.dunit.internal.JUnit4DistributedTestCase;
 
 public abstract class TestSessionsTomcat8Base extends JUnit4DistributedTestCase{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsClientServerDUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsClientServerDUnitTest.java b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsClientServerDUnitTest.java
index ca9cdbe..8b29048 100644
--- a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsClientServerDUnitTest.java
+++ b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsClientServerDUnitTest.java
@@ -14,28 +14,28 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-import static com.gemstone.gemfire.internal.cache.CacheServerLauncher.serverPort;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+import static org.apache.geode.internal.cache.CacheServerLauncher.serverPort;
 
 import java.util.Properties;
 
 import org.junit.experimental.categories.Category;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-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.internal.AvailablePortHelper;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.modules.session.catalina.ClientServerCacheLifecycleListener;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
-import com.gemstone.gemfire.modules.session.catalina.Tomcat8DeltaSessionManager;
-import com.gemstone.gemfire.test.dunit.Host;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.client.PoolFactory;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.modules.session.catalina.ClientServerCacheLifecycleListener;
+import org.apache.geode.modules.session.catalina.DeltaSessionManager;
+import org.apache.geode.modules.session.catalina.Tomcat8DeltaSessionManager;
+import org.apache.geode.test.dunit.Host;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.categories.UnitTest;
 
 @Category(DistributedTest.class)
 public class Tomcat8SessionsClientServerDUnitTest extends TestSessionsTomcat8Base {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsDUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsDUnitTest.java b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsDUnitTest.java
index e573c4e..d61e114 100644
--- a/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsDUnitTest.java
+++ b/extensions/geode-modules-tomcat8/src/test/java/org/apache/geode/modules/session/Tomcat8SessionsDUnitTest.java
@@ -14,16 +14,16 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session;
+package org.apache.geode.modules.session;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
-import com.gemstone.gemfire.internal.AvailablePortHelper;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
-import com.gemstone.gemfire.modules.session.catalina.PeerToPeerCacheLifecycleListener;
-import com.gemstone.gemfire.modules.session.catalina.Tomcat8DeltaSessionManager;
-import com.gemstone.gemfire.test.junit.categories.DistributedTest;
-import com.gemstone.gemfire.test.junit.categories.UnitTest;
+import org.apache.geode.internal.AvailablePortHelper;
+import org.apache.geode.modules.session.catalina.DeltaSessionManager;
+import org.apache.geode.modules.session.catalina.PeerToPeerCacheLifecycleListener;
+import org.apache.geode.modules.session.catalina.Tomcat8DeltaSessionManager;
+import org.apache.geode.test.junit.categories.DistributedTest;
+import org.apache.geode.test.junit.categories.UnitTest;
 
 import org.junit.AfterClass;
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/AbstractGatewayDeltaEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/AbstractGatewayDeltaEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/AbstractGatewayDeltaEvent.java
index 13b2e77..fabde8d 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/AbstractGatewayDeltaEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/AbstractGatewayDeltaEvent.java
@@ -14,12 +14,12 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDelta.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDelta.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDelta.java
index 4acad05..7a3ff8e 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDelta.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDelta.java
@@ -14,7 +14,7 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
 public interface GatewayDelta {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaCreateEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaCreateEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaCreateEvent.java
index 3202591..3782ef5 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaCreateEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaCreateEvent.java
@@ -14,15 +14,15 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.CachedDeserializableFactory;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.CachedDeserializableFactory;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaDestroyEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaDestroyEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaDestroyEvent.java
index 54e7c0d..96d9b6c 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaDestroyEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaDestroyEvent.java
@@ -14,14 +14,14 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.session.catalina.DeltaSessionInterface;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.session.catalina.DeltaSessionInterface;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEvent.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEvent.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEvent.java
index 672a01f..1da0a9c 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEvent.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEvent.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
-import com.gemstone.gemfire.cache.Cache;
+import org.apache.geode.cache.Cache;
 
 public interface GatewayDeltaEvent {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEventApplicationCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEventApplicationCacheListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEventApplicationCacheListener.java
index cf9aa1a..ca58dde 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEventApplicationCacheListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaEventApplicationCacheListener.java
@@ -14,15 +14,15 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
+package org.apache.geode.modules.gatewaydelta;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventCallbackArgument;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventCallbackArgument;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaForwarderCacheListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaForwarderCacheListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaForwarderCacheListener.java
index ce44fcb..aa8ad99 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaForwarderCacheListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/gatewaydelta/GatewayDeltaForwarderCacheListener.java
@@ -14,22 +14,22 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.gatewaydelta;
-
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.InterestPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.SerializedCacheValue;
-import com.gemstone.gemfire.cache.SubscriptionAttributes;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
+package org.apache.geode.modules.gatewaydelta;
+
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.InterestPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.SerializedCacheValue;
+import org.apache.geode.cache.SubscriptionAttributes;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.LocalRegion;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/AbstractCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/AbstractCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/AbstractCache.java
index 9704853..6c18e0f 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/AbstractCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/AbstractCache.java
@@ -14,16 +14,16 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.bootstrap;
-
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.internal.AbstractDistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.modules.util.Banner;
-import com.gemstone.gemfire.modules.util.RegionHelper;
-import com.gemstone.gemfire.modules.util.ResourceManagerValidator;
+package org.apache.geode.modules.session.bootstrap;
+
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.internal.AbstractDistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.modules.util.Banner;
+import org.apache.geode.modules.util.RegionHelper;
+import org.apache.geode.modules.util.ResourceManagerValidator;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -36,7 +36,7 @@ import java.util.Properties;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.atomic.AtomicBoolean;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 public abstract class AbstractCache {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/ClientServerCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/ClientServerCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/ClientServerCache.java
index a4bd7a5..986ff32 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/ClientServerCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/ClientServerCache.java
@@ -14,10 +14,10 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.bootstrap;
+package org.apache.geode.modules.session.bootstrap;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.client.ClientCacheFactory;
 
 /**
  * This is a singleton class which maintains configuration properties as well as starting a Client-Server cache.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/LifecycleTypeAdapter.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/LifecycleTypeAdapter.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/LifecycleTypeAdapter.java
index 2f0c9bb..3b24cda 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/LifecycleTypeAdapter.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/LifecycleTypeAdapter.java
@@ -19,7 +19,7 @@
  * and open the template in the editor.
  */
 
-package com.gemstone.gemfire.modules.session.bootstrap;
+package org.apache.geode.modules.session.bootstrap;
 
 /**
  * Adapter for the Catalina Lifecycle event types

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/PeerToPeerCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/PeerToPeerCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/PeerToPeerCache.java
index 92c5f1f..c220804 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/PeerToPeerCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/bootstrap/PeerToPeerCache.java
@@ -14,12 +14,12 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.bootstrap;
+package org.apache.geode.modules.session.bootstrap;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.control.RebalanceResults;
-import com.gemstone.gemfire.modules.util.RegionHelper;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.control.RebalanceResults;
+import org.apache.geode.modules.util.RegionHelper;
 
 /**
  * This is a singleton class which maintains configuration properties as well as starting a Peer-To-Peer cache.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractCacheLifecycleListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractCacheLifecycleListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractCacheLifecycleListener.java
index 1019ddc..edea6a9 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractCacheLifecycleListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractCacheLifecycleListener.java
@@ -14,11 +14,11 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
 
-import com.gemstone.gemfire.modules.session.bootstrap.AbstractCache;
-import com.gemstone.gemfire.modules.session.bootstrap.LifecycleTypeAdapter;
+import org.apache.geode.modules.session.bootstrap.AbstractCache;
+import org.apache.geode.modules.session.bootstrap.LifecycleTypeAdapter;
 import org.apache.catalina.LifecycleEvent;
 import org.apache.catalina.LifecycleListener;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractSessionCache.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractSessionCache.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractSessionCache.java
index 3019cae..461a982 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractSessionCache.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/AbstractSessionCache.java
@@ -14,13 +14,13 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.modules.session.catalina.internal.DeltaSessionStatistics;
-import com.gemstone.gemfire.modules.util.RegionConfiguration;
-import com.gemstone.gemfire.modules.util.SessionCustomExpiry;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.modules.session.catalina.internal.DeltaSessionStatistics;
+import org.apache.geode.modules.util.RegionConfiguration;
+import org.apache.geode.modules.util.SessionCustomExpiry;
 import org.apache.catalina.Session;
 
 import javax.servlet.http.HttpSession;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerCacheLifecycleListener.java
----------------------------------------------------------------------
diff --git a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerCacheLifecycleListener.java b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerCacheLifecycleListener.java
index ba66fa2..ffed8ca 100644
--- a/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerCacheLifecycleListener.java
+++ b/extensions/geode-modules/src/main/java/org/apache/geode/modules/session/catalina/ClientServerCacheLifecycleListener.java
@@ -14,9 +14,9 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
-package com.gemstone.gemfire.modules.session.catalina;
+package org.apache.geode.modules.session.catalina;
 
-import com.gemstone.gemfire.modules.session.bootstrap.ClientServerCache;
+import org.apache.geode.modules.session.bootstrap.ClientServerCache;
 
 public class ClientServerCacheLifecycleListener extends AbstractCacheLifecycleListener {
 


[15/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/GemFireCacheImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/GemFireCacheImpl.java
index 47c7e24..0efbb84 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/GemFireCacheImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/GemFireCacheImpl.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.BufferedReader;
 import java.io.ByteArrayInputStream;
@@ -76,160 +76,160 @@ import com.sun.jna.Platform;
 import org.apache.geode.redis.GeodeRedisServer;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.ForcedDisconnectException;
-import com.gemstone.gemfire.GemFireCacheException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.internal.SystemMemberCacheEventProcessor;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.CacheExistsException;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.CacheTransactionManager;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.CacheXmlException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.DiskStore;
-import com.gemstone.gemfire.cache.DiskStoreFactory;
-import com.gemstone.gemfire.cache.DynamicRegionFactory;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.GatewayException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.cache.RegionFactory;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.RegionShortcut;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueue;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventQueueFactory;
-import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueFactoryImpl;
-import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueImpl;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientRegionFactory;
-import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.PoolFactory;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.ClientMetadataService;
-import com.gemstone.gemfire.cache.client.internal.ClientRegionFactoryImpl;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.CqServiceProvider;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.cache.snapshot.CacheSnapshotService;
-import com.gemstone.gemfire.cache.util.GatewayConflictResolver;
-import com.gemstone.gemfire.cache.wan.GatewayReceiver;
-import com.gemstone.gemfire.cache.wan.GatewayReceiverFactory;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.CacheTime;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-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.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.distributed.internal.PooledExecutorWithDMStats;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ResourceEvent;
-import com.gemstone.gemfire.distributed.internal.ResourceEventsListener;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.JarDeployer;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor;
-import com.gemstone.gemfire.internal.cache.execute.util.FindRestEnabledServersFunction;
-import com.gemstone.gemfire.internal.cache.extension.Extensible;
-import com.gemstone.gemfire.internal.cache.extension.ExtensionPoint;
-import com.gemstone.gemfire.internal.cache.extension.SimpleExtensionPoint;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-import com.gemstone.gemfire.internal.cache.locks.TXLockService;
-import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-import com.gemstone.gemfire.internal.cache.lru.OffHeapEvictor;
-import com.gemstone.gemfire.internal.cache.partitioned.RedundancyAlreadyMetException;
-import com.gemstone.gemfire.internal.cache.persistence.BackupManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.query.TemporaryResultSetFactory;
-import com.gemstone.gemfire.internal.cache.snapshot.CacheSnapshotServiceImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.AcceptorImpl;
-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.ClientHealthMonitor;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAdvisor;
-import com.gemstone.gemfire.internal.cache.wan.WANServiceProvider;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlParser;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlPropertyResolver;
-import com.gemstone.gemfire.internal.cache.xmlcache.PropertyResolver;
-import com.gemstone.gemfire.internal.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.jndi.JNDIInvoker;
-import com.gemstone.gemfire.internal.jta.TransactionManagerImpl;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.offheap.MemoryAllocator;
-import com.gemstone.gemfire.internal.process.ClusterConfigurationNotAvailableException;
-import com.gemstone.gemfire.internal.sequencelog.SequenceLoggerImpl;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-import com.gemstone.gemfire.internal.util.concurrent.FutureResult;
-import com.gemstone.gemfire.lang.Identifiable;
-import com.gemstone.gemfire.management.internal.JmxManagerAdvisee;
-import com.gemstone.gemfire.management.internal.JmxManagerAdvisor;
-import com.gemstone.gemfire.management.internal.RestAgent;
-import com.gemstone.gemfire.management.internal.beans.ManagementListener;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationResponse;
-import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
-import com.gemstone.gemfire.memcached.GemFireMemcachedServer.Protocol;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxInstanceFactory;
-import com.gemstone.gemfire.pdx.PdxSerializer;
-import com.gemstone.gemfire.pdx.ReflectionBasedAutoSerializer;
-import com.gemstone.gemfire.pdx.internal.AutoSerializableManager;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceFactoryImpl;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceImpl;
-import com.gemstone.gemfire.pdx.internal.TypeRegistry;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.ForcedDisconnectException;
+import org.apache.geode.GemFireCacheException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.LogWriter;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.internal.SystemMemberCacheEventProcessor;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheExistsException;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheTransactionManager;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.CacheXmlException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.DiskStore;
+import org.apache.geode.cache.DiskStoreFactory;
+import org.apache.geode.cache.DynamicRegionFactory;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.GatewayException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.RegionFactory;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.RegionShortcut;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueue;
+import org.apache.geode.cache.asyncqueue.AsyncEventQueueFactory;
+import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueFactoryImpl;
+import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueImpl;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientRegionFactory;
+import org.apache.geode.cache.client.ClientRegionShortcut;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.PoolFactory;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.ClientMetadataService;
+import org.apache.geode.cache.client.internal.ClientRegionFactoryImpl;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.CqServiceProvider;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.cache.snapshot.CacheSnapshotService;
+import org.apache.geode.cache.util.GatewayConflictResolver;
+import org.apache.geode.cache.wan.GatewayReceiver;
+import org.apache.geode.cache.wan.GatewayReceiverFactory;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.cache.wan.GatewaySenderFactory;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.CacheTime;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.distributed.internal.PooledExecutorWithDMStats;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.distributed.internal.ResourceEventsListener;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.JarDeployer;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.ResourceAdvisor;
+import org.apache.geode.internal.cache.execute.util.FindRestEnabledServersFunction;
+import org.apache.geode.internal.cache.extension.Extensible;
+import org.apache.geode.internal.cache.extension.ExtensionPoint;
+import org.apache.geode.internal.cache.extension.SimpleExtensionPoint;
+import org.apache.geode.internal.cache.ha.HARegionQueue;
+import org.apache.geode.internal.cache.locks.TXLockService;
+import org.apache.geode.internal.cache.lru.HeapEvictor;
+import org.apache.geode.internal.cache.lru.OffHeapEvictor;
+import org.apache.geode.internal.cache.partitioned.RedundancyAlreadyMetException;
+import org.apache.geode.internal.cache.persistence.BackupManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.query.TemporaryResultSetFactory;
+import org.apache.geode.internal.cache.snapshot.CacheSnapshotServiceImpl;
+import org.apache.geode.internal.cache.tier.sockets.AcceptorImpl;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.internal.cache.tier.sockets.ClientHealthMonitor;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.GatewaySenderAdvisor;
+import org.apache.geode.internal.cache.wan.WANServiceProvider;
+import org.apache.geode.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlParser;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlPropertyResolver;
+import org.apache.geode.internal.cache.xmlcache.PropertyResolver;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.jndi.JNDIInvoker;
+import org.apache.geode.internal.jta.TransactionManagerImpl;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.offheap.MemoryAllocator;
+import org.apache.geode.internal.process.ClusterConfigurationNotAvailableException;
+import org.apache.geode.internal.sequencelog.SequenceLoggerImpl;
+import org.apache.geode.internal.tcp.ConnectionTable;
+import org.apache.geode.internal.util.concurrent.FutureResult;
+import org.apache.geode.lang.Identifiable;
+import org.apache.geode.management.internal.JmxManagerAdvisee;
+import org.apache.geode.management.internal.JmxManagerAdvisor;
+import org.apache.geode.management.internal.RestAgent;
+import org.apache.geode.management.internal.beans.ManagementListener;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationResponse;
+import org.apache.geode.memcached.GemFireMemcachedServer;
+import org.apache.geode.memcached.GemFireMemcachedServer.Protocol;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxInstanceFactory;
+import org.apache.geode.pdx.PdxSerializer;
+import org.apache.geode.pdx.ReflectionBasedAutoSerializer;
+import org.apache.geode.pdx.internal.AutoSerializableManager;
+import org.apache.geode.pdx.internal.PdxInstanceFactoryImpl;
+import org.apache.geode.pdx.internal.PdxInstanceImpl;
+import org.apache.geode.pdx.internal.TypeRegistry;
 
 // @todo somebody Come up with more reasonable values for {@link #DEFAULT_LOCK_TIMEOUT}, etc.
 /**
- * GemFire's implementation of a distributed {@link com.gemstone.gemfire.cache.Cache}.
+ * GemFire's implementation of a distributed {@link org.apache.geode.cache.Cache}.
  *
  */
 @SuppressWarnings("deprecation")
@@ -627,7 +627,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
   
   /**
-   * This is for debugging cache-open issues (esp. {@link com.gemstone.gemfire.cache.CacheExistsException})
+   * This is for debugging cache-open issues (esp. {@link org.apache.geode.cache.CacheExistsException})
    */
   @Override
   public String toString() {
@@ -1274,7 +1274,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
    * @throws CacheXmlException
    *           If something goes wrong while parsing the declarative caching XML file.
    * @throws TimeoutException
-   *           If a {@link com.gemstone.gemfire.cache.Region#put(Object, Object)}times out while initializing the cache.
+   *           If a {@link org.apache.geode.cache.Region#put(Object, Object)}times out while initializing the cache.
    * @throws CacheWriterException
    *           If a <code>CacheWriterException</code> is thrown while initializing the cache.
    * @throws RegionExistsException
@@ -1399,7 +1399,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
     /*
      * (non-Javadoc)
      *
-     * @see com.gemstone.gemfire.CancelCriterion#cancelInProgress()
+     * @see org.apache.geode.CancelCriterion#cancelInProgress()
      */
     @Override
     public String cancelInProgress() {
@@ -1419,7 +1419,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
     /*
      * (non-Javadoc)
      *
-     * @see com.gemstone.gemfire.CancelCriterion#generateCancelledException(java.lang.Throwable)
+     * @see org.apache.geode.CancelCriterion#generateCancelledException(java.lang.Throwable)
      */
     @Override
     public RuntimeException generateCancelledException(Throwable e) {
@@ -2700,7 +2700,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /*
    * (non-Javadoc)
    *
-   * @see com.gemstone.gemfire.cache.Cache#getMembers()
+   * @see org.apache.geode.cache.Cache#getMembers()
    */
   public Set<DistributedMember> getMembers() {
     return Collections.unmodifiableSet(this.dm.getOtherNormalDistributionManagerIds());
@@ -2709,7 +2709,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /*
    * (non-Javadoc)
    *
-   * @see com.gemstone.gemfire.cache.Cache#getAdminMembers()
+   * @see org.apache.geode.cache.Cache#getAdminMembers()
    */
   public Set<DistributedMember> getAdminMembers() {
     return this.dm.getAdminMemberSet();
@@ -2718,7 +2718,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /*
    * (non-Javadoc)
    *
-   * @see com.gemstone.gemfire.cache.Cache#getMembers(com.gemstone.gemfire.cache.Region)
+   * @see org.apache.geode.cache.Cache#getMembers(org.apache.geode.cache.Region)
    */
   public Set<DistributedMember> getMembers(Region r) {
     if (r instanceof DistributedRegion) {
@@ -2735,7 +2735,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /*
    * (non-Javadoc)
    *
-   * @see com.gemstone.gemfire.cache.client.ClientCache#getCurrentServers()
+   * @see org.apache.geode.cache.client.ClientCache#getCurrentServers()
    */
   public Set<InetSocketAddress> getCurrentServers() {
     Map<String, Pool> pools = PoolManager.getAll();
@@ -3616,7 +3616,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * Implementation of {@link com.gemstone.gemfire.cache.Cache#setCopyOnRead}
+   * Implementation of {@link org.apache.geode.cache.Cache#setCopyOnRead}
    *
    * @since GemFire 4.0
    */
@@ -3625,7 +3625,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * Implementation of {@link com.gemstone.gemfire.cache.Cache#getCopyOnRead}
+   * Implementation of {@link org.apache.geode.cache.Cache#getCopyOnRead}
    *
    * @since GemFire 4.0
    */
@@ -4524,7 +4524,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
    */
   public QueryMonitor getQueryMonitor() {
     //Check to see if monitor is required if ResourceManager critical heap percentage is set
-    //@see com.gemstone.gemfire.cache.control.ResourceManager#setCriticalHeapPercentage(int)
+    //@see org.apache.geode.cache.control.ResourceManager#setCriticalHeapPercentage(int)
     //or whether we override it with the system variable;
     boolean monitorRequired = !QUERY_MONITOR_DISABLED_FOR_LOW_MEM && QUERY_MONITOR_REQUIRED_FOR_RESOURCE_MANAGER;
     // Added for DUnit test purpose, which turns-on and off the this.TEST_MAX_QUERY_EXECUTION_TIME.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/GemfireCacheHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/GemfireCacheHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/GemfireCacheHelper.java
index 19fd3fa..45cba65 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/GemfireCacheHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/GemfireCacheHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.concurrent.FutureTask;
 import java.util.concurrent.ThreadFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/GridAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/GridAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/GridAdvisor.java
index ff7dea1..c6ae9a2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/GridAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/GridAdvisor.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
 import java.io.*;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.*;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.membership.*;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/HARegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/HARegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/HARegion.java
index d79cb72..772c20b 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/HARegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/HARegion.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,29 +25,29 @@ import java.util.Map;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.cache.CacheLoader;
-import com.gemstone.gemfire.cache.CacheLoaderException;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.ExpirationAction;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-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.RegionExistsException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.ExpirationAction;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.LoaderHelper;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.ha.HARegionQueue;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.HAEventWrapper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * This region is being implemented to suppress distribution of puts and to
@@ -335,7 +335,7 @@ public final class HARegion extends DistributedRegion
    * This method is overriden so as to make isOriginRemote true always so that
    * the operation is never propagated to other nodes
    * 
-   * @see com.gemstone.gemfire.internal.cache.AbstractRegion#destroyRegion()
+   * @see org.apache.geode.internal.cache.AbstractRegion#destroyRegion()
    */
   @Override
   public void destroyRegion(Object aCallbackArgument)
@@ -481,7 +481,7 @@ public final class HARegion extends DistributedRegion
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#getEventState()
+   * @see org.apache.geode.internal.cache.LocalRegion#getEventState()
    */
   @Override
   public Map<? extends DataSerializable, ? extends DataSerializable> getEventState() {
@@ -537,7 +537,7 @@ public final class HARegion extends DistributedRegion
     }
     
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor#adviseInitialImage(com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.InitialImageAdvice)
+     * @see org.apache.geode.internal.cache.CacheDistributionAdvisor#adviseInitialImage(org.apache.geode.internal.cache.CacheDistributionAdvisor.InitialImageAdvice)
      */
     @Override
     public InitialImageAdvice adviseInitialImage(
@@ -582,7 +582,7 @@ public final class HARegion extends DistributedRegion
       }
 
       /* (non-Javadoc)
-       * @see com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile#fromData(java.io.DataInput)
+       * @see org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile#fromData(java.io.DataInput)
        */
       @Override
       public void fromData(DataInput in) throws IOException,
@@ -594,7 +594,7 @@ public final class HARegion extends DistributedRegion
       }
       
       /* (non-Javadoc)
-       * @see com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile#toData(java.io.DataOutput)
+       * @see org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile#toData(java.io.DataOutput)
        */
       @Override
       public void toData(DataOutput out) throws IOException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/HasCachePerfStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/HasCachePerfStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/HasCachePerfStats.java
index 70aaa97..7d52f57 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/HasCachePerfStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/HasCachePerfStats.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 public interface HasCachePerfStats
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/IdentityArrayList.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/IdentityArrayList.java b/geode-core/src/main/java/org/apache/geode/internal/cache/IdentityArrayList.java
index 736f6bf..1640fa9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/IdentityArrayList.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/IdentityArrayList.java
@@ -18,7 +18,7 @@
  * This is a modified version of the fastutil ObjectArrayList.  It is modified
  * to use identity checks rather than equality checks for higher performance.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 import java.util.Arrays;
 import java.util.Collection;
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ImageState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ImageState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ImageState.java
index da3873c..05378ed 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ImageState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ImageState.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.Iterator;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * State object used during getInitialImage Locked during clean up of destroyed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InMemoryPersistentMemberView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InMemoryPersistentMemberView.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InMemoryPersistentMemberView.java
index aa55634..65f7349 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InMemoryPersistentMemberView.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InMemoryPersistentMemberView.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.HashSet;
 import java.util.Map;
@@ -22,11 +22,11 @@ import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
 import java.util.Collections;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberState;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberView;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.cache.persistence.PersistentMemberState;
+import org.apache.geode.internal.cache.persistence.PersistentMemberView;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/IncomingGatewayStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/IncomingGatewayStatus.java b/geode-core/src/main/java/org/apache/geode/internal/cache/IncomingGatewayStatus.java
index abcbcf1..a35b9bc 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/IncomingGatewayStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/IncomingGatewayStatus.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.Serializable;
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageFlowControl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageFlowControl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageFlowControl.java
index 613d040..8c4ae0c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageFlowControl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageFlowControl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,17 +27,17 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.ProcessorKeeper21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.i18n.StringId;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.ProcessorKeeper21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.i18n.StringId;
 
 /**
  * This class keeps track of how many InitialImageMessages are in flight between the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
index 7ee5c74..df4746d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
@@ -15,41 +15,41 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.query.internal.CqStateImpl;
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.ServerCQ;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.InitialImageFlowControl.FlowControlPermitMessage;
-import com.gemstone.gemfire.internal.cache.ha.HAContainerWrapper;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistenceAdvisor;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-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 com.gemstone.gemfire.internal.cache.versions.*;
-import com.gemstone.gemfire.internal.cache.vmotion.VMotionObserverHolder;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
-import com.gemstone.gemfire.internal.sequencelog.RegionLogger;
-import com.gemstone.gemfire.internal.util.ObjectIntProcedure;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.query.internal.CqStateImpl;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.ServerCQ;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.InitialImageFlowControl.FlowControlPermitMessage;
+import org.apache.geode.internal.cache.ha.HAContainerWrapper;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.persistence.PersistenceAdvisor;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.*;
+import org.apache.geode.internal.cache.vmotion.VMotionObserverHolder;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.sequencelog.EntryLogger;
+import org.apache.geode.internal.sequencelog.RegionLogger;
+import org.apache.geode.internal.util.ObjectIntProcedure;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
@@ -200,14 +200,14 @@ public class InitialImageOperation  {
    * @param advice
    * @param recoveredRVV recovered rvv
    * @return true if succeeded to get image
-   * @throws com.gemstone.gemfire.cache.TimeoutException
+   * @throws org.apache.geode.cache.TimeoutException
    */
   GIIStatus getFromOne(
       Set recipientSet,
       boolean targetReinitialized,
       CacheDistributionAdvisor.InitialImageAdvice advice,
       boolean recoveredFromDisk, RegionVersionVector recoveredRVV)
-      throws com.gemstone.gemfire.cache.TimeoutException
+      throws org.apache.geode.cache.TimeoutException
   {
     final boolean isDebugEnabled = logger.isDebugEnabled();
     
@@ -485,8 +485,8 @@ public class InitialImageOperation  {
           continue;
         } catch (InternalGemFireException ex) {
           Throwable cause = ex.getCause();
-          if (cause instanceof com.gemstone.gemfire.cache.TimeoutException) {
-            throw (com.gemstone.gemfire.cache.TimeoutException)cause;
+          if (cause instanceof org.apache.geode.cache.TimeoutException) {
+            throw (org.apache.geode.cache.TimeoutException)cause;
           }
           throw ex;
         } catch (ReplyException e) {
@@ -597,8 +597,8 @@ public class InitialImageOperation  {
         }
       } catch (InternalGemFireException ex) {
         Throwable cause = ex.getCause();
-        if (cause instanceof com.gemstone.gemfire.cache.TimeoutException) {
-          throw (com.gemstone.gemfire.cache.TimeoutException)cause;
+        if (cause instanceof org.apache.geode.cache.TimeoutException) {
+          throw (org.apache.geode.cache.TimeoutException)cause;
         }
         throw ex;
       } catch (ReplyException e) {
@@ -720,8 +720,8 @@ public class InitialImageOperation  {
       return processor.filtersReceived;
     } catch (InternalGemFireException ex) {
       Throwable cause = ex.getCause();
-      if (cause instanceof com.gemstone.gemfire.cache.TimeoutException) {
-        throw (com.gemstone.gemfire.cache.TimeoutException)cause;
+      if (cause instanceof org.apache.geode.cache.TimeoutException) {
+        throw (org.apache.geode.cache.TimeoutException)cause;
       }
       throw ex;
     } catch (ReplyException e) {
@@ -966,8 +966,8 @@ public class InitialImageOperation  {
       received_rvv = rvv_processor.received_rvv;
     } catch (InternalGemFireException ex) {
       Throwable cause = ex.getCause();
-      if (cause instanceof com.gemstone.gemfire.cache.TimeoutException) {
-        throw (com.gemstone.gemfire.cache.TimeoutException)cause;
+      if (cause instanceof org.apache.geode.cache.TimeoutException) {
+        throw (org.apache.geode.cache.TimeoutException)cause;
       }
       throw ex;
     } catch (ReplyException e) {
@@ -1189,7 +1189,7 @@ public class InitialImageOperation  {
     
     /*
      * (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.ReplyProcessor21#process(com.gemstone.gemfire.distributed.internal.DistributionMessage)
+     * @see org.apache.geode.distributed.internal.ReplyProcessor21#process(org.apache.geode.distributed.internal.DistributionMessage)
      */
     @Override  
     public void process(DistributionMessage msg) {
@@ -2358,7 +2358,7 @@ public class InitialImageOperation  {
     } 
      
     /* (non-Javadoc) 
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID() 
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID() 
      */ 
     @Override   
     public int getDSFID() { 
@@ -3350,7 +3350,7 @@ public class InitialImageOperation  {
     } 
      
     /* (non-Javadoc) 
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID() 
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID() 
      */ 
     @Override   
     public int getDSFID() { 
@@ -3858,7 +3858,7 @@ public class InitialImageOperation  {
     } 
           
     /* (non-Javadoc) 
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID() 
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID() 
      */ 
     @Override   
     public int getDSFID() { 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InlineKeyHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InlineKeyHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InlineKeyHelper.java
index aa98fa6..6ea9729 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InlineKeyHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InlineKeyHelper.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 /**
  * No instances of this class. Just some static method having to do with inline keys.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InterestEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestEvent.java
index 77412be..330b05e 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestEvent.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerHelper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerHelper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.IOException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InterestFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestFilter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestFilter.java
index e4419a3..1d2be4c 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestFilter.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 public interface InterestFilter extends CacheCallback {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InterestRegistrationEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestRegistrationEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestRegistrationEventImpl.java
index 41d3abd..cf0f078 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InterestRegistrationEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InterestRegistrationEventImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,14 +22,14 @@ import java.io.IOException;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.ClientSession;
-import com.gemstone.gemfire.cache.InterestRegistrationEvent;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientProxy;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.ClientSession;
+import org.apache.geode.cache.InterestRegistrationEvent;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientProxy;
 
 public class InterestRegistrationEventImpl implements
     InterestRegistrationEvent, DataSerializable {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCache.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCache.java
index 20f5f49..0f9a87f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCache.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCache.java
@@ -15,20 +15,20 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.extension.Extensible;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.extension.Extensible;
 
 /**
  * The InternalCache interface is contract for implementing classes for defining internal cache operations that should
  * not be part of the "public" API of the implementing class.
  * </p>
- * @see com.gemstone.gemfire.cache.Cache
+ * @see org.apache.geode.cache.Cache
  * @since GemFire 7.0
  */
 public interface InternalCache extends Cache, Extensible<Cache> {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCacheEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCacheEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCacheEvent.java
index da2d385..3bacd0a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCacheEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalCacheEvent.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * A CacheEvent, but the isGenerateCallbacks() is hidden from public consumption

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InternalDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalDataView.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalDataView.java
index 2452804..334fb3e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalDataView.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalDataView.java
@@ -17,18 +17,18 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * @since GemFire 6.0tx

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InternalRegionArguments.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalRegionArguments.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalRegionArguments.java
index 54c9194..ad50dd3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InternalRegionArguments.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InternalRegionArguments.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.InputStream;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.LocalRegion.TestCallable;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.cache.persistence.PersistenceAdvisor;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.LocalRegion.TestCallable;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.cache.persistence.PersistenceAdvisor;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
 
 /**
  * An internal version of Region Attributes that allows for additional information

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateOperation.java
index 1742ad3..9f09e97 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,16 +25,16 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.ConflationKey;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.ConflationKey;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * Handles distribution messaging for invalidating an entry in a region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidatePartitionedRegionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidatePartitionedRegionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidatePartitionedRegionMessage.java
index 97346d3..f604a80 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidatePartitionedRegionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidatePartitionedRegionMessage.java
@@ -17,15 +17,15 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -61,7 +61,7 @@ public class InvalidatePartitionedRegionMessage extends PartitionMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage#operateOnPartitionedRegion(com.gemstone.gemfire.distributed.internal.DistributionManager, com.gemstone.gemfire.internal.cache.PartitionedRegion, long)
+   * @see org.apache.geode.internal.cache.partitioned.PartitionMessage#operateOnPartitionedRegion(org.apache.geode.distributed.internal.DistributionManager, org.apache.geode.internal.cache.PartitionedRegion, long)
    */
   @Override
   protected boolean operateOnPartitionedRegion(DistributionManager dm,
@@ -75,14 +75,14 @@ public class InvalidatePartitionedRegionMessage extends PartitionMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return INVALIDATE_PARTITIONED_REGION_MESSAGE;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage#fromData(java.io.DataInput)
+   * @see org.apache.geode.internal.cache.partitioned.PartitionMessage#fromData(java.io.DataInput)
    */
   @Override
   public void fromData(DataInput in) throws IOException, ClassNotFoundException {
@@ -91,7 +91,7 @@ public class InvalidatePartitionedRegionMessage extends PartitionMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage#toData(java.io.DataOutput)
+   * @see org.apache.geode.internal.cache.partitioned.PartitionMessage#toData(java.io.DataOutput)
    */
   @Override
   public void toData(DataOutput out) throws IOException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateRegionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateRegionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateRegionOperation.java
index e36234e..c1cbbcb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateRegionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InvalidateRegionOperation.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.DataSerializer;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/JtaAfterCompletionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/JtaAfterCompletionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/JtaAfterCompletionMessage.java
index f20cb9e..f173de8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/JtaAfterCompletionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/JtaAfterCompletionMessage.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,15 +27,15 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage.RemoteCommitResponse;
-import com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXRemoteCommitMessage.RemoteCommitResponse;
+import org.apache.geode.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  *
@@ -80,7 +80,7 @@ public class JtaAfterCompletionMessage extends TXMessage {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXMessage#operateOnTx(com.gemstone.gemfire.internal.cache.TXId)
+   * @see org.apache.geode.internal.cache.TXMessage#operateOnTx(org.apache.geode.internal.cache.TXId)
    */
   @Override
   protected boolean operateOnTx(TXId txId,DistributionManager dm) throws RemoteOperationException {
@@ -98,14 +98,14 @@ public class JtaAfterCompletionMessage extends TXMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return JTA_AFTER_COMPLETION_MESSAGE;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXMessage#toData(java.io.DataOutput)
+   * @see org.apache.geode.internal.cache.TXMessage#toData(java.io.DataOutput)
    */
   @Override
   public void toData(DataOutput out) throws IOException {
@@ -115,7 +115,7 @@ public class JtaAfterCompletionMessage extends TXMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXMessage#fromData(java.io.DataInput)
+   * @see org.apache.geode.internal.cache.TXMessage#fromData(java.io.DataInput)
    */
   @Override
   public void fromData(DataInput in) throws IOException, ClassNotFoundException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/JtaBeforeCompletionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/JtaBeforeCompletionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/JtaBeforeCompletionMessage.java
index 079fd89..1c7a449 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/JtaBeforeCompletionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/JtaBeforeCompletionMessage.java
@@ -17,21 +17,21 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collections;
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReliableReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  *
@@ -59,7 +59,7 @@ public class JtaBeforeCompletionMessage extends TXMessage {
 
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXMessage#operateOnTx(com.gemstone.gemfire.internal.cache.TXId)
+   * @see org.apache.geode.internal.cache.TXMessage#operateOnTx(org.apache.geode.internal.cache.TXId)
    */
   @Override
   protected boolean operateOnTx(TXId txId,DistributionManager dm) {
@@ -73,7 +73,7 @@ public class JtaBeforeCompletionMessage extends TXMessage {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return JTA_BEFORE_COMPLETION_MESSAGE;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/KeyInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/KeyInfo.java b/geode-core/src/main/java/org/apache/geode/internal/cache/KeyInfo.java
index 3065b47..1010054 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/KeyInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/KeyInfo.java
@@ -17,14 +17,14 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
 
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperFactory.java
index 707ee2d..8ca3c32 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperFactory.java
@@ -20,13 +20,13 @@
  * outside the context of the Region the loader invoked from.
  * @since GemFire 5.0
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.LoaderHelper;
+import org.apache.geode.cache.LoaderHelper;
 
 /**
  * The LoaderHelperFactory creates a LoaderHelper class which is used by a 
- * {@link com.gemstone.gemfire.cache.CacheLoader}.
+ * {@link org.apache.geode.cache.CacheLoader}.
  *  
  * @since GemFire 5.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperImpl.java
index 55a10b5..15eb988 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/LoaderHelperImpl.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 //import java.io.*;
 //import java.util.Set;
-import com.gemstone.gemfire.i18n.StringId;
+import org.apache.geode.i18n.StringId;
 
 /** Provides a set of APIs to help the
  * implementation of the <code>CacheLoader</code> load method. An instance of <code>LoaderHelper</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/LocalDataSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalDataSet.java b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalDataSet.java
index 62c95e1..0883581 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/LocalDataSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/LocalDataSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -31,41 +31,41 @@ import java.util.concurrent.locks.Lock;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.AttributesMutator;
-import com.gemstone.gemfire.cache.CacheLoaderException;
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionExistsException;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.DefaultQuery;
-import com.gemstone.gemfire.cache.query.internal.QueryExecutor;
-import com.gemstone.gemfire.cache.query.internal.QueryObserver;
-import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.LocalRegion.IteratorType;
-import com.gemstone.gemfire.internal.cache.LocalRegion.NonTXEntry;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.execute.InternalRegionFunctionContext;
-import com.gemstone.gemfire.internal.cache.snapshot.RegionSnapshotServiceImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.AttributesMutator;
+import org.apache.geode.cache.CacheLoaderException;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.DefaultQuery;
+import org.apache.geode.cache.query.internal.QueryExecutor;
+import org.apache.geode.cache.query.internal.QueryObserver;
+import org.apache.geode.cache.snapshot.RegionSnapshotService;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.LocalRegion.IteratorType;
+import org.apache.geode.internal.cache.LocalRegion.NonTXEntry;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.cache.execute.InternalRegionFunctionContext;
+import org.apache.geode.internal.cache.snapshot.RegionSnapshotServiceImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 
 /**


[04/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapUUIDKey.java
index 0c926dd..07f7d1b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryHeapUUIDKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeap.java
index b9c5a5c..d3c41cc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapIntKey.java
index d7e55f7..05138de 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapIntKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapLongKey.java
index bcef07f..3950c75 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapLongKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapObjectKey.java
index 2e5ecf1..c691765 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapObjectKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey1.java
index ae470d2..ef7902d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey1.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey2.java
index fa3936f..447feb6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapStringKey2.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapUUIDKey.java
index 382d1cc..d10ff7c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinRegionEntryOffHeapUUIDKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedCallbackArgument.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedCallbackArgument.java b/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedCallbackArgument.java
index 93fc533..6a6f591 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedCallbackArgument.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedCallbackArgument.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.Assert;
 
 /**
  * Used to create subclasses that wrap another callback argument by having

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedRegionMembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedRegionMembershipListener.java b/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedRegionMembershipListener.java
index be0bec4..4cd3db1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedRegionMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/WrappedRegionMembershipListener.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.RegionMembershipListener;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.RegionMembershipListener;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * WrappedRegionMembershipListener is used during initialization of new
@@ -58,7 +58,7 @@ class WrappedRegionMembershipListener implements
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.RegionMembershipListener#afterRemoteRegionCrash(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.RegionMembershipListener#afterRemoteRegionCrash(org.apache.geode.cache.RegionEvent)
    */
   public void afterRemoteRegionCrash(RegionEvent event) {
     synchronized(this.initLock) {
@@ -69,7 +69,7 @@ class WrappedRegionMembershipListener implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.RegionMembershipListener#afterRemoteRegionCreate(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.RegionMembershipListener#afterRemoteRegionCreate(org.apache.geode.cache.RegionEvent)
    */
   public void afterRemoteRegionCreate(RegionEvent event) {
     synchronized(this.initLock) {
@@ -80,7 +80,7 @@ class WrappedRegionMembershipListener implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.RegionMembershipListener#afterRemoteRegionDeparture(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.RegionMembershipListener#afterRemoteRegionDeparture(org.apache.geode.cache.RegionEvent)
    */
   public void afterRemoteRegionDeparture(RegionEvent event) {
     synchronized(this.initLock) {
@@ -91,7 +91,7 @@ class WrappedRegionMembershipListener implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.RegionMembershipListener#initialMembers(com.gemstone.gemfire.cache.Region, com.gemstone.gemfire.distributed.DistributedMember[])
+   * @see org.apache.geode.cache.RegionMembershipListener#initialMembers(org.apache.geode.cache.Region, org.apache.geode.distributed.DistributedMember[])
    */
   public void initialMembers(Region region, DistributedMember[] initialMembers) {
     synchronized(this.initLock) {
@@ -103,70 +103,70 @@ class WrappedRegionMembershipListener implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterCreate(com.gemstone.gemfire.cache.EntryEvent)
+   * @see org.apache.geode.cache.CacheListener#afterCreate(org.apache.geode.cache.EntryEvent)
    */
   public void afterCreate(EntryEvent event) {
     this.wrappedListener.afterCreate(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterDestroy(com.gemstone.gemfire.cache.EntryEvent)
+   * @see org.apache.geode.cache.CacheListener#afterDestroy(org.apache.geode.cache.EntryEvent)
    */
   public void afterDestroy(EntryEvent event) {
     this.wrappedListener.afterDestroy(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterInvalidate(com.gemstone.gemfire.cache.EntryEvent)
+   * @see org.apache.geode.cache.CacheListener#afterInvalidate(org.apache.geode.cache.EntryEvent)
    */
   public void afterInvalidate(EntryEvent event) {
     this.wrappedListener.afterInvalidate(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterRegionClear(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.CacheListener#afterRegionClear(org.apache.geode.cache.RegionEvent)
    */
   public void afterRegionClear(RegionEvent event) {
     this.wrappedListener.afterRegionClear(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterRegionCreate(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.CacheListener#afterRegionCreate(org.apache.geode.cache.RegionEvent)
    */
   public void afterRegionCreate(RegionEvent event) {
     this.wrappedListener.afterRegionCreate(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterRegionDestroy(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.CacheListener#afterRegionDestroy(org.apache.geode.cache.RegionEvent)
    */
   public void afterRegionDestroy(RegionEvent event) {
     this.wrappedListener.afterRegionDestroy(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterRegionInvalidate(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.CacheListener#afterRegionInvalidate(org.apache.geode.cache.RegionEvent)
    */
   public void afterRegionInvalidate(RegionEvent event) {
     this.wrappedListener.afterRegionInvalidate(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterRegionLive(com.gemstone.gemfire.cache.RegionEvent)
+   * @see org.apache.geode.cache.CacheListener#afterRegionLive(org.apache.geode.cache.RegionEvent)
    */
   public void afterRegionLive(RegionEvent event) {
     this.wrappedListener.afterRegionLive(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheListener#afterUpdate(com.gemstone.gemfire.cache.EntryEvent)
+   * @see org.apache.geode.cache.CacheListener#afterUpdate(org.apache.geode.cache.EntryEvent)
    */
   public void afterUpdate(EntryEvent event) {
     this.wrappedListener.afterUpdate(event);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.CacheCallback#close()
+   * @see org.apache.geode.cache.CacheCallback#close()
    */
   public void close() {
     this.wrappedListener.close();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/compression/CompressedCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/compression/CompressedCachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/compression/CompressedCachedDeserializable.java
index 59e249d..6ed8ded 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/compression/CompressedCachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/compression/CompressedCachedDeserializable.java
@@ -15,24 +15,24 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.compression;
+package org.apache.geode.internal.cache.compression;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.cache.BytesAndBitsForCompactor;
-import com.gemstone.gemfire.internal.cache.CachedDeserializable;
-import com.gemstone.gemfire.internal.cache.CachedDeserializableFactory;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.lru.Sizeable;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.cache.BytesAndBitsForCompactor;
+import org.apache.geode.internal.cache.CachedDeserializable;
+import org.apache.geode.internal.cache.CachedDeserializableFactory;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.lru.Sizeable;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
 
 /**
  * An abstract implementation of {@link CachedDeserializable} that prefers serialization and compresses

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/compression/SnappyCompressedCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/compression/SnappyCompressedCachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/compression/SnappyCompressedCachedDeserializable.java
index e32fd36..b8bfc8f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/compression/SnappyCompressedCachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/compression/SnappyCompressedCachedDeserializable.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.compression;
+package org.apache.geode.internal.cache.compression;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.compression.SnappyCompressor;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.compression.SnappyCompressor;
+import org.apache.geode.internal.Version;
 
 /**
  * An implementation of {@link CompressedCachedDeserializable} that uses the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/FilterByPath.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/FilterByPath.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/FilterByPath.java
index c814eee..6fd0cc5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/FilterByPath.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/FilterByPath.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/HeapMemoryMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/HeapMemoryMonitor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/HeapMemoryMonitor.java
index eeaad42..8636ccd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/HeapMemoryMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/HeapMemoryMonitor.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
-import com.gemstone.gemfire.internal.statistics.LocalStatListener;
-import com.gemstone.gemfire.internal.SetUtils;
-import com.gemstone.gemfire.internal.statistics.StatisticsImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds.MemoryState;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.internal.cache.control;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
+import org.apache.geode.internal.statistics.LocalStatListener;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.statistics.StatisticsImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryThresholds.MemoryState;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import javax.management.ListenerNotFoundException;
@@ -759,7 +759,7 @@ public void stopMonitoring() {
   
   class LocalHeapStatListener implements LocalStatListener {
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.statistics.LocalStatListener#statValueChanged(double)
+     * @see org.apache.geode.internal.statistics.LocalStatListener#statValueChanged(double)
      */
     @Override
     @SuppressWarnings("synthetic-access")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/InternalResourceManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/InternalResourceManager.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/InternalResourceManager.java
index 4547d4a..a32dff3 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/InternalResourceManager.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/InternalResourceManager.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.control.RebalanceFactory;
-import com.gemstone.gemfire.cache.control.RebalanceOperation;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.OverflowQueueWithDMStats;
-import com.gemstone.gemfire.distributed.internal.SerialQueuedExecutorWithDMStats;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
-import com.gemstone.gemfire.internal.cache.partitioned.LoadProbe;
-import com.gemstone.gemfire.internal.cache.partitioned.SizedBasedLoadProbe;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.internal.cache.control;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.control.RebalanceFactory;
+import org.apache.geode.cache.control.RebalanceOperation;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.OverflowQueueWithDMStats;
+import org.apache.geode.distributed.internal.SerialQueuedExecutorWithDMStats;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
+import org.apache.geode.internal.cache.partitioned.LoadProbe;
+import org.apache.geode.internal.cache.partitioned.SizedBasedLoadProbe;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;
@@ -505,7 +505,7 @@ public class InternalResourceManager implements ResourceManager {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DistributionAdvisee#getCancelCriterion()
+   * @see org.apache.geode.distributed.internal.DistributionAdvisee#getCancelCriterion()
    */
   public CancelCriterion getCancelCriterion() {
     return this.cache.getCancelCriterion();
@@ -529,7 +529,7 @@ public class InternalResourceManager implements ResourceManager {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.control.ResourceManager#setEvictionHeapPercentage(int)
+   * @see org.apache.geode.cache.control.ResourceManager#setEvictionHeapPercentage(int)
    */
   @Override
   public void setCriticalOffHeapPercentage(float offHeapPercentage) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryEvent.java
index 3b54b50..17b37ba 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryEvent.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds.MemoryState;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryThresholds.MemoryState;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryThresholds.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryThresholds.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryThresholds.java
index 3da07f7..f2f8c57 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryThresholds.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/MemoryThresholds.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/OffHeapMemoryMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/OffHeapMemoryMonitor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/OffHeapMemoryMonitor.java
index 855d904..30d0395 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/OffHeapMemoryMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/OffHeapMemoryMonitor.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds.MemoryState;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.offheap.MemoryAllocator;
-import com.gemstone.gemfire.internal.offheap.MemoryUsageListener;
+import org.apache.geode.CancelException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryThresholds.MemoryState;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.offheap.MemoryAllocator;
+import org.apache.geode.internal.offheap.MemoryUsageListener;
 
 /**
  * Allows for the setting of eviction and critical thresholds. These thresholds

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/PartitionRebalanceDetailsImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/PartitionRebalanceDetailsImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/PartitionRebalanceDetailsImpl.java
index 0e0383e..2411b0e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/PartitionRebalanceDetailsImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/PartitionRebalanceDetailsImpl.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.io.Serializable;
 import java.util.Set;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.partition.PartitionMemberInfo;
-import com.gemstone.gemfire.cache.partition.PartitionRebalanceInfo;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.cache.partition.PartitionMemberInfo;
+import org.apache.geode.cache.partition.PartitionRebalanceInfo;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 /**
  * Holds the rebalancing details for a single partitioned

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceOperationImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceOperationImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceOperationImpl.java
index 9ff95fc..d32bd50 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceOperationImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceOperationImpl.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.control.RebalanceOperation;
-import com.gemstone.gemfire.cache.control.RebalanceResults;
-import com.gemstone.gemfire.cache.partition.PartitionRebalanceInfo;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionRebalanceOp;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.CompositeDirector;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.GemFireException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.control.RebalanceOperation;
+import org.apache.geode.cache.control.RebalanceResults;
+import org.apache.geode.cache.partition.PartitionRebalanceInfo;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.partitioned.PartitionedRegionRebalanceOp;
+import org.apache.geode.internal.cache.partitioned.rebalance.CompositeDirector;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceResultsImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceResultsImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceResultsImpl.java
index 911c249..07a0fc4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceResultsImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RebalanceResultsImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.io.Serializable;
 import java.util.Set;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.control.RebalanceResults;
-import com.gemstone.gemfire.cache.partition.PartitionRebalanceInfo;
+import org.apache.geode.cache.control.RebalanceResults;
+import org.apache.geode.cache.partition.PartitionRebalanceInfo;
 
 public class RebalanceResultsImpl implements RebalanceResults, Serializable {
   private Set<PartitionRebalanceInfo> detailSet = new TreeSet<PartitionRebalanceInfo>();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionFilter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionFilter.java
index 43b14aa..090608b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/RegionFilter.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceAdvisor.java
index 415fa3c..e2790d5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceAdvisor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,27 +27,27 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.UpdateAttributesProcessor;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds.MemoryState;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DSCODE;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.UpdateAttributesProcessor;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryThresholds.MemoryState;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * The advisor associated with a {@link ResourceManager}.  Allows knowledge of
@@ -89,7 +89,7 @@ public class ResourceAdvisor extends DistributionAdvisor {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.DistributionMessage#process(com.gemstone.gemfire.distributed.internal.DistributionManager)
+     * @see org.apache.geode.distributed.internal.DistributionMessage#process(org.apache.geode.distributed.internal.DistributionManager)
      */
     @Override
     protected void process(DistributionManager dm) {
@@ -141,7 +141,7 @@ public class ResourceAdvisor extends DistributionAdvisor {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+     * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
      */
     @Override
     public int getDSFID() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceEvent.java
index ae62ffb..10f8c90 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceEvent.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceListener.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceListener.java
index 79725b7..253bb6b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceListener.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 /**
- * Provides notification of {@link com.gemstone.gemfire.cache.Cache}
+ * Provides notification of {@link org.apache.geode.cache.Cache}
  * resource management events.
  * 
  * @since GemFire 6.0

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceManagerStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceManagerStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceManagerStats.java
index 3281273..a1e9aee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceManagerStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceManagerStats.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.distributed.internal.PoolStatHelper;
-import com.gemstone.gemfire.distributed.internal.QueueStatHelper;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.distributed.internal.PoolStatHelper;
+import org.apache.geode.distributed.internal.QueueStatHelper;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * Contains methods for manipulating resource manager statistics.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceMonitor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceMonitor.java
index 27b725d..fe7eb05 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/control/ResourceMonitor.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.control;
+package org.apache.geode.internal.cache.control;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
 
 /**
  * Implemented by classes that the ResourceManager creates in order to monitor a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/AbstractExecution.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/AbstractExecution.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/AbstractExecution.java
index 852301c..202bca6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/AbstractExecution.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/AbstractExecution.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Collection;
 import java.util.Collections;
@@ -25,26 +25,26 @@ import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Abstract implementation of InternalExecution interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/BucketMovedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/BucketMovedException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/BucketMovedException.java
index aa489f1..d4fdec2 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/BucketMovedException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/BucketMovedException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 public class BucketMovedException extends GemFireException {
     private static final long serialVersionUID = 4893171227542647452L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DefaultResultCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DefaultResultCollector.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DefaultResultCollector.java
index 470a540..aabc842 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DefaultResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DefaultResultCollector.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.ArrayList;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Default implementation of ResultCollector interface. DefaultResultCollector

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionExecutor.java
index 0053bf8..4b065c5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionExecutor.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 /**
  * Executes Function on Distributed Regions.
  * 
@@ -407,7 +407,7 @@ public class DistributedRegionFunctionExecutor extends AbstractExecution {
     return buf.toString();
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.execute.AbstractExecution#validateExecution(com.gemstone.gemfire.cache.execute.Function, java.util.Set)
+   * @see org.apache.geode.internal.cache.execute.AbstractExecution#validateExecution(org.apache.geode.cache.execute.Function, java.util.Set)
    */
   @Override
   public void validateExecution(Function function, Set targetMembers) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
index d3e4338..f8ec7a0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.cache.DistributedRegionFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.cache.DistributedRegionFunctionStreamingMessage;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultWaiter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultWaiter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultWaiter.java
index 2ee5105..19701c1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultWaiter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultWaiter.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.HashMap;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.DistributedRegionFunctionStreamingMessage;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.DistributedRegionFunctionStreamingMessage;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionContextImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionContextImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionContextImpl.java
index 9b5ce0f..27a1a55 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionContextImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionContextImpl.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.cache.execute.ResultSender;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.execute.ResultSender;
 
 /**
  * Context available to application functions which is passed from GemFire to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionExecutionNodePruner.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionExecutionNodePruner.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionExecutionNodePruner.java
index 0201ba9..6c5c7ec 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionExecutionNodePruner.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionExecutionNodePruner.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.ArrayList;
 import java.util.HashMap;
@@ -26,13 +26,13 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionRemoteContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionRemoteContext.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionRemoteContext.java
index 72b6f66..7304e4f 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionRemoteContext.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionRemoteContext.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,10 +22,10 @@ import java.io.IOException;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionService;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
 /**
  * FunctionContext for remote/target nodes
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionServiceStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionServiceStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionServiceStats.java
index b4ad43b..272aef1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionServiceStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionServiceStats.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.internal.statistics.DummyStatisticsImpl;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.internal.cache.execute;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.internal.statistics.DummyStatisticsImpl;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 public class FunctionServiceStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStats.java
index 88a8b10..f703529 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStats.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.statistics.DummyStatisticsImpl;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.internal.cache.execute;
+
+import org.apache.geode.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.statistics.DummyStatisticsImpl;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 public class FunctionStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
index 359ae6b..cc6ac5b 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -28,27 +28,27 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.FunctionStreamingReplyMessage;
-import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.FunctionStreamingReplyMessage;
+import org.apache.geode.internal.cache.PrimaryBucketException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalExecution.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalExecution.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalExecution.java
index 81944ef..7c22cfc 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalExecution.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalExecution.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
 
 /**
  * Internal interface that adds some internal methods to the Execution interface.
@@ -47,7 +47,7 @@ public interface InternalExecution extends Execution {
    * @return an Execution with the filter
    * @throws UnsupportedOperationException
    *           if not called after
-   *           {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)}
+   *           {@link FunctionService#onRegion(org.apache.geode.cache.Region)}
    * @since Geode 1.0
    */
   public InternalExecution withBucketFilter(Set<Integer> bucketIDs);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionException.java
index 80e467c..e75aa97 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/InternalFunctionException.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.execute;
+package org.apache.geode.internal.cache.execute;
 
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
 
 /**
  * This is an exception used internally when the function sends the exception.



[77/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JmxManagerFinder.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JmxManagerFinder.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JmxManagerFinder.java
deleted file mode 100644
index f2d211a..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/JmxManagerFinder.java
+++ /dev/null
@@ -1,169 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import java.io.DataInputStream;
-import java.io.DataOutputStream;
-import java.io.IOException;
-import java.net.InetAddress;
-import java.net.InetSocketAddress;
-import java.net.Socket;
-import java.net.SocketAddress;
-
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.ConnectionUtil;
-
-/**
- * This class can be used to connect to a locator and ask it to find a jmx
- * manager. If the locator can find a jmx manager that is already running it
- * returns it. Otherwise the locator will attempt to start a jmx manager and
- * then return it.
- * 
- * This code does not depend on gemfire.jar but in order to do this some of
- * GemFire's internal serialization codes and byte sequences have been hard
- * coded into this code.
- * 
- * @since GemFire version 7.0.Beta 2012-09-23
- * 
- */
-public class JmxManagerFinder {
-
-  private final static PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-
-  /*
-   * public static void main(String[] args) throws IOException { if (args.length
-   * != 2) { System.err.println(
-   * "Usage: JmxManagerFinder locatorHost locatorPort. Expected two arguments but found "
-   * + args.length); return; } String locatorHost = args[0]; int locatorPort =
-   * Integer.parseInt(args[1]);
-   * 
-   * InetAddress addr = InetAddress.getByName(locatorHost); JmxManagerInfo
-   * locRes = askLocatorForJmxManager(addr, locatorPort, 15000);
-   * 
-   * if (locRes.port == 0) {
-   * System.out.println("Locator could not find a jmx manager"); } else {
-   * System.out.println("Locator on host " + locRes.host + " port " +
-   * locRes.port + (locRes.ssl ? " ssl" : "")); } }
-   */
-  private static final short JMX_MANAGER_LOCATOR_REQUEST = 2150;
-  private static final short JMX_MANAGER_LOCATOR_RESPONSE = 2151;
-  private static final byte DS_FIXED_ID_SHORT = 2;
-  private static final int GOSSIPVERSION = 1001;
-  private static final byte STRING_BYTES = 87;
-  private static final byte NULL_STRING = 69;
-
-  /**
-   * Describes the location of a jmx manager. If a jmx manager does not exist
-   * then port will be 0.
-   * 
-   * 
-   */
-  public static class JmxManagerInfo {
-    JmxManagerInfo(String host, int port, boolean ssl) {
-      this.host = host;
-      this.port = port;
-      this.ssl = ssl;
-    }
-
-    /**
-     * The host/address the jmx manager is listening on.
-     */
-    public final String host;
-    /**
-     * The port the jmx manager is listening on.
-     */
-    public final int port;
-    /**
-     * True if the jmx manager is using SSL.
-     */
-    public final boolean ssl;
-  }
-
-  /**
-   * Ask a locator to find a jmx manager. The locator will start one if one is
-   * not already running.
-   * 
-   * @param addr
-   *          the host address the locator is listening on
-   * @param port
-   *          the port the locator is listening on
-   * @param timeout
-   *          the number of milliseconds to wait for a response; 15000 is a
-   *          reasonable default
-   * @return describes the location of the jmx manager. The port will be zero if
-   *         no jmx manager was found.
-   * @throws IOException
-   *           if a problem occurs trying to connect to the locator or
-   *           communicate with it.
-   */
-  public static JmxManagerInfo askLocatorForJmxManager(InetAddress addr,
-      int port, int timeout, boolean usessl) throws IOException {
-    SocketAddress sockaddr = new InetSocketAddress(addr, port);
-    Socket sock = ConnectionUtil.getSocketFactory(usessl).createSocket();
-    try {
-      sock.connect(sockaddr, timeout);
-      sock.setSoTimeout(timeout);
-      DataOutputStream out = new DataOutputStream(sock.getOutputStream());
-
-      out.writeInt(GOSSIPVERSION);
-      out.writeByte(DS_FIXED_ID_SHORT);
-      out.writeShort(JMX_MANAGER_LOCATOR_REQUEST);
-      out.flush();
-
-      DataInputStream in = new DataInputStream(sock.getInputStream());
-      byte header = in.readByte();
-      if (header != DS_FIXED_ID_SHORT) {
-        throw new IllegalStateException("Expected " + DS_FIXED_ID_SHORT
-            + " but found " + header);
-      }
-      int msgType = in.readShort();
-      if (msgType != JMX_MANAGER_LOCATOR_RESPONSE) {
-        throw new IllegalStateException("Expected "
-            + JMX_MANAGER_LOCATOR_RESPONSE + " but found " + msgType);
-      }
-      byte hostHeader = in.readByte();
-      String host;
-      if (hostHeader == NULL_STRING) {
-        host = "";
-      } else if (hostHeader == STRING_BYTES) {
-        int len = in.readUnsignedShort();
-        byte[] buf = new byte[len];
-        in.readFully(buf, 0, len);
-        @SuppressWarnings("deprecation")
-        String str = new String(buf, 0);
-        host = str;
-      } else {
-        throw new IllegalStateException("Expected " + STRING_BYTES + " or "
-            + NULL_STRING + " but found " + hostHeader);
-      }
-      int jmport = in.readInt();
-      boolean ssl = in.readBoolean();
-      if (host.equals("")) {
-        jmport = 0;
-      }
-      return new JmxManagerInfo(host, jmport, ssl);
-    } finally {
-      try {
-        sock.close();
-      } catch (Exception e) {
-      }
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConfig.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConfig.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConfig.java
deleted file mode 100644
index cfd6b62..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConfig.java
+++ /dev/null
@@ -1,139 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import java.util.logging.Level;
-
-/**
- * Class PulseConfig
- * 
- * PulseConfig is used for configuring Pulse application.
- * 
- * @since GemFire 7.0.1
- * 
- */
-public class PulseConfig {
-
-  // Log file name
-  private String LogFileName;
-
-  // Log file location
-  private String LogFileLocation;
-
-  // Log file size in MBs
-  private int logFileSize;
-
-  // Number of cyclic log files
-  private int logFileCount;
-
-  // Log messages date pattern
-  private String logDatePattern;
-
-  // Log level
-  private Level logLevel;
-
-  // Flag for appending log messages
-  private Boolean logAppend;
-
-  // Query history log file
-  private String queryHistoryFileName;
-
-  public PulseConfig() {
-    this.setLogFileName(PulseConstants.PULSE_LOG_FILE_NAME);
-    this.LogFileLocation = PulseConstants.PULSE_LOG_FILE_LOCATION;
-    this.logFileSize = PulseConstants.PULSE_LOG_FILE_SIZE;
-    this.logFileCount = PulseConstants.PULSE_LOG_FILE_COUNT;
-    this.logDatePattern = PulseConstants.PULSE_LOG_MESSAGE_DATE_PATTERN;
-    this.logLevel = PulseConstants.PULSE_LOG_LEVEL;
-    this.logAppend = PulseConstants.PULSE_LOG_APPEND;
-    this.queryHistoryFileName = PulseConstants.PULSE_QUERY_HISTORY_FILE_LOCATION
-      + System.getProperty("file.separator")
-      + PulseConstants.PULSE_QUERY_HISTORY_FILE_NAME;
-
-  }
-
-  public String getLogFileName() {
-    return LogFileName;
-  }
-
-  public void setLogFileName(String logFileName) {
-    this.LogFileName = logFileName + "_%g.log";
-  }
-
-  public String getLogFileLocation() {
-    return LogFileLocation;
-  }
-
-  public void setLogFileLocation(String logFileLocation) {
-    this.LogFileLocation = logFileLocation;
-  }
-
-  public String getLogFileFullName() {
-    return this.LogFileLocation + "/" + this.LogFileName;
-  }
-
-  public int getLogFileSize() {
-    return logFileSize;
-  }
-
-  public void setLogFileSize(int logFileSize) {
-    this.logFileSize = logFileSize;
-  }
-
-  public int getLogFileCount() {
-    return logFileCount;
-  }
-
-  public void setLogFileCount(int logFileCount) {
-    this.logFileCount = logFileCount;
-  }
-
-  public String getLogDatePattern() {
-    return logDatePattern;
-  }
-
-  public void setLogDatePattern(String logDatePattern) {
-    this.logDatePattern = logDatePattern;
-  }
-
-  public Level getLogLevel() {
-    return logLevel;
-  }
-
-  public void setLogLevel(Level logLevel) {
-    this.logLevel = logLevel;
-  }
-
-  public Boolean getLogAppend() {
-    return logAppend;
-  }
-
-  public void setLogAppend(Boolean logAppend) {
-    this.logAppend = logAppend;
-  }
-
-  public String getQueryHistoryFileName() {
-    return queryHistoryFileName;
-  }
-
-  public void setQueryHistoryFileName(String queryHistoryFileName) {
-    this.queryHistoryFileName = queryHistoryFileName;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
deleted file mode 100644
index c9e711a..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseConstants.java
+++ /dev/null
@@ -1,434 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import java.util.logging.Level;
-
-public class PulseConstants {
-
-  public static final String APP_NAME = "PULSE";
-  public static final String PULSE_LOG_FILE = APP_NAME + ".log";
-  // public static final String PULSE_LOG_FILE_LOCATION =
-  // System.getProperty("user.home");
-  public static final String PULSE_PROPERTIES_FILE = "pulse.properties";
-  public static final String PULSE_SECURITY_PROPERTIES_FILE = "pulsesecurity.properties";
-  public static final String PULSE_NOTIFICATION_ALERT_DATE_PATTERN = "yyyy-MM-dd'T'HH:mm'Z'";
-  public static final String LOG_MESSAGE_DATE_PATTERN = "yyyy/MM/dd HH:mm:ss.SSS z";
-
-  public static final String LOG_MESSAGES_FILE = "LogMessages";
-  public static final String APPLICATION_LANGUAGE = "en";
-  public static final String APPLICATION_COUNTRY = "US";
-
-  // Pulse version details properties from properties file
-  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";
-  public static final String PROPERTY_SOURCE_REVISION = "Source-Revision";
-  public static final String PROPERTY_SOURCE_REPOSITORY = "Source-Repository";
-
-  // DEFAULT CONFIGUARTION VALUES FOR PULSE LOGGER
-  // Log File
-  public static final String PULSE_QUERY_HISTORY_FILE_NAME = APP_NAME
-      + "_QueryHistory.json";
-  // Log File location
-  public static final String PULSE_QUERY_HISTORY_FILE_LOCATION = System
-      .getProperty("user.home");
-  // Date pattern to be used in log messages
-  public static final String PULSE_QUERY_HISTORY_DATE_PATTERN = "EEE, MMM dd yyyy, HH:mm:ss z";
-
-  // Decimal format pattern "###.##" and "0.0000"
-  public static final String DECIMAL_FORMAT_PATTERN = "###.##";
-  public static final String DECIMAL_FORMAT_PATTERN_2 = "0.0000";
-
-  // DEFAULT VALUES
-  public static final String GEMFIRE_DEFAULT_HOST = "localhost";
-  public static final String GEMFIRE_DEFAULT_PORT = "1099";
-
-  // DEFAULT CONFIGUARTION VALUES FOR PULSE LOGGER
-  // Log File
-  public static final String PULSE_LOG_FILE_NAME = APP_NAME;
-  // Log File location
-  public static final String PULSE_LOG_FILE_LOCATION = System
-      .getProperty("user.home");
-  // Date pattern to be used in log messages
-  public static final String PULSE_LOG_MESSAGE_DATE_PATTERN = "yyyy/MM/dd HH:mm:ss.SSS z";
-  // Log file size - 1MB.
-  public static final int PULSE_LOG_FILE_SIZE = 1024 * 1024;
-  // The log file count - 4 files.
-  public static final int PULSE_LOG_FILE_COUNT = 4;
-  // Append logs - true.
-  public static final boolean PULSE_LOG_APPEND = true;
-  // Log level - FINE
-  public static final Level PULSE_LOG_LEVEL = Level.FINE;
-
-  // SYSTEM PROPERTIES
-  public static final String SYSTEM_PROPERTY_PULSE_EMBEDDED = "pulse.embedded";
-  public static final String SYSTEM_PROPERTY_PULSE_EMBEDDED_SQLF = "pulse.embedded.sqlf";
-  public static final String SYSTEM_PROPERTY_PULSE_USELOCATOR = "pulse.useLocator";
-  public static final String SYSTEM_PROPERTY_PULSE_HOST = "pulse.host";
-  public static final String SYSTEM_PROPERTY_PULSE_PORT = "pulse.port";
-
-  // APPLICATION PROPERTIES
-  public static final String APPLICATION_PROPERTY_PULSE_USELOCATOR = "pulse.useLocator";
-  public static final String APPLICATION_PROPERTY_PULSE_HOST = "pulse.host";
-  public static final String APPLICATION_PROPERTY_PULSE_PORT = "pulse.port";
-  public static final String APPLICATION_PROPERTY_PULSE_JMXUSERNAME = "pulse.jmxUserName";
-  public static final String APPLICATION_PROPERTY_PULSE_JMXPASSWORD = "pulse.jmxUserPassword";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGFILENAME = "pulse.Log-File-Name";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGFILELOCATION = "pulse.Log-File-Location";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGFILESIZE = "pulse.Log-File-Size";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGFILECOUNT = "pulse.Log-File-Count";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN = "pulse.Log-Date-Pattern";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGLEVEL = "pulse.Log-Level";
-  public static final String APPLICATION_PROPERTY_PULSE_LOGAPPEND = "pulse.Log-Append";
-  public static final String APPLICATION_PROPERTY_PULSE_PRODUCTSUPPORT = "pulse.product";
-  public static final String APPLICATION_PROPERTY_PULSE_SEC_PROFILE_GEMFIRE = "pulse.authentication.gemfire";
-  public static final String APPLICATION_PROPERTY_PULSE_SEC_PROFILE_DEFAULT = "pulse.authentication.default";
-  public static final String APPLICATION_PROPERTY_PULSE_SPRING_PROFILE_KEY = "spring.profiles.default";
-
-  // STRING FLAGS
-  public static final String STRING_FLAG_TRUE = "true";
-  public static final String STRING_FLAG_FALSE = "false";
-  public static final String DEFAULT_SERVER_GROUP = "Default";
-  public static final String DEFAULT_REDUNDANCY_ZONE = "Default";
-  public static final String JVM_PAUSES_TYPE_CLUSTER = "cluster";
-  public static final String JVM_PAUSES_TYPE_MEMBER = "member";
-
-  // CONSTANTS FOR MBEAN DATA
-  public static final String OBJECT_DOMAIN_NAME_GEMFIRE = "GemFire";
-  public static final String OBJECT_DOMAIN_NAME_SQLFIRE = "GemFireXD";
-  public static final String OBJECT_NAME_MEMBER = OBJECT_DOMAIN_NAME_GEMFIRE + ":type=Member,*";
-  public static final String OBJECT_NAME_MEMBER_MANAGER = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Manager,type=Member,*";
-  public static final String OBJECT_NAME_SYSTEM_DISTRIBUTED = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=System,type=Distributed";
-  public static final String OBJECT_NAME_REGION_DISTRIBUTED = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Region,type=Distributed,*";
-  public static final String OBJECT_NAME_STATEMENT_DISTRIBUTED = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Statement,type=Aggregate,*";
-  public static final String OBJECT_NAME_SF_CLUSTER = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Cluster";
-  public static final String OBJECT_NAME_SF_MEMBER_PATTERN = OBJECT_DOMAIN_NAME_SQLFIRE + ":group=*,type=Member,member=";
-  public static final String OBJECT_NAME_TABLE_AGGREGATE = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Table,type=Aggregate,table=*";
-  public static final String OBJECT_NAME_TABLE_AGGREGATE_PATTERN = OBJECT_DOMAIN_NAME_SQLFIRE + ":service=Table,type=Aggregate,table=";
-  public static final String OBJECT_NAME_REGION_ON_MEMBER_REGION = OBJECT_DOMAIN_NAME_GEMFIRE + ":service=Region,name=";
-  public static final String OBJECT_NAME_REGION_ON_MEMBER_MEMBER = ",type=Member,member=";
-  public static final String OBJECT_NAME_ACCESSCONTROL_MBEAN = "GemFire:service=AccessControl,type=Distributed";
-
-  public static final String MBEAN_KEY_PROPERTY_SERVICE = "service";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_REGION = "Region";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_CACHESERVER = "CacheServer";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYRECEIVER = "GatewayReceiver";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYSENDER = "GatewaySender";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_ASYNCEVENTQUEUE = "AsyncEventQueue";
-  public static final String MBEAN_KEY_PROPERTY_SERVICE_VALUE_LOCATOR = "Locator";
-  public static final String MBEAN_KEY_PROPERTY_REGION_NAME = "name";
-
-  public static final String MBEAN_KEY_PROPERTY_MEMBER = "member";
-
-  public static final String MBEAN_ATTRIBUTE_MEMBER = "Member";
-  public static final String MBEAN_ATTRIBUTE_MEMBERS = "Members";
-  public static final String MBEAN_ATTRIBUTE_MANAGER = "Manager";
-  public static final String MBEAN_ATTRIBUTE_LOCATOR = "Locator";
-  public static final String MBEAN_ATTRIBUTE_SERVER = "Server";
-  public static final String MBEAN_ATTRIBUTE_SERVERGROUPS = "Groups";
-  public static final String MBEAN_ATTRIBUTE_REDUNDANCYZONES = "RedundancyZone";
-  public static final String MBEAN_ATTRIBUTE_DATASTORE = "DataStore";
-  public static final String MBEAN_ATTRIBUTE_ID = "Id";
-
-  public static final String MBEAN_ATTRIBUTE_GEMFIREVERSION = "Version";
-  public static final String MBEAN_ATTRIBUTE_MEMBERCOUNT = "MemberCount";
-  public static final String MBEAN_ATTRIBUTE_NUMCLIENTS = "NumClients";
-  public static final String MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS = "NetworkServerClientConnectionStats";
-  public static final String MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID = "DistributedSystemId";
-  public static final String MBEAN_ATTRIBUTE_LOCATORCOUNT = "LocatorCount";
-  public static final String MBEAN_ATTRIBUTE_TOTALREGIONCOUNT = "TotalRegionCount";
-  public static final String MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION = "NumRunningFunctions";
-  public static final String MBEAN_ATTRIBUTE_PROCEDURECALLSCOMPLETED = "ProcedureCallsCompleted";
-  public static final String MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS = "ProcedureCallsInProgress";
-  public static final String MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT = "RegisteredCQCount";
-  public static final String MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS = "NumSubscriptions";
-  public static final String MBEAN_ATTRIBUTE_NUMTXNCOMMITTED = "TransactionCommitted";
-  public static final String MBEAN_ATTRIBUTE_NUMTXNROLLBACK = "TransactionRolledBack";
-  public static final String MBEAN_ATTRIBUTE_TOTALHEAPSIZE = "TotalHeapSize";
-  public static final String MBEAN_ATTRIBUTE_USEDHEAPSIZE = "UsedHeapSize";
-  public static final String MBEAN_ATTRIBUTE_OFFHEAPFREESIZE = "OffHeapFreeSize";
-  public static final String MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE = "OffHeapUsedSize";
-  public static final String MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT = "TotalRegionEntryCount";
-  public static final String MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT = "CurrentQueryCount";
-  public static final String MBEAN_ATTRIBUTE_TOTALDISKUSAGE = "TotalDiskUsage";
-  public static final String MBEAN_ATTRIBUTE_DISKWRITESRATE = "DiskWritesRate";
-  public static final String MBEAN_ATTRIBUTE_AVERAGEWRITES = "AverageWrites";
-  public static final String MBEAN_ATTRIBUTE_DISKREADSRATE = "DiskReadsRate";
-  public static final String MBEAN_ATTRIBUTE_AVERAGEREADS = "AverageReads";
-  public static final String MBEAN_ATTRIBUTE_QUERYREQUESTRATE = "QueryRequestRate";
-  public static final String MBEAN_ATTRIBUTE_JVMPAUSES = "JVMPauses";
-  public static final String MBEAN_ATTRIBUTE_HOST = "Host";
-  public static final String MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS = "HostnameForClients";
-  public static final String MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT = "HostNameForClients";
-  public static final String MBEAN_ATTRIBUTE_BINDADDRESS = "BindAddress";
-  public static final String MBEAN_ATTRIBUTE_PORT = "Port";
-  public static final String MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE = "EventsReceivedRate";
-  public static final String MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME = "AverageBatchProcessingTime";
-  public static final String MBEAN_ATTRIBUTE_RUNNING = "Running";
-  public static final String MBEAN_ATTRIBUTE_BATCHSIZE = "BatchSize";
-  public static final String MBEAN_ATTRIBUTE_SENDERID = "SenderId";
-  public static final String MBEAN_ATTRIBUTE_EVENTQUEUESIZE = "EventQueueSize";
-  public static final String MBEAN_ATTRIBUTE_PRIMARY = "Primary";
-  public static final String MBEAN_ATTRIBUTE_PERSISTENCEENABLED = "PersistenceEnabled";
-  public static final String MBEAN_ATTRIBUTE_PARALLEL = "Parallel";
-  public static final String MBEAN_ATTRIBUTE_REMOTE_DS_ID = "RemoteDSId";
-  public static final String MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD = "EventsExceedingAlertThreshold";
-  public static final String MBEAN_ATTRIBUTE_FULLPATH = "FullPath";
-  public static final String MBEAN_ATTRIBUTE_EMPTYNODES = "EmptyNodes";
-  public static final String MBEAN_ATTRIBUTE_GETSRATE = "GetsRate";
-  public static final String MBEAN_ATTRIBUTE_PUTSRATE = "PutsRate";
-  public static final String MBEAN_ATTRIBUTE_LRUEVICTIONRATE = "LruEvictionRate";
-  public static final String MBEAN_ATTRIBUTE_REGIONTYPE = "RegionType";
-  public static final String MBEAN_ATTRIBUTE_ENTRYSIZE = "EntrySize";
-  public static final String MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT = "SystemRegionEntryCount";
-  public static final String MBEAN_ATTRIBUTE_PERSISTENTENABLED = "PersistentEnabled";
-  public static final String MBEAN_ATTRIBUTE_NAME = "Name";
-  public static final String MBEAN_ATTRIBUTE_GATEWAYENABLED = "GatewayEnabled";
-  public static final String MBEAN_ATTRIBUTE_DISKUSAGE = "DiskUsage";
-  public static final String MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN = "TotalFileDescriptorOpen";
-  public static final String MBEAN_ATTRIBUTE_LOADAVERAGE = "LoadAverage";
-  public static final String MBEAN_ATTRIBUTE_CURRENTHEAPSIZE = "CurrentHeapSize"; // deprecated in Gemfire8.1
-  public static final String MBEAN_ATTRIBUTE_USEDMEMORY = "UsedMemory";
-  public static final String MBEAN_ATTRIBUTE_MAXIMUMHEAPSIZE = "MaximumHeapSize"; // deprecated in Gemfire8.1
-  public static final String MBEAN_ATTRIBUTE_MAXMEMORY = "MaxMemory";
-  public static final String MBEAN_ATTRIBUTE_NUMTHREADS = "NumThreads";
-  public static final String MBEAN_ATTRIBUTE_MEMBERUPTIME = "MemberUpTime";
-  public static final String MBEAN_ATTRIBUTE_TOTALBYTESONDISK = "TotalBytesOnDisk";
-  public static final String MBEAN_ATTRIBUTE_CPUUSAGE = "CpuUsage";
-  public static final String MBEAN_ATTRIBUTE_HOSTCPUUSAGE = "HostCpuUsage";
-  public static final String MBEAN_ATTRIBUTE_ENTRYCOUNT = "EntryCount";
-  public static final String MBEAN_ATTRIBUTE_NUMBEROFROWS = "NumberOfRows";
-  public static final String MBEAN_ATTRIBUTE_LOCALMAXMEMORY = "LocalMaxMemory";
-
-  public static final String MBEAN_ATTRIBUTE_NUMTIMESCOMPILED = "NumTimesCompiled";
-  public static final String MBEAN_ATTRIBUTE_NUMEXECUTION = "NumExecution";
-  public static final String MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS = "NumExecutionsInProgress";
-  public static final String MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP = "NumTimesGlobalIndexLookup";
-  public static final String MBEAN_ATTRIBUTE_NUMROWSMODIFIED = "NumRowsModified";
-  public static final String MBEAN_ATTRIBUTE_PARSETIME = "ParseTime";
-  public static final String MBEAN_ATTRIBUTE_BINDTIME = "BindTime";
-  public static final String MBEAN_ATTRIBUTE_OPTIMIZETIME = "OptimizeTime";
-  public static final String MBEAN_ATTRIBUTE_ROUTINGINFOTIME = "RoutingInfoTime";
-  public static final String MBEAN_ATTRIBUTE_GENERATETIME = "GenerateTime";
-  public static final String MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME = "TotalCompilationTime";
-  public static final String MBEAN_ATTRIBUTE_EXECUTIONTIME = "ExecutionTime";
-  public static final String MBEAN_ATTRIBUTE_PROJECTIONTIME = "ProjectionTime";
-  public static final String MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME = "TotalExecutionTime";
-  public static final String MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME = "RowsModificationTime";
-  public static final String MBEAN_ATTRIBUTE_QNNUMROWSSEEN = "QNNumRowsSeen";
-  public static final String MBEAN_ATTRIBUTE_QNMSGSENDTIME = "QNMsgSendTime";
-  public static final String MBEAN_ATTRIBUTE_QNMSGSERTIME = "QNMsgSerTime";
-  public static final String MBEAN_ATTRIBUTE_QNRESPDESERTIME = "QNRespDeSerTime";
-  public static final String MBEAN_ATTRIBUTE_QUERYDEFINITION = "Query";
-
-  public static final String MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID = "Id";
-  public static final String MBEAN_ATTRIBUTE_AEQ_PRIMARY = "Primary";
-  public static final String MBEAN_ATTRIBUTE_AEQ_PARALLEL = "Parallel";
-  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE = "BatchSize";
-  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL = "BatchTimeInterval";
-  public static final String MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED = "BatchConflationEnabled";
-  public static final String MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER = "AsyncEventListener";
-  public static final String MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE = "EventQueueSize";
-
-  // column names
-  public static final String MBEAN_COLNAME_NUMTIMESCOMPILED = "NumTimesCompiled";
-  public static final String MBEAN_COLNAME_NUMEXECUTION = "NumExecution";
-  public static final String MBEAN_COLNAME_NUMEXECUTIONSINPROGRESS = "NumExecutionsInProgress";
-  public static final String MBEAN_COLNAME_NUMTIMESGLOBALINDEXLOOKUP = "NumTimesGlobalIndexLookup";
-  public static final String MBEAN_COLNAME_NUMROWSMODIFIED = "NumRowsModified";
-  public static final String MBEAN_COLNAME_PARSETIME = "ParseTime(ms)";
-  public static final String MBEAN_COLNAME_BINDTIME = "BindTime(ms)";
-  public static final String MBEAN_COLNAME_OPTIMIZETIME = "OptimizeTime(ms)";
-  public static final String MBEAN_COLNAME_ROUTINGINFOTIME = "RoutingInfoTime(ms)";
-  public static final String MBEAN_COLNAME_GENERATETIME = "GenerateTime(ms)";
-  public static final String MBEAN_COLNAME_TOTALCOMPILATIONTIME = "TotalCompilationTime(ms)";
-  public static final String MBEAN_COLNAME_EXECUTIONTIME = "ExecutionTime(ns)";
-  public static final String MBEAN_COLNAME_PROJECTIONTIME = "ProjectionTime(ns)";
-  public static final String MBEAN_COLNAME_TOTALEXECUTIONTIME = "TotalExecutionTime(ns)";
-  public static final String MBEAN_COLNAME_ROWSMODIFICATIONTIME = "RowsModificationTime(ns)";
-  public static final String MBEAN_COLNAME_QNNUMROWSSEEN = "QNNumRowsSeen";
-  public static final String MBEAN_COLNAME_QNMSGSENDTIME = "QNMsgSendTime(ns)";
-  public static final String MBEAN_COLNAME_QNMSGSERTIME = "QNMsgSerTime(ns)";
-  public static final String MBEAN_COLNAME_QNRESPDESERTIME = "QNRespDeSerTime(ns)";
-  public static final String MBEAN_COLNAME_QUERYDEFINITION = "Query";
-
-  // TODO : add attributes for aggregate statistics
-  // public static final String MBEAN_ATTRIBUTE_ENTRYCOUNT = "EntryCount";
-
-  public static final String MBEAN_MANAGER_ATTRIBUTE_PULSEURL = "PulseURL";
-
-  public static final String MBEAN_OPERATION_LISTCACHESERVER = "listCacheServers";
-  public static final String MBEAN_OPERATION_LISTSERVERS = "listServers";
-  public static final String MBEAN_OPERATION_VIEWREMOTECLUSTERSTATUS = "viewRemoteClusterStatus";
-  public static final String MBEAN_OPERATION_SHOWALLCLIENTS = "showAllClientStats";
-  public static final String MBEAN_OPERATION_LISTREGIONATTRIBUTES = "listRegionAttributes";
-  public static final String MBEAN_OPERATION_QUERYDATABROWSER = "queryData";
-
-  // COMPOSITE DATA KEYS
-  public static final String COMPOSITE_DATA_KEY_CLIENTID = "clientId";
-  public static final String COMPOSITE_DATA_KEY_NAME = "name";
-  public static final String COMPOSITE_DATA_KEY_HOSTNAME = "hostName";
-  public static final String COMPOSITE_DATA_KEY_QUEUESIZE = "queueSize";
-  public static final String COMPOSITE_DATA_KEY_PROCESSCPUTIME = "processCpuTime";
-  public static final String COMPOSITE_DATA_KEY_UPTIME = "upTime";
-  public static final String COMPOSITE_DATA_KEY_NUMOFTHREADS = "numOfThreads";
-  public static final String COMPOSITE_DATA_KEY_NUMOFGETS = "numOfGets";
-  public static final String COMPOSITE_DATA_KEY_NUMOFPUTS = "numOfPuts";
-  public static final String COMPOSITE_DATA_KEY_CPUS = "cpus";
-  public static final String COMPOSITE_DATA_KEY_CLIENTCQCOUNT = "clientCQCount"; 
-  public static final String COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED = "subscriptionEnabled"; 
-  public static final String COMPOSITE_DATA_KEY_SCOPE = "scope";
-  public static final String COMPOSITE_DATA_KEY_DISKSTORENAME = "diskStoreName";
-  public static final String COMPOSITE_DATA_KEY_DISKSYNCHRONOUS = "diskSynchronous";
-  public static final String COMPOSITE_DATA_KEY_COMPRESSIONCODEC = "compressionCodec";
-  public static final String COMPOSITE_DATA_KEY_ENABLEOFFHEAPMEMORY = "enableOffHeapMemory";
-  public static final String COMPOSITE_DATA_KEY_CONNECTIONSACTIVE = "connectionsActive";
-  public static final String COMPOSITE_DATA_KEY_CONNECTED = "connected";
-
-  public static final String ALERT_DESC_SEVERE = "Severe Alert! The cluster is on fire !";
-  public static final String ALERT_DESC_ERROR = "Error Alert! There is a problem with your cluster ! Better fix it !";
-  public static final String ALERT_DESC_WARNING = "Warning Alert! Look at this cluster after you finish your coffee !";
-  public static final String ALERT_DESC_INFO = "Info Alert! For your kind information !";
-
-  public static final String NOTIFICATION_TYPE_SYSTEM_ALERT = "system.alert";
-  public static final String NOTIFICATION_TYPE_CACHE_MEMBER_DEPARTED = "gemfire.distributedsystem.cache.member.departed";
-  public static final String NOTIFICATION_TYPE_REGION_DESTROYED = "gemfire.distributedsystem.cache.region.closed";
-
-  public static final String PRODUCT_NAME_GEMFIRE = "gemfire"; // For GemFire
-  public static final String PRODUCT_NAME_SQLFIRE = "gemfirexd"; // For SQLFire
-
-  //Following attributes are not present in 9.0
-  //"Members"
-  //"EmptyNodes"
-  //"SystemRegionEntryCount"
-  //"MemberCount"
-  public static final String[] REGION_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_MEMBERS, MBEAN_ATTRIBUTE_FULLPATH,
-      MBEAN_ATTRIBUTE_DISKREADSRATE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
-      MBEAN_ATTRIBUTE_EMPTYNODES, MBEAN_ATTRIBUTE_GETSRATE,
-      MBEAN_ATTRIBUTE_LRUEVICTIONRATE, MBEAN_ATTRIBUTE_PUTSRATE,
-      MBEAN_ATTRIBUTE_REGIONTYPE, MBEAN_ATTRIBUTE_ENTRYSIZE,
-      MBEAN_ATTRIBUTE_ENTRYCOUNT, MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT,
-      MBEAN_ATTRIBUTE_MEMBERCOUNT, MBEAN_ATTRIBUTE_PERSISTENTENABLED,
-      MBEAN_ATTRIBUTE_NAME, MBEAN_ATTRIBUTE_GATEWAYENABLED,
-      MBEAN_ATTRIBUTE_DISKUSAGE, MBEAN_ATTRIBUTE_LOCALMAXMEMORY };
-
-  public static final String[] CLUSTER_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_MEMBERCOUNT, MBEAN_ATTRIBUTE_NUMCLIENTS,
-      MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID, MBEAN_ATTRIBUTE_LOCATORCOUNT,
-      MBEAN_ATTRIBUTE_TOTALREGIONCOUNT, MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION,
-      MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT, MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS,
-      MBEAN_ATTRIBUTE_NUMTXNCOMMITTED, MBEAN_ATTRIBUTE_NUMTXNROLLBACK,
-      MBEAN_ATTRIBUTE_TOTALHEAPSIZE, MBEAN_ATTRIBUTE_USEDHEAPSIZE,
-      MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT, MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT,
-      MBEAN_ATTRIBUTE_TOTALDISKUSAGE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
-      MBEAN_ATTRIBUTE_AVERAGEWRITES, MBEAN_ATTRIBUTE_AVERAGEREADS,
-      MBEAN_ATTRIBUTE_QUERYREQUESTRATE, MBEAN_ATTRIBUTE_DISKREADSRATE,
-      MBEAN_ATTRIBUTE_JVMPAUSES };
-
-  public static final String[] GATEWAY_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_PORT, MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE,
-      MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME, MBEAN_ATTRIBUTE_RUNNING };
-
-  public static final String[] GATEWAYSENDER_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE, MBEAN_ATTRIBUTE_BATCHSIZE,
-      MBEAN_ATTRIBUTE_SENDERID, MBEAN_ATTRIBUTE_EVENTQUEUESIZE,
-      MBEAN_ATTRIBUTE_RUNNING, MBEAN_ATTRIBUTE_PRIMARY,
-      MBEAN_ATTRIBUTE_PERSISTENCEENABLED, MBEAN_ATTRIBUTE_PARALLEL,
-      MBEAN_ATTRIBUTE_REMOTE_DS_ID, MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD};
-
-  public static final String[] ASYNC_EVENT_QUEUE_MBEAN_ATTRIBUTES = {
-    MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID, MBEAN_ATTRIBUTE_AEQ_PRIMARY,
-    MBEAN_ATTRIBUTE_AEQ_PARALLEL, MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE,
-    MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL, MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED,
-    MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER, MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE};
-
-  public static final String[] MEMBER_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_MANAGER, MBEAN_ATTRIBUTE_TOTALREGIONCOUNT,
-      MBEAN_ATTRIBUTE_LOCATOR, MBEAN_ATTRIBUTE_TOTALDISKUSAGE,
-      MBEAN_ATTRIBUTE_SERVER, MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN,
-      MBEAN_ATTRIBUTE_LOADAVERAGE, MBEAN_ATTRIBUTE_DISKWRITESRATE,
-      MBEAN_ATTRIBUTE_DISKREADSRATE, MBEAN_ATTRIBUTE_JVMPAUSES,
-      MBEAN_ATTRIBUTE_USEDMEMORY, MBEAN_ATTRIBUTE_MAXMEMORY,
-      MBEAN_ATTRIBUTE_NUMTHREADS, MBEAN_ATTRIBUTE_MEMBERUPTIME,
-      MBEAN_ATTRIBUTE_HOST, MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS,
-      MBEAN_ATTRIBUTE_BINDADDRESS, MBEAN_ATTRIBUTE_TOTALBYTESONDISK,
-      MBEAN_ATTRIBUTE_CPUUSAGE, MBEAN_ATTRIBUTE_HOSTCPUUSAGE,
-      MBEAN_ATTRIBUTE_MEMBER, MBEAN_ATTRIBUTE_ID, MBEAN_ATTRIBUTE_AVERAGEREADS,
-      MBEAN_ATTRIBUTE_AVERAGEWRITES, MBEAN_ATTRIBUTE_OFFHEAPFREESIZE,
-      MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE, MBEAN_ATTRIBUTE_SERVERGROUPS,
-      MBEAN_ATTRIBUTE_REDUNDANCYZONES, MBEAN_ATTRIBUTE_GEMFIREVERSION };
-
-  public static final String[] STATEMENT_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_NAME, MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
-      MBEAN_ATTRIBUTE_NUMEXECUTION, MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
-      MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
-      MBEAN_ATTRIBUTE_NUMROWSMODIFIED, MBEAN_ATTRIBUTE_PARSETIME,
-      MBEAN_ATTRIBUTE_BINDTIME, MBEAN_ATTRIBUTE_OPTIMIZETIME,
-      MBEAN_ATTRIBUTE_ROUTINGINFOTIME, MBEAN_ATTRIBUTE_GENERATETIME,
-      MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME, MBEAN_ATTRIBUTE_EXECUTIONTIME,
-      MBEAN_ATTRIBUTE_PROJECTIONTIME, MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
-      MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME, MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
-      MBEAN_ATTRIBUTE_QNMSGSENDTIME, MBEAN_ATTRIBUTE_QNMSGSERTIME };
-
-  public static final String[] REGION_ON_MEMBER_MBEAN_ATTRIBUTES = {
-    MBEAN_ATTRIBUTE_ENTRYSIZE,
-    MBEAN_ATTRIBUTE_ENTRYCOUNT,
-    MBEAN_ATTRIBUTE_PUTSRATE,
-    MBEAN_ATTRIBUTE_GETSRATE,
-    MBEAN_ATTRIBUTE_DISKREADSRATE,
-    MBEAN_ATTRIBUTE_DISKWRITESRATE,
-    MBEAN_ATTRIBUTE_LOCALMAXMEMORY
-    };
-
-  public static final String[] SF_CLUSTER_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS,
-      MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS };
-
-  public static final String[] SF_MEMBER_MBEAN_ATTRIBUTES = {
-    MBEAN_ATTRIBUTE_DATASTORE,
-    MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS };
-
-  public static final String[] SF_TABLE_MBEAN_ATTRIBUTES = {
-      MBEAN_ATTRIBUTE_ENTRYSIZE, MBEAN_ATTRIBUTE_NUMBEROFROWS };
-  
-  public static final String PULSE_ROLES[] = {
-    "CLUSTER:READ",
-    "DATA:READ"
-  };
-
-  // SSL Related attributes
-
-  public static final String SSL_KEYSTORE = "javax.net.ssl.keyStore";
-  public static final String SSL_KEYSTORE_PASSWORD = "javax.net.ssl.keyStorePassword";
-  public static final String SSL_TRUSTSTORE = "javax.net.ssl.trustStore";
-  public static final String SSL_TRUSTSTORE_PASSWORD = "javax.net.ssl.trustStorePassword";
-  public static final String SSL_ENABLED_CIPHERS = "javax.rmi.ssl.client.enabledCipherSuites";
-  public static final String SSL_ENABLED_PROTOCOLS = "javax.rmi.ssl.client.enabledProtocols";
-
-  public static final String SYSTEM_PROPERTY_PULSE_USESSL_LOCATOR = "pulse.useSSL.locator";
-  public static final String SYSTEM_PROPERTY_PULSE_USESSL_MANAGER = "pulse.useSSL.manager";
-
-  public static final String REQUEST_PARAM_REGION_FULL_PATH = "regionFullPath";
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseVersion.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseVersion.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseVersion.java
deleted file mode 100644
index e7b62a2..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/PulseVersion.java
+++ /dev/null
@@ -1,103 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import java.util.ResourceBundle;
-
-/**
- * Class PulseVersion
- * 
- * This class is for holding Pulse Applications Version's details (like version
- * details, build details, source details, etc) from properties file
- * 
- * @since GemFire version Helios
- */
-
-public class PulseVersion {
-
-  private String pulseVersion;
-
-  public String getPulseVersion() {
-    return pulseVersion;
-  }
-
-  public void setPulseVersion(String pulseVersion) {
-    this.pulseVersion = pulseVersion;
-  }
-
-  private String pulseBuildId;
-
-  public String getPulseBuildId() {
-    return pulseBuildId;
-  }
-
-  public void setPulseBuildId(String pulseBuildId) {
-    this.pulseBuildId = pulseBuildId;
-  }
-
-  private String pulseBuildDate;
-
-  public String getPulseBuildDate() {
-    return pulseBuildDate;
-  }
-
-  public void setPulseBuildDate(String pulseBuildDate) {
-    this.pulseBuildDate = pulseBuildDate;
-  }
-
-  private String pulseSourceDate;
-
-  public String getPulseSourceDate() {
-    return pulseSourceDate;
-  }
-
-  public void setPulseSourceDate(String pulseSourceDate) {
-    this.pulseSourceDate = pulseSourceDate;
-  }
-
-  private String pulseSourceRevision;
-
-  public String getPulseSourceRevision() {
-    return pulseSourceRevision;
-  }
-
-  public void setPulseSourceRevision(String pulseSourceRevision) {
-    this.pulseSourceRevision = pulseSourceRevision;
-  }
-
-  private String pulseSourceRepository;
-
-  public String getPulseSourceRepository() {
-    return pulseSourceRepository;
-  }
-
-  public void setPulseSourceRepository(String pulseSourceRepository) {
-    this.pulseSourceRepository = pulseSourceRepository;
-  }
-
-  public String getPulseVersionLogMessage() {
-    ResourceBundle resourceBundle = Repository.get().getResourceBundle();
-    String logMessage = resourceBundle.getString("LOG_MSG_PULSE_VERSION") + " "
-        + this.getPulseVersion() + " " + this.getPulseBuildId() + " "
-        + this.getPulseBuildDate();
-    return logMessage;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Repository.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Repository.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Repository.java
deleted file mode 100644
index 8eea7cc..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/Repository.java
+++ /dev/null
@@ -1,246 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import org.springframework.security.core.Authentication;
-import org.springframework.security.core.context.SecurityContextHolder;
-
-import java.net.ConnectException;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Locale;
-import java.util.Map;
-import java.util.ResourceBundle;
-
-/**
- * A Singleton instance of the memory cache for clusters.
- * 
- * @since GemFire version 7.0.Beta 2012-09-23
- */
-public class Repository {
-  private PulseLogWriter LOGGER;
-
-  private static Repository instance = new Repository();
-  private HashMap<String, Cluster> clusterMap = new HashMap<String, Cluster>();
-  private Boolean jmxUseLocator;
-  private String jmxHost;
-  private String jmxPort;
-  private String jmxUserName;
-  private String jmxUserPassword;
-  private Boolean isEmbeddedMode;
-  private boolean useSSLLocator = false;
-  private boolean useSSLManager = false;
-  private boolean useGemFireCredentials = false;
-  
-
-  private String pulseWebAppUrl;
-
-  Locale locale = new Locale(PulseConstants.APPLICATION_LANGUAGE,
-      PulseConstants.APPLICATION_COUNTRY);
-
-  private ResourceBundle resourceBundle = ResourceBundle.getBundle(
-      PulseConstants.LOG_MESSAGES_FILE, locale);
-
-  private PulseConfig pulseConfig = new PulseConfig();
-
-  private Repository() {
-
-  }
-
-  public static Repository get() {
-    return instance;
-  }
-
-  public Boolean getJmxUseLocator() {
-    return this.jmxUseLocator;
-  }
-
-  public void setJmxUseLocator(Boolean jmxUseLocator) {
-    this.jmxUseLocator = jmxUseLocator;
-  }
-
-  public String getJmxHost() {
-    return this.jmxHost;
-  }
-
-  public void setJmxHost(String jmxHost) {
-    this.jmxHost = jmxHost;
-  }
-
-  public String getJmxPort() {
-    return this.jmxPort;
-  }
-
-  public void setJmxPort(String jmxPort) {
-    this.jmxPort = jmxPort;
-  }
-
-  public String getJmxUserName() {
-    return this.jmxUserName;
-  }
-
-  public void setJmxUserName(String jmxUserName) {
-    this.jmxUserName = jmxUserName;
-  }
-
-  public String getJmxUserPassword() {
-    return this.jmxUserPassword;
-  }
-
-  public void setJmxUserPassword(String jmxUserPassword) {
-    this.jmxUserPassword = jmxUserPassword;
-  }
-
-  public Boolean getIsEmbeddedMode() {
-    return this.isEmbeddedMode;
-  }
-
-  public void setIsEmbeddedMode(Boolean isEmbeddedMode) {
-    this.isEmbeddedMode = isEmbeddedMode;
-  }
-
-  public boolean isUseSSLLocator() {
-    return useSSLLocator;
-  }
-
-  public void setUseSSLLocator(boolean useSSLLocator) {
-    this.useSSLLocator = useSSLLocator;
-  }
-
-  public boolean isUseSSLManager() {
-    return useSSLManager;
-  }
-
-  public void setUseSSLManager(boolean useSSLManager) {
-    this.useSSLManager = useSSLManager;
-  }
-
-  public String getPulseWebAppUrl() {
-    return this.pulseWebAppUrl;
-  }
-
-  public void setPulseWebAppUrl(String pulseWebAppUrl) {
-    this.pulseWebAppUrl = pulseWebAppUrl;
-  }
-
-  public PulseConfig getPulseConfig() {
-    return this.pulseConfig;
-  }
-
-  public void setPulseConfig(PulseConfig pulseConfig) {
-    this.pulseConfig = pulseConfig;
-  }
-
-  /**
-   * we're maintaining a 1:1 mapping between webapp and cluster, there is no need for a map of clusters based on the host and port
-   * We are using this clusterMap to maintain cluster for different users now.
-   * For a single-user connection to gemfire JMX, we will use the default username/password in the pulse.properties
-   * (# JMX User Properties )
-   * pulse.jmxUserName=admin
-   * pulse.jmxUserPassword=admin
-   *
-   * But for multi-user connections to gemfireJMX, i.e pulse that uses gemfire integrated security, we will need to get the username form the context
-   */
-  public Cluster getCluster() {
-    String username = null;
-    String password = null;
-    if(useGemFireCredentials) {
-      Authentication auth = SecurityContextHolder.getContext().getAuthentication();
-      if(auth!=null) {
-        username = auth.getName();
-        password = (String) auth.getCredentials();
-      }
-    }
-    else{
-      username = this.jmxUserName;
-      password = this.jmxUserPassword;
-    }
-    return this.getCluster(username, password);
-  }
-
-  public Cluster getCluster(String username, String password) {
-    synchronized (this.clusterMap) {
-      String key = username;
-      Cluster data = this.clusterMap.get(key);
-
-      LOGGER = PulseLogWriter.getLogger();
-
-      if (data == null) {
-        try {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(resourceBundle.getString("LOG_MSG_CREATE_NEW_THREAD")
-                + " : " + key);
-          }
-          data = new Cluster(this.jmxHost, this.jmxPort, username, password);
-          // Assign name to thread created
-          data.setName(PulseConstants.APP_NAME + "-" + this.jmxHost + ":" + this.jmxPort + ":" + username);
-          // Start Thread
-          data.start();
-          this.clusterMap.put(key, data);
-        } catch (ConnectException e) {
-          data = null;
-          if (LOGGER.fineEnabled()) {
-            LOGGER.fine(e.getMessage());
-          }
-        }
-      }
-      return data;
-    }
-  }
-
-  private String getClusterKey(String host, String port) {
-    return host + ":" + port;
-  }
-
-  // This method is used to remove all cluster threads
-  public void removeAllClusters() {
-
-    Iterator<Map.Entry<String, Cluster>> iter = clusterMap.entrySet()
-        .iterator();
-
-    while (iter.hasNext()) {
-      Map.Entry<String, Cluster> entry = iter.next();
-      Cluster c = entry.getValue();
-      String clusterKey = entry.getKey();
-      c.stopThread();
-      iter.remove();
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle.getString("LOG_MSG_REMOVE_THREAD") + " : "
-            + clusterKey.toString());
-      }
-    }
-  }
-
-  public ResourceBundle getResourceBundle() {
-    return this.resourceBundle;
-  }
-
-  public boolean isUseGemFireCredentials() {
-    return useGemFireCredentials;
-  }
-
-  public void setUseGemFireCredentials(boolean useGemFireCredentials) {
-    this.useGemFireCredentials = useGemFireCredentials;
-  }
-  
-  
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CDL.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CDL.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CDL.java
deleted file mode 100644
index 56ffeb8..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CDL.java
+++ /dev/null
@@ -1,274 +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 com.vmware.geode.tools.pulse.internal.json;
-
-/**
- * This provides static methods to convert comma delimited text into a
- * JSONArray, and to covert a JSONArray into comma delimited text. Comma
- * delimited text is a very popular format for data interchange. It is
- * understood by most database, spreadsheet, and organizer programs.
- * <p>
- * Each row of text represents a row in a table or a data record. Each row
- * ends with a NEWLINE character. Each row contains one or more values.
- * Values are separated by commas. A value can contain any character except
- * for comma, unless is is wrapped in single quotes or double quotes.
- * <p>
- * The first row usually contains the names of the columns.
- * <p>
- * A comma delimited list can be converted into a JSONArray of JSONObjects.
- * The names for the elements in the JSONObjects can be taken from the names
- * in the first row.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class CDL {
-
-    /**
-     * Get the next value. The value can be wrapped in quotes. The value can
-     * be empty.
-     * @param x A JSONTokener of the source text.
-     * @return The value string, or null if empty.
-     * @throws JSONException if the quoted string is badly formed.
-     */
-    private static String getValue(JSONTokener x) throws JSONException {
-        char c;
-        char q;
-        StringBuffer sb;
-        do {
-            c = x.next();
-        } while (c == ' ' || c == '\t');
-        switch (c) {
-        case 0:
-            return null;
-        case '"':
-        case '\'':
-            q = c;
-            sb = new StringBuffer();
-            for (;;) {
-                c = x.next();
-                if (c == q) {
-                    break;
-                }
-                if (c == 0 || c == '\n' || c == '\r') {
-                    throw x.syntaxError("Missing close quote '" + q + "'.");
-                }
-                sb.append(c);
-            }
-            return sb.toString();
-        case ',':
-            x.back();
-            return "";
-        default:
-            x.back();
-            return x.nextTo(',');
-        }
-    }
-
-    /**
-     * Produce a JSONArray of strings from a row of comma delimited values.
-     * @param x A JSONTokener of the source text.
-     * @return A JSONArray of strings.
-     * @throws JSONException
-     */
-    public static JSONArray rowToJSONArray(JSONTokener x) throws JSONException {
-        JSONArray ja = new JSONArray();
-        for (;;) {
-            String value = getValue(x);
-            char c = x.next();
-            if (value == null || 
-                    (ja.length() == 0 && value.length() == 0 && c != ',')) {
-                return null;
-            }
-            ja.put(value);
-            for (;;) {                
-                if (c == ',') {
-                    break;
-                }
-                if (c != ' ') {
-                    if (c == '\n' || c == '\r' || c == 0) {
-                        return ja;
-                    }
-                    throw x.syntaxError("Bad character '" + c + "' (" +
-                            (int)c + ").");
-                }
-                c = x.next();
-            }
-        }
-    }
-
-    /**
-     * Produce a JSONObject from a row of comma delimited text, using a
-     * parallel JSONArray of strings to provides the names of the elements.
-     * @param names A JSONArray of names. This is commonly obtained from the
-     *  first row of a comma delimited text file using the rowToJSONArray
-     *  method.
-     * @param x A JSONTokener of the source text.
-     * @return A JSONObject combining the names and values.
-     * @throws JSONException
-     */
-    public static JSONObject rowToJSONObject(JSONArray names, JSONTokener x)
-            throws JSONException {
-        JSONArray ja = rowToJSONArray(x);
-        return ja != null ? ja.toJSONObject(names) :  null;
-    }
-
-    /**
-     * Produce a comma delimited text row from a JSONArray. Values containing
-     * the comma character will be quoted. Troublesome characters may be 
-     * removed.
-     * @param ja A JSONArray of strings.
-     * @return A string ending in NEWLINE.
-     */
-    public static String rowToString(JSONArray ja) {
-        StringBuffer sb = new StringBuffer();
-        for (int i = 0; i < ja.length(); i += 1) {
-            if (i > 0) {
-                sb.append(',');
-            }
-            Object object = ja.opt(i);
-            if (object != null) {
-                String string = object.toString();
-                if (string.length() > 0 && (string.indexOf(',') >= 0 || 
-                        string.indexOf('\n') >= 0 || string.indexOf('\r') >= 0 || 
-                        string.indexOf(0) >= 0 || string.charAt(0) == '"')) {
-                    sb.append('"');
-                    int length = string.length();
-                    for (int j = 0; j < length; j += 1) {
-                        char c = string.charAt(j);
-                        if (c >= ' ' && c != '"') {
-                            sb.append(c);
-                        }
-                    }
-                    sb.append('"');
-                } else {
-                    sb.append(string);
-                }
-            }
-        }
-        sb.append('\n');
-        return sb.toString();
-    }
-
-    /**
-     * Produce a JSONArray of JSONObjects from a comma delimited text string,
-     * using the first row as a source of names.
-     * @param string The comma delimited text.
-     * @return A JSONArray of JSONObjects.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(String string) throws JSONException {
-        return toJSONArray(new JSONTokener(string));
-    }
-
-    /**
-     * Produce a JSONArray of JSONObjects from a comma delimited text string,
-     * using the first row as a source of names.
-     * @param x The JSONTokener containing the comma delimited text.
-     * @return A JSONArray of JSONObjects.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(JSONTokener x) throws JSONException {
-        return toJSONArray(rowToJSONArray(x), x);
-    }
-
-    /**
-     * Produce a JSONArray of JSONObjects from a comma delimited text string
-     * using a supplied JSONArray as the source of element names.
-     * @param names A JSONArray of strings.
-     * @param string The comma delimited text.
-     * @return A JSONArray of JSONObjects.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(JSONArray names, String string)
-            throws JSONException {
-        return toJSONArray(names, new JSONTokener(string));
-    }
-
-    /**
-     * Produce a JSONArray of JSONObjects from a comma delimited text string
-     * using a supplied JSONArray as the source of element names.
-     * @param names A JSONArray of strings.
-     * @param x A JSONTokener of the source text.
-     * @return A JSONArray of JSONObjects.
-     * @throws JSONException
-     */
-    public static JSONArray toJSONArray(JSONArray names, JSONTokener x)
-            throws JSONException {
-        if (names == null || names.length() == 0) {
-            return null;
-        }
-        JSONArray ja = new JSONArray();
-        for (;;) {
-            JSONObject jo = rowToJSONObject(names, x);
-            if (jo == null) {
-                break;
-            }
-            ja.put(jo);
-        }
-        if (ja.length() == 0) {
-            return null;
-        }
-        return ja;
-    }
-
-
-    /**
-     * Produce a comma delimited text from a JSONArray of JSONObjects. The
-     * first row will be a list of names obtained by inspecting the first
-     * JSONObject.
-     * @param ja A JSONArray of JSONObjects.
-     * @return A comma delimited text.
-     * @throws JSONException
-     */
-    public static String toString(JSONArray ja) throws JSONException {
-        JSONObject jo = ja.optJSONObject(0);
-        if (jo != null) {
-            JSONArray names = jo.names();
-            if (names != null) {
-                return rowToString(names) + toString(names, ja);
-            }
-        }
-        return null;
-    }
-
-    /**
-     * Produce a comma delimited text from a JSONArray of JSONObjects using
-     * a provided list of names. The list of names is not included in the
-     * output.
-     * @param names A JSONArray of strings.
-     * @param ja A JSONArray of JSONObjects.
-     * @return A comma delimited text.
-     * @throws JSONException
-     */
-    public static String toString(JSONArray names, JSONArray ja)
-            throws JSONException {
-        if (names == null || names.length() == 0) {
-            return null;
-        }
-        StringBuffer sb = new StringBuffer();
-        for (int i = 0; i < ja.length(); i += 1) {
-            JSONObject jo = ja.optJSONObject(i);
-            if (jo != null) {
-                sb.append(rowToString(jo.toJSONArray(names)));
-            }
-        }
-        return sb.toString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/Cookie.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/Cookie.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/Cookie.java
deleted file mode 100644
index 8e208f0..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/Cookie.java
+++ /dev/null
@@ -1,164 +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 com.vmware.geode.tools.pulse.internal.json;
-
-/**
- * Convert a web browser cookie specification to a JSONObject and back.
- * JSON and Cookies are both notations for name/value pairs.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class Cookie {
-
-    /**
-     * Produce a copy of a string in which the characters '+', '%', '=', ';'
-     * and control characters are replaced with "%hh". This is a gentle form
-     * of URL encoding, attempting to cause as little distortion to the
-     * string as possible. The characters '=' and ';' are meta characters in
-     * cookies. By convention, they are escaped using the URL-encoding. This is
-     * only a convention, not a standard. Often, cookies are expected to have
-     * encoded values. We encode '=' and ';' because we must. We encode '%' and
-     * '+' because they are meta characters in URL encoding.
-     * @param string The source string.
-     * @return       The escaped result.
-     */
-    public static String escape(String string) {
-        char         c;
-        String       s = string.trim();
-        StringBuffer sb = new StringBuffer();
-        int          length = s.length();
-        for (int i = 0; i < length; i += 1) {
-            c = s.charAt(i);
-            if (c < ' ' || c == '+' || c == '%' || c == '=' || c == ';') {
-                sb.append('%');
-                sb.append(Character.forDigit((char)((c >>> 4) & 0x0f), 16));
-                sb.append(Character.forDigit((char)(c & 0x0f), 16));
-            } else {
-                sb.append(c);
-            }
-        }
-        return sb.toString();
-    }
-
-
-    /**
-     * Convert a cookie specification string into a JSONObject. The string
-     * will contain a name value pair separated by '='. The name and the value
-     * will be unescaped, possibly converting '+' and '%' sequences. The
-     * cookie properties may follow, separated by ';', also represented as
-     * name=value (except the secure property, which does not have a value).
-     * The name will be stored under the key "name", and the value will be
-     * stored under the key "value". This method does not do checking or
-     * validation of the parameters. It only converts the cookie string into
-     * a JSONObject.
-     * @param string The cookie specification string.
-     * @return A JSONObject containing "name", "value", and possibly other
-     *  members.
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(String string) throws JSONException {
-        String         name;
-        JSONObject     jo = new JSONObject();
-        Object         value;
-        JSONTokener x = new JSONTokener(string);
-        jo.put("name", x.nextTo('='));
-        x.next('=');
-        jo.put("value", x.nextTo(';'));
-        x.next();
-        while (x.more()) {
-            name = unescape(x.nextTo("=;"));
-            if (x.next() != '=') {
-                if (name.equals("secure")) {
-                    value = Boolean.TRUE;
-                } else {
-                    throw x.syntaxError("Missing '=' in cookie parameter.");
-                }
-            } else {
-                value = unescape(x.nextTo(';'));
-                x.next();
-            }
-            jo.put(name, value);
-        }
-        return jo;
-    }
-
-
-    /**
-     * Convert a JSONObject into a cookie specification string. The JSONObject
-     * must contain "name" and "value" members.
-     * If the JSONObject contains "expires", "domain", "path", or "secure"
-     * members, they will be appended to the cookie specification string.
-     * All other members are ignored.
-     * @param jo A JSONObject
-     * @return A cookie specification string
-     * @throws JSONException
-     */
-    public static String toString(JSONObject jo) throws JSONException {
-        StringBuffer sb = new StringBuffer();
-
-        sb.append(escape(jo.getString("name")));
-        sb.append("=");
-        sb.append(escape(jo.getString("value")));
-        if (jo.has("expires")) {
-            sb.append(";expires=");
-            sb.append(jo.getString("expires"));
-        }
-        if (jo.has("domain")) {
-            sb.append(";domain=");
-            sb.append(escape(jo.getString("domain")));
-        }
-        if (jo.has("path")) {
-            sb.append(";path=");
-            sb.append(escape(jo.getString("path")));
-        }
-        if (jo.optBoolean("secure")) {
-            sb.append(";secure");
-        }
-        return sb.toString();
-    }
-
-    /**
-     * Convert <code>%</code><i>hh</i> sequences to single characters, and
-     * convert plus to space.
-     * @param string A string that may contain
-     *      <code>+</code>&nbsp;<small>(plus)</small> and
-     *      <code>%</code><i>hh</i> sequences.
-     * @return The unescaped string.
-     */
-    public static String unescape(String string) {
-        int length = string.length();
-        StringBuffer sb = new StringBuffer();
-        for (int i = 0; i < length; ++i) {
-            char c = string.charAt(i);
-            if (c == '+') {
-                c = ' ';
-            } else if (c == '%' && i + 2 < length) {
-                int d = JSONTokener.dehexchar(string.charAt(i + 1));
-                int e = JSONTokener.dehexchar(string.charAt(i + 2));
-                if (d >= 0 && e >= 0) {
-                    c = (char)(d * 16 + e);
-                    i += 2;
-                }
-            }
-            sb.append(c);
-        }
-        return sb.toString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CookieList.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CookieList.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CookieList.java
deleted file mode 100644
index e03f75c..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/CookieList.java
+++ /dev/null
@@ -1,85 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.util.Iterator;
-
-/**
- * Convert a web browser cookie list string to a JSONObject and back.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class CookieList {
-
-    /**
-     * Convert a cookie list into a JSONObject. A cookie list is a sequence
-     * of name/value pairs. The names are separated from the values by '='.
-     * The pairs are separated by ';'. The names and the values
-     * will be unescaped, possibly converting '+' and '%' sequences.
-     *
-     * To add a cookie to a cooklist,
-     * cookielistJSONObject.put(cookieJSONObject.getString("name"),
-     *     cookieJSONObject.getString("value"));
-     * @param string  A cookie list string
-     * @return A JSONObject
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(String string) throws JSONException {
-        JSONObject jo = new JSONObject();
-        JSONTokener x = new JSONTokener(string);
-        while (x.more()) {
-            String name = Cookie.unescape(x.nextTo('='));
-            x.next('=');
-            jo.put(name, Cookie.unescape(x.nextTo(';')));
-            x.next();
-        }
-        return jo;
-    }
-
-
-    /**
-     * Convert a JSONObject into a cookie list. A cookie list is a sequence
-     * of name/value pairs. The names are separated from the values by '='.
-     * The pairs are separated by ';'. The characters '%', '+', '=', and ';'
-     * in the names and values are replaced by "%hh".
-     * @param jo A JSONObject
-     * @return A cookie list string
-     * @throws JSONException
-     */
-    public static String toString(JSONObject jo) throws JSONException {
-        boolean      b = false;
-        Iterator     keys = jo.keys();
-        String       string;
-        StringBuffer sb = new StringBuffer();
-        while (keys.hasNext()) {
-            string = keys.next().toString();
-            if (!jo.isNull(string)) {
-                if (b) {
-                    sb.append(';');
-                }
-                sb.append(Cookie.escape(string));
-                sb.append("=");
-                sb.append(Cookie.escape(jo.getString(string)));
-                b = true;
-            }
-        }
-        return sb.toString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTP.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTP.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTP.java
deleted file mode 100644
index 19c7d53..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTP.java
+++ /dev/null
@@ -1,158 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.util.Iterator;
-
-/**
- * Convert an HTTP header to a JSONObject and back.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class HTTP {
-
-    /** Carriage return/line feed. */
-    public static final String CRLF = "\r\n";
-
-    /**
-     * Convert an HTTP header string into a JSONObject. It can be a request
-     * header or a response header. A request header will contain
-     * <pre>{
-     *    Method: "POST" (for example),
-     *    "Request-URI": "/" (for example),
-     *    "HTTP-Version": "HTTP/1.1" (for example)
-     * }</pre>
-     * A response header will contain
-     * <pre>{
-     *    "HTTP-Version": "HTTP/1.1" (for example),
-     *    "Status-Code": "200" (for example),
-     *    "Reason-Phrase": "OK" (for example)
-     * }</pre>
-     * In addition, the other parameters in the header will be captured, using
-     * the HTTP field names as JSON names, so that <pre>
-     *    Date: Sun, 26 May 2002 18:06:04 GMT
-     *    Cookie: Q=q2=PPEAsg--; B=677gi6ouf29bn&b=2&f=s
-     *    Cache-Control: no-cache</pre>
-     * become
-     * <pre>{...
-     *    Date: "Sun, 26 May 2002 18:06:04 GMT",
-     *    Cookie: "Q=q2=PPEAsg--; B=677gi6ouf29bn&b=2&f=s",
-     *    "Cache-Control": "no-cache",
-     * ...}</pre>
-     * It does no further checking or conversion. It does not parse dates.
-     * It does not do '%' transforms on URLs.
-     * @param string An HTTP header string.
-     * @return A JSONObject containing the elements and attributes
-     * of the XML string.
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(String string) throws JSONException {
-        JSONObject     jo = new JSONObject();
-        HTTPTokener    x = new HTTPTokener(string);
-        String         token;
-
-        token = x.nextToken();
-        if (token.toUpperCase().startsWith("HTTP")) {
-
-// Response
-
-            jo.put("HTTP-Version", token);
-            jo.put("Status-Code", x.nextToken());
-            jo.put("Reason-Phrase", x.nextTo('\0'));
-            x.next();
-
-        } else {
-
-// Request
-
-            jo.put("Method", token);
-            jo.put("Request-URI", x.nextToken());
-            jo.put("HTTP-Version", x.nextToken());
-        }
-
-// Fields
-
-        while (x.more()) {
-            String name = x.nextTo(':');
-            x.next(':');
-            jo.put(name, x.nextTo('\0'));
-            x.next();
-        }
-        return jo;
-    }
-
-
-    /**
-     * Convert a JSONObject into an HTTP header. A request header must contain
-     * <pre>{
-     *    Method: "POST" (for example),
-     *    "Request-URI": "/" (for example),
-     *    "HTTP-Version": "HTTP/1.1" (for example)
-     * }</pre>
-     * A response header must contain
-     * <pre>{
-     *    "HTTP-Version": "HTTP/1.1" (for example),
-     *    "Status-Code": "200" (for example),
-     *    "Reason-Phrase": "OK" (for example)
-     * }</pre>
-     * Any other members of the JSONObject will be output as HTTP fields.
-     * The result will end with two CRLF pairs.
-     * @param jo A JSONObject
-     * @return An HTTP header string.
-     * @throws JSONException if the object does not contain enough
-     *  information.
-     */
-    public static String toString(JSONObject jo) throws JSONException {
-        Iterator     keys = jo.keys();
-        String       string;
-        StringBuffer sb = new StringBuffer();
-        if (jo.has("Status-Code") && jo.has("Reason-Phrase")) {
-            sb.append(jo.getString("HTTP-Version"));
-            sb.append(' ');
-            sb.append(jo.getString("Status-Code"));
-            sb.append(' ');
-            sb.append(jo.getString("Reason-Phrase"));
-        } else if (jo.has("Method") && jo.has("Request-URI")) {
-            sb.append(jo.getString("Method"));
-            sb.append(' ');
-            sb.append('"');
-            sb.append(jo.getString("Request-URI"));
-            sb.append('"');
-            sb.append(' ');
-            sb.append(jo.getString("HTTP-Version"));
-        } else {
-            throw new JSONException("Not enough material for an HTTP header.");
-        }
-        sb.append(CRLF);
-        while (keys.hasNext()) {
-            string = keys.next().toString();
-            if (!"HTTP-Version".equals(string)      && !"Status-Code".equals(string) &&
-                    !"Reason-Phrase".equals(string) && !"Method".equals(string) &&
-                    !"Request-URI".equals(string)   && !jo.isNull(string)) {
-                sb.append(string);
-                sb.append(": ");
-                sb.append(jo.getString(string));
-                sb.append(CRLF);
-            }
-        }
-        sb.append(CRLF);
-        return sb.toString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTPTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTPTokener.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTPTokener.java
deleted file mode 100644
index 536aee0..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/HTTPTokener.java
+++ /dev/null
@@ -1,72 +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 com.vmware.geode.tools.pulse.internal.json;
-
-/**
- * The HTTPTokener extends the JSONTokener to provide additional methods
- * for the parsing of HTTP headers.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class HTTPTokener extends JSONTokener {
-
-    /**
-     * Construct an HTTPTokener from a string.
-     * @param string A source string.
-     */
-    public HTTPTokener(String string) {
-        super(string);
-    }
-
-
-    /**
-     * Get the next token or string. This is used in parsing HTTP headers.
-     * @throws JSONException
-     * @return A String.
-     */
-    public String nextToken() throws JSONException {
-        char c;
-        char q;
-        StringBuffer sb = new StringBuffer();
-        do {
-            c = next();
-        } while (Character.isWhitespace(c));
-        if (c == '"' || c == '\'') {
-            q = c;
-            for (;;) {
-                c = next();
-                if (c < ' ') {
-                    throw syntaxError("Unterminated string.");
-                }
-                if (c == q) {
-                    return sb.toString();
-                }
-                sb.append(c);
-            }
-        } 
-        for (;;) {
-            if (c == 0 || Character.isWhitespace(c)) {
-                return sb.toString();
-            }
-            sb.append(c);
-            c = next();
-        }
-    }
-}


[30/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/oql.g
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/oql.g b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/oql.g
index caf0ec0..a743752 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/oql.g
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/oql.g
@@ -23,9 +23,9 @@
 */
 
 header {
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 import java.util.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
+import org.apache.geode.cache.query.internal.types.*;
 }
 
 options {
@@ -311,7 +311,7 @@ ML_COMMENT
 /***************************** OQL PARSER *************************************/
 
 class OQLParser
-extends Parser("com.gemstone.gemfire.cache.query.internal.parse.UtilParser");
+extends Parser("org.apache.geode.cache.query.internal.parse.UtilParser");
 
 options {
     buildAST = true;
@@ -356,14 +356,14 @@ queryProgram :
        	EOF!
         { #queryProgram =
           #([QUERY_PROGRAM, "queryProgram",
-            "com.gemstone.gemfire.cache.query.internal.parse.GemFireAST"],
+            "org.apache.geode.cache.query.internal.parse.GemFireAST"],
             #queryProgram); }
     ;
 
 traceCommand:
 		( 	
 			TOK_LT!
-			"trace"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTTrace>
+			"trace"^<AST=org.apache.geode.cache.query.internal.parse.ASTTrace>
 			TOK_GT!
 		)
 	;
@@ -377,7 +377,7 @@ loneFromClause :
         )* EOF!
     { #loneFromClause =
           #([LITERAL_from, "from",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTCombination"],
+            "org.apache.geode.cache.query.internal.parse.ASTCombination"],
             #loneFromClause); }
     ;
 
@@ -396,7 +396,7 @@ declaration :
 
 importQuery :
 
-        "import"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTImport>
+        "import"^<AST=org.apache.geode.cache.query.internal.parse.ASTImport>
         qualifiedName
         (
             "as" identifier
@@ -410,7 +410,7 @@ loneImports :
         EOF!
         // combine into a single node
         { #loneImports = #([IMPORTS, "imports",
-            "com.gemstone.gemfire.cache.query.internal.parse.GemFireAST"],
+            "org.apache.geode.cache.query.internal.parse.GemFireAST"],
                 #loneImports); }
     ;
 
@@ -469,7 +469,7 @@ query :
 
 selectExpr :
 		( hintCommand )?
-        "select"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTSelect>
+        "select"^<AST=org.apache.geode.cache.query.internal.parse.ASTSelect>
 
         (
             // ambig. betweed this distinct and a distinct conversion expr
@@ -479,8 +479,8 @@ selectExpr :
                 warnWhenFollowAmbig = false;
             } :
 
-            "distinct" <AST=com.gemstone.gemfire.cache.query.internal.parse.ASTDummy>
-            | "all" <AST=com.gemstone.gemfire.cache.query.internal.parse.ASTDummy>
+            "distinct" <AST=org.apache.geode.cache.query.internal.parse.ASTDummy>
+            | "all" <AST=org.apache.geode.cache.query.internal.parse.ASTDummy>
         )?
 
         
@@ -496,7 +496,7 @@ selectExpr :
 
 fromClause :
 
-        "from"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCombination>
+        "from"^<AST=org.apache.geode.cache.query.internal.parse.ASTCombination>
         iteratorDef
         (
             TOK_COMMA!
@@ -511,7 +511,7 @@ iteratorDef! :
             id1:identifier
             "in"!
             ex1:expr ( "type"! t1:type )?
-            { #iteratorDef = #([ITERATOR_DEF, "iterDef", "com.gemstone.gemfire.cache.query.internal.parse.ASTIteratorDef"], #ex1, #id1, #t1); }
+            { #iteratorDef = #([ITERATOR_DEF, "iterDef", "org.apache.geode.cache.query.internal.parse.ASTIteratorDef"], #ex1, #id1, #t1); }
 
         |   ex2:expr
             (
@@ -520,7 +520,7 @@ iteratorDef! :
             )?
             ( "type"! t2:type )?
 
-            { #iteratorDef = #([ITERATOR_DEF, "iterDef", "com.gemstone.gemfire.cache.query.internal.parse.ASTIteratorDef"], #ex2, #id2, #t2); }
+            { #iteratorDef = #([ITERATOR_DEF, "iterDef", "org.apache.geode.cache.query.internal.parse.ASTIteratorDef"], #ex2, #id2, #t2); }
     ;
 
 whereClause :
@@ -532,9 +532,9 @@ limitClause! :
 
         "limit" (TOK_DOLLAR NUM_INT
         { #limitClause = #([LIMIT, "limitParam",
-               "com.gemstone.gemfire.cache.query.internal.parse.ASTParameter"],
+               "org.apache.geode.cache.query.internal.parse.ASTParameter"],
                    #NUM_INT); }
-         | n:NUM_INT{ #limitClause =#[LIMIT,n.getText(),"com.gemstone.gemfire.cache.query.internal.parse.ASTLimit"] ; })
+         | n:NUM_INT{ #limitClause =#[LIMIT,n.getText(),"org.apache.geode.cache.query.internal.parse.ASTLimit"] ; })
     ;
 
 projectionAttributes :
@@ -546,10 +546,10 @@ projectionAttributes :
                 projection
             )*
             { #projectionAttributes = #([PROJECTION_ATTRS, "projectionAttrs",
-                "com.gemstone.gemfire.cache.query.internal.parse.ASTCombination"],
+                "org.apache.geode.cache.query.internal.parse.ASTCombination"],
                 #projectionAttributes); }
 
-        |   TOK_STAR <AST=com.gemstone.gemfire.cache.query.internal.parse.ASTDummy>
+        |   TOK_STAR <AST=org.apache.geode.cache.query.internal.parse.ASTDummy>
         )
     ;
 
@@ -557,7 +557,7 @@ projection!{ AST node  = null;}:
         
             lb1:identifier TOK_COLON!  ( tok1:aggregateExpr{node = #tok1;} | tok2:expr{node = #tok2;})
             { #projection = #([PROJECTION, "projection",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTProjection"],  node, #lb1); } 
+            "org.apache.geode.cache.query.internal.parse.ASTProjection"],  node, #lb1); } 
         |
             (tok3:aggregateExpr{node = #tok3;} | tok4:expr{node = #tok4;})
             (
@@ -565,7 +565,7 @@ projection!{ AST node  = null;}:
                 lb2: identifier
             )?
             { #projection = #([PROJECTION, "projection",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTProjection"], node, #lb2); }
+            "org.apache.geode.cache.query.internal.parse.ASTProjection"], node, #lb2); }
     ;
 
 
@@ -573,7 +573,7 @@ projection!{ AST node  = null;}:
 
 groupClause :
 
-        "group"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTGroupBy>
+        "group"^<AST=org.apache.geode.cache.query.internal.parse.ASTGroupBy>
         "by"!  groupByList
 
         (
@@ -585,7 +585,7 @@ groupClause :
 hintCommand :
 		 	
 			TOK_LT!
-			"hint"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTHint>
+			"hint"^<AST=org.apache.geode.cache.query.internal.parse.ASTHint>
 			hintIdentifier
 			(
 			  TOK_COMMA! hintIdentifier
@@ -596,12 +596,12 @@ hintCommand :
 
       
 hintIdentifier :
- 	n:StringLiteral{ #hintIdentifier =#[HINT,n.getText(),"com.gemstone.gemfire.cache.query.internal.parse.ASTHintIdentifier"] ; }       
+ 	n:StringLiteral{ #hintIdentifier =#[HINT,n.getText(),"org.apache.geode.cache.query.internal.parse.ASTHintIdentifier"] ; }       
 ;
 
 orderClause :
 
-        "order"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTOrderBy>
+        "order"^<AST=org.apache.geode.cache.query.internal.parse.ASTOrderBy>
         "by"!
         sortCriterion
         (
@@ -611,7 +611,7 @@ orderClause :
 
 sortCriterion :
 
-        tok:expr { #sortCriterion = #([SORT_CRITERION, "asc", "com.gemstone.gemfire.cache.query.internal.parse.ASTSortCriterion"],
+        tok:expr { #sortCriterion = #([SORT_CRITERION, "asc", "org.apache.geode.cache.query.internal.parse.ASTSortCriterion"],
             tok); }        
         (
             "asc"! {#sortCriterion.setText("asc");}
@@ -634,7 +634,7 @@ castExpr
         // follows, it's a typecast.  No semantic checking needed to parse.
         // if it _looks_ like a cast, it _is_ a cast; else it's a "(expr)"
     	(TOK_LPAREN type TOK_RPAREN castExpr)=>
-        lp:TOK_LPAREN^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTTypeCast>
+        lp:TOK_LPAREN^<AST=org.apache.geode.cache.query.internal.parse.ASTTypeCast>
                 {#lp.setType(TYPECAST); #lp.setText("typecast");}
             type TOK_RPAREN!
         castExpr
@@ -648,7 +648,7 @@ orExpr
             orelseExpr ( "or"! orelseExpr  { cmplx = true; } )*
        { if (cmplx) {
             #orExpr = #([LITERAL_or, "or",
-                    "com.gemstone.gemfire.cache.query.internal.parse.ASTOr"],
+                    "org.apache.geode.cache.query.internal.parse.ASTOr"],
                 #orExpr); } }
       ;
 
@@ -664,7 +664,7 @@ andExpr
            quantifierExpr ( "and"! quantifierExpr { cmplx = true; } )*
         { if (cmplx) {
             #andExpr = #([LITERAL_and, "and",
-                    "com.gemstone.gemfire.cache.query.internal.parse.ASTAnd"],
+                    "org.apache.geode.cache.query.internal.parse.ASTAnd"],
                     #andExpr); } }
     ;
 
@@ -704,8 +704,8 @@ equalityExpr :
 
             (   
                 (   (
-                        TOK_EQ^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
-                    |   TOK_NE^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
+                        TOK_EQ^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
+                    |   TOK_NE^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
                     )
                     (   "all"^
                     |   "any"^
@@ -713,7 +713,7 @@ equalityExpr :
                     )?
                 relationalExpr )+
     
-            |   (  "like"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLike>
+            |   (  "like"^<AST=org.apache.geode.cache.query.internal.parse.ASTLike>
                 relationalExpr )*
             )
     ;
@@ -723,10 +723,10 @@ relationalExpr :
         additiveExpr
         (
             (
-                TOK_LT^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
-            |   TOK_GT^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
-            |   TOK_LE^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
-            |   TOK_GE^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCompareOp>
+                TOK_LT^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
+            |   TOK_GT^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
+            |   TOK_LE^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
+            |   TOK_GE^<AST=org.apache.geode.cache.query.internal.parse.ASTCompareOp>
             )
 
             (
@@ -777,7 +777,7 @@ inExpr :
 
         unaryExpr
         (
-            "in"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTIn> unaryExpr
+            "in"^<AST=org.apache.geode.cache.query.internal.parse.ASTIn> unaryExpr
         )?
     ;
 
@@ -786,9 +786,9 @@ unaryExpr :
         (
             (
                 TOK_PLUS!
-            |   TOK_MINUS^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTUnary>
+            |   TOK_MINUS^<AST=org.apache.geode.cache.query.internal.parse.ASTUnary>
             |   "abs"^
-            |   "not"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTUnary>
+            |   "not"^<AST=org.apache.geode.cache.query.internal.parse.ASTUnary>
             )
         )*
         postfixExpr
@@ -811,7 +811,7 @@ postfixExpr
             )*
             { if (cmplx) {
                 #postfixExpr = #([POSTFIX, "postfix",
-                   "com.gemstone.gemfire.cache.query.internal.parse.ASTPostfix"],
+                   "org.apache.geode.cache.query.internal.parse.ASTPostfix"],
                     #postfixExpr);
               }
             }
@@ -823,7 +823,7 @@ methodInvocation! [boolean implicitReceiver] :
             methodName:identifier args:argList  
             { #methodInvocation =
                 #([METHOD_INV, "methodInv",
-                    "com.gemstone.gemfire.cache.query.internal.parse.ASTMethodInvocation"],
+                    "org.apache.geode.cache.query.internal.parse.ASTMethodInvocation"],
                   #methodName, #args); 
               ((ASTMethodInvocation)#methodInvocation).setImplicitReceiver(implicitReceiver); }
         ;
@@ -852,14 +852,14 @@ index :
           | TOK_STAR
         )
         { #index = #([TOK_LBRACK, "index",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTCombination"],
+            "org.apache.geode.cache.query.internal.parse.ASTCombination"],
                 #index);
         }
     ;
 
 argList :
 
-        t:TOK_LPAREN^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTCombination>
+        t:TOK_LPAREN^<AST=org.apache.geode.cache.query.internal.parse.ASTCombination>
         (
             expr
             (
@@ -886,7 +886,7 @@ primaryExpr :
         |   queryParam
         |   literal
         |   TOK_LPAREN! query TOK_RPAREN!
-        |   RegionPath<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTRegionPath>
+        |   RegionPath<AST=org.apache.geode.cache.query.internal.parse.ASTRegionPath>
         )
     ;
 
@@ -896,7 +896,7 @@ conversionExpr :
 
 	    (
                   "listtoset"^
-              |   "element"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr>
+              |   "element"^<AST=org.apache.geode.cache.query.internal.parse.ASTConversionExpr>
             
               |   "distinct"^
               |   "flatten"^
@@ -905,7 +905,7 @@ conversionExpr :
         |
            (  
               (
-               "nvl"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr>
+               "nvl"^<AST=org.apache.geode.cache.query.internal.parse.ASTConversionExpr>
               )
               TOK_LPAREN!
               expr TOK_COMMA! expr
@@ -914,7 +914,7 @@ conversionExpr :
         |
            (  
               (
-               "to_date"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTConversionExpr>
+               "to_date"^<AST=org.apache.geode.cache.query.internal.parse.ASTConversionExpr>
               )
               TOK_LPAREN!
               stringLiteral TOK_COMMA! stringLiteral
@@ -942,7 +942,7 @@ aggregateExpr  { int aggFunc = -1; boolean distinctOnly = false; }:
 
              !("sum" {aggFunc = SUM;} | "avg" {aggFunc = AVG;} )
               TOK_LPAREN ("distinct"! {distinctOnly = true;} ) ? tokExpr1:expr TOK_RPAREN 
-              { #aggregateExpr = #([AGG_FUNC, "aggregate", "com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc"],
+              { #aggregateExpr = #([AGG_FUNC, "aggregate", "org.apache.geode.cache.query.internal.parse.ASTAggregateFunc"],
               #tokExpr1); 
                 ((ASTAggregateFunc)#aggregateExpr).setAggregateFunctionType(aggFunc);
                 ((ASTAggregateFunc)#aggregateExpr).setDistinctOnly(distinctOnly);
@@ -951,14 +951,14 @@ aggregateExpr  { int aggFunc = -1; boolean distinctOnly = false; }:
              |
              !("min" {aggFunc = MIN;} | "max" {aggFunc = MAX;} )
               TOK_LPAREN  tokExpr2:expr TOK_RPAREN 
-              { #aggregateExpr = #([AGG_FUNC, "aggregate", "com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc"],
+              { #aggregateExpr = #([AGG_FUNC, "aggregate", "org.apache.geode.cache.query.internal.parse.ASTAggregateFunc"],
               #tokExpr2); 
                 ((ASTAggregateFunc)#aggregateExpr).setAggregateFunctionType(aggFunc);               
                }
              
              |
-              "count"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTAggregateFunc>
-              TOK_LPAREN!  ( TOK_STAR <AST=com.gemstone.gemfire.cache.query.internal.parse.ASTDummy>
+              "count"^<AST=org.apache.geode.cache.query.internal.parse.ASTAggregateFunc>
+              TOK_LPAREN!  ( TOK_STAR <AST=org.apache.geode.cache.query.internal.parse.ASTDummy>
               | ("distinct"! {distinctOnly = true;} ) ? expr ) TOK_RPAREN! 
               {  
                  ((ASTAggregateFunc)#aggregateExpr).setAggregateFunctionType(COUNT);
@@ -970,8 +970,8 @@ aggregateExpr  { int aggFunc = -1; boolean distinctOnly = false; }:
 undefinedExpr :
 
         (
-            "is_undefined"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr>
-        |   "is_defined"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTUndefinedExpr>
+            "is_undefined"^<AST=org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr>
+        |   "is_defined"^<AST=org.apache.geode.cache.query.internal.parse.ASTUndefinedExpr>
         )
         TOK_LPAREN!
         query
@@ -1004,7 +1004,7 @@ groupByList :
             expr
         )*
         /*{ #groupByList = #([COMBO, "groupByList",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTCombination"],
+            "org.apache.geode.cache.query.internal.parse.ASTCombination"],
                 #groupByList); }*/
   ;
 
@@ -1018,7 +1018,7 @@ fieldList :
             TOK_COLON! expr
         )*
         { #fieldList = #([COMBO, "fieldList",
-            "com.gemstone.gemfire.cache.query.internal.parse.ASTCombination"],
+            "org.apache.geode.cache.query.internal.parse.ASTCombination"],
                 #fieldList); }
     ;
 
@@ -1026,7 +1026,7 @@ collectionConstruction :
         (
             (
                 "array"^
-            |   "set"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTConstruction>
+            |   "set"^<AST=org.apache.geode.cache.query.internal.parse.ASTConstruction>
             |   "bag"^
             )
             argList
@@ -1050,7 +1050,7 @@ queryParam! :
 
         TOK_DOLLAR NUM_INT
         { #queryParam = #([QUERY_PARAM, "queryParam",
-               "com.gemstone.gemfire.cache.query.internal.parse.ASTParameter"],
+               "org.apache.geode.cache.query.internal.parse.ASTParameter"],
                    #NUM_INT); }
         
     ;
@@ -1060,26 +1060,26 @@ type :
       (
 //            ( "unsigned" )? // ignored
 //            (
-                typ00:"short"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+                typ00:"short"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ00.setJavaType(TypeUtils.getObjectType(Short.class)); }
-            |   typ01:"long"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+            |   typ01:"long"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ01.setJavaType(TypeUtils.getObjectType(Long.class)); }
 //            )
-        |   typ02:"int"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ02:"int"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ02.setJavaType(TypeUtils.getObjectType(Integer.class)); }
-        |   typ03:"float"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ03:"float"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ03.setJavaType(TypeUtils.getObjectType(Float.class)); }
-        |   typ04:"double"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ04:"double"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ04.setJavaType(TypeUtils.getObjectType(Double.class)); }
-        |   typ05:"char"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ05:"char"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ05.setJavaType(TypeUtils.getObjectType(Character.class)); }
-        |   typ06:"string"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ06:"string"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ06.setJavaType(TypeUtils.getObjectType(String.class)); }
-        |   typ07:"boolean"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ07:"boolean"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ07.setJavaType(TypeUtils.getObjectType(Boolean.class)); }
-        |   typ08:"byte"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ08:"byte"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ08.setJavaType(TypeUtils.getObjectType(Byte.class)); } 
-        |   typ09:"octet"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ09:"octet"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ09.setJavaType(TypeUtils.getObjectType(Byte.class)); }
         |   "enum"^ // unsupported
             (
@@ -1087,32 +1087,32 @@ type :
                 TOK_DOT
             )?
             identifier
-        |   typ10:"date"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ10:"date"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ10.setJavaType(TypeUtils.getObjectType(java.sql.Date.class)); }
-        |   typ11:"time"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ11:"time"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ11.setJavaType(TypeUtils.getObjectType(java.sql.Time.class)); }
         |   "interval" // unsupported
-        |   typ12:"timestamp"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ12:"timestamp"<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ12.setJavaType(TypeUtils.getObjectType(java.sql.Timestamp.class)); }
-        |   typ13:"set"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ13:"set"^<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                 TOK_LT! type TOK_GT!
                     { #typ13.setJavaType(new CollectionTypeImpl(Set.class, TypeUtils.OBJECT_TYPE /*resolved later*/)); } 
-        |   typ14:"collection"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   typ14:"collection"^<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                 TOK_LT! type TOK_GT!
                     { #typ14.setJavaType(new CollectionTypeImpl(Collection.class, TypeUtils.OBJECT_TYPE /*resolved later*/)); } 
         |   "bag"^ TOK_LT! type TOK_GT! // not supported
-        |   typ15:"list"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType> TOK_LT! type TOK_GT!
+        |   typ15:"list"^<AST=org.apache.geode.cache.query.internal.parse.ASTType> TOK_LT! type TOK_GT!
                     { #typ15.setJavaType(new CollectionTypeImpl(List.class, TypeUtils.OBJECT_TYPE /*resolved later*/)); }
-        |   typ16:"array"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType> TOK_LT! type TOK_GT!
+        |   typ16:"array"^<AST=org.apache.geode.cache.query.internal.parse.ASTType> TOK_LT! type TOK_GT!
                     { #typ16.setJavaType(new CollectionTypeImpl(Object[].class, TypeUtils.OBJECT_TYPE /*resolved later*/)); }
-        |   (typ17:"dictionary"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+        |   (typ17:"dictionary"^<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ17.setJavaType(new MapTypeImpl(Map.class, TypeUtils.OBJECT_TYPE , TypeUtils.OBJECT_TYPE /*resolved later*/)); }
-                | typ18:"map"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTType>
+                | typ18:"map"^<AST=org.apache.geode.cache.query.internal.parse.ASTType>
                     { #typ18.setJavaType(new MapTypeImpl(Map.class, TypeUtils.OBJECT_TYPE , TypeUtils.OBJECT_TYPE /*resolved later*/)); }
             )
             TOK_LT! type TOK_COMMA! type TOK_GT!
         |!   id:identifier { String txt = #id.getText();
-                #type = #[Identifier, txt, "com.gemstone.gemfire.cache.query.internal.parse.ASTType"];
+                #type = #[Identifier, txt, "org.apache.geode.cache.query.internal.parse.ASTType"];
                  ((ASTType)#type).setTypeName(txt); }
       )
       
@@ -1133,25 +1133,25 @@ literal :
 
 objectLiteral :
 
-        "nil"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-      | "null"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-      | "undefined"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        "nil"<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+      | "null"<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+      | "undefined"<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
     ;
 
 booleanLiteral :
 
         (
-            "true"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-        |   "false"<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+            "true"<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+        |   "false"<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
         )
     ;
 
 numericLiteral :
 
-        (   NUM_INT<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-          | NUM_LONG<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-          | NUM_FLOAT<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
-          | NUM_DOUBLE<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        (   NUM_INT<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+          | NUM_LONG<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+          | NUM_FLOAT<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
+          | NUM_DOUBLE<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
         )
         
     ;
@@ -1159,37 +1159,37 @@ numericLiteral :
 
 charLiteral :
 
-        "char"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        "char"^<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
             StringLiteral
     ;
 
 
 stringLiteral :
 
-        StringLiteral<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        StringLiteral<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
     ;
 
 dateLiteral :
 
-        "date"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        "date"^<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
             StringLiteral
     ;
 
 timeLiteral :
 
-        "time"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        "time"^<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
             StringLiteral
     ;
 
 timestampLiteral :
 
-        "timestamp"^<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTLiteral>
+        "timestamp"^<AST=org.apache.geode.cache.query.internal.parse.ASTLiteral>
            StringLiteral
     ;
 
 identifier :
-        Identifier<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier>
-    |   q:QuotedIdentifier<AST=com.gemstone.gemfire.cache.query.internal.parse.ASTIdentifier> 
+        Identifier<AST=org.apache.geode.cache.query.internal.parse.ASTIdentifier>
+    |   q:QuotedIdentifier<AST=org.apache.geode.cache.query.internal.parse.ASTIdentifier> 
             { #q.setType(Identifier); }
     ;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/CollectionTypeImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/CollectionTypeImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/CollectionTypeImpl.java
index f8f4b50..aeb3430 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/CollectionTypeImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/CollectionTypeImpl.java
@@ -15,22 +15,22 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.internal.NWayMergeResults;
-import com.gemstone.gemfire.cache.query.internal.Ordered;
-import com.gemstone.gemfire.cache.query.internal.ResultsSet;
-import com.gemstone.gemfire.cache.query.internal.SortedResultSet;
-import com.gemstone.gemfire.cache.query.internal.SortedStructSet;
-import com.gemstone.gemfire.cache.query.internal.StructSet;
-import com.gemstone.gemfire.cache.query.types.*;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.internal.NWayMergeResults;
+import org.apache.geode.cache.query.internal.Ordered;
+import org.apache.geode.cache.query.internal.ResultsSet;
+import org.apache.geode.cache.query.internal.SortedResultSet;
+import org.apache.geode.cache.query.internal.SortedStructSet;
+import org.apache.geode.cache.query.internal.StructSet;
+import org.apache.geode.cache.query.types.*;
 
 /**
  * Implementation of CollectionType

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ExtendedNumericComparator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ExtendedNumericComparator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ExtendedNumericComparator.java
index 649a8c2..f5b8afb 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ExtendedNumericComparator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ExtendedNumericComparator.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.internal.NullToken;
-import com.gemstone.gemfire.cache.query.internal.Undefined;
+import org.apache.geode.cache.query.internal.NullToken;
+import org.apache.geode.cache.query.internal.Undefined;
 
 /**
  * A general comparator that will let us compare different numeric types for equality

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/MapTypeImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/MapTypeImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/MapTypeImpl.java
index 4943e97..b3b36f0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/MapTypeImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/MapTypeImpl.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.io.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.DataSerializer;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/NumericComparator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/NumericComparator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/NumericComparator.java
index a09313c..5978cff 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/NumericComparator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/NumericComparator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ObjectTypeImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ObjectTypeImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ObjectTypeImpl.java
index 9ea5d63..5d488af 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ObjectTypeImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/ObjectTypeImpl.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 /**
  * Implementation of ObjectType

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/StructTypeImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/StructTypeImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/StructTypeImpl.java
index 1b7aa50..926ef51 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/StructTypeImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/StructTypeImpl.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
 
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Implementation of StructType

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TemporalComparator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TemporalComparator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TemporalComparator.java
index 0bbba7f..6c78068 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TemporalComparator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TemporalComparator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
index d244798..d2405dc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.types;
+package org.apache.geode.cache.query.internal.types;
 
 
 import java.util.Arrays;
@@ -24,19 +24,19 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.Support;
-import com.gemstone.gemfire.cache.query.internal.Undefined;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.types.MapType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.EnumInfo.PdxInstanceEnumInfo;
-import com.gemstone.gemfire.pdx.internal.PdxInstanceEnum;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.Undefined;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.types.MapType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.EnumInfo.PdxInstanceEnumInfo;
+import org.apache.geode.pdx.internal.PdxInstanceEnum;
+import org.apache.geode.pdx.internal.PdxString;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/LimitIterator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/LimitIterator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/LimitIterator.java
index af9e88d..4083613 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/LimitIterator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/LimitIterator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.utils;
+package org.apache.geode.cache.query.internal.utils;
 
 import java.util.Iterator;
 import java.util.NoSuchElementException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/PDXUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/PDXUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/PDXUtils.java
index 3bbeb33..b0457d0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/PDXUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/utils/PDXUtils.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.utils;
+package org.apache.geode.cache.query.internal.utils;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.internal.cache.VMCachedDeserializable;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 public class PDXUtils {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/package.html b/geode-core/src/main/java/org/apache/geode/cache/query/package.html
index c11298d..c7829cf 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/package.html
@@ -18,7 +18,7 @@ limitations under the License.
 <HTML>
 <HEAD>
 	<META HTTP-EQUIV="CONTENT-TYPE" CONTENT="text/html; charset=iso-8859-1">
-	<TITLE>com.gemstone.gemfire.cache.query</TITLE>
+	<TITLE>org.apache.geode.cache.query</TITLE>
 	<META NAME="GENERATOR" CONTENT="OpenOffice.org 1.1.4  (Solaris Sparc)">
 	<META NAME="CREATED" CONTENT="20050524;10003600">
 	<META NAME="CHANGEDBY" CONTENT="Eric Zoerner">
@@ -37,15 +37,15 @@ of a high-level query language. The query language allows you to
 access the data based on multiple attributes and to tranform the
 results. The service also allows you to create indexes in order to
 optimize the performance of data retrieval<B>. <BR></B><BR>The
-{@linkplain com.gemstone.gemfire.cache.query.QueryService
+{@linkplain org.apache.geode.cache.query.QueryService
 QueryService} interface provides the public entry point to query
 execution, query compilation, and index creation. A <TT>QueryService
 </TT>instance is obtained from {@linkplain
-com.gemstone.gemfire.cache.Cache#getQueryService}. Queries can also
+org.apache.geode.cache.Cache#getQueryService}. Queries can also
 be performed by using the shortcut methods {@linkplain
-com.gemstone.gemfire.cache.Region#query}, {@linkplain
-com.gemstone.gemfire.cache.Region#selectValue}, and {@linkplain
-com.gemstone.gemfire.cache.Region#existsValue}. 
+org.apache.geode.cache.Region#query}, {@linkplain
+org.apache.geode.cache.Region#selectValue}, and {@linkplain
+org.apache.geode.cache.Region#existsValue}. 
 </P>
 <P>This package description contains the following sections: 
 </P>
@@ -116,7 +116,7 @@ com.gemstone.gemfire.cache.Region#existsValue}.
 	generate structs whose elements can be referred to as an attribute
 	in the query language. Structures that are returned to Java are
 	immutable and implement the {@linkplain
-	com.gemstone.gemfire.cache.query.Struct Struct} interface. 
+	org.apache.geode.cache.query.Struct Struct} interface. 
 	</DD></DL>
 <H1>
 <A NAME="Query_Language"></A>Query Language</H1>
@@ -183,7 +183,7 @@ the keys or entries of the region. To facilitate this, when a region
 path evaluates to a Region in the context of a query, the type of
 object it refers to has the following interface: 
 </P>
-<PRE STYLE="margin-bottom: 0.2in"> interface QRegion extends com.gemstone.gemfire.cache.Region, java.util.Collection { }</PRE><P>
+<PRE STYLE="margin-bottom: 0.2in"> interface QRegion extends org.apache.geode.cache.Region, java.util.Collection { }</PRE><P>
 Thus, the interface inherits all the attributes and methods from both
 Region and Collection. When used as a Collection, the elements are
 the values of the region. This enables a query to use a Region as
@@ -225,7 +225,7 @@ is bound to a collection, or a nested SELECT statement. &nbsp;
 <H3><A NAME="SelectResults"></A><A NAME="Result of a Select Statement|outline"></A>
 Result of a Select Statement</H3>
 <P>The result of a SELECT statement is a collection that implements
-the {@linkplain com.gemstone.gemfire.cache.query.SelectResults
+the {@linkplain org.apache.geode.cache.query.SelectResults
 SelectResults} interface.</P>
 <P>The SelectResults is a simple collection of unstructured objects
 in two cases:</P>
@@ -563,7 +563,7 @@ same path found in a WHERE clause when used to compare against a
 constant expression (i.e. an expression that does not depend on the
 iterator context) using the relational operators. The exact use and
 specification of the indexedExpression varies depending on the index
-type. See {@linkplain com.gemstone.gemfire.cache.query.IndexType}. No
+type. See {@linkplain org.apache.geode.cache.query.IndexType}. No
 query parameters or region paths are permitted.</P>
 <P>The <I>imports</I> provides packages and classes used in variable
 typing and typecasts.</P>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/types/CollectionType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/types/CollectionType.java b/geode-core/src/main/java/org/apache/geode/cache/query/types/CollectionType.java
index ad2ddaf..e62f32f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/types/CollectionType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/types/CollectionType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.types;
+package org.apache.geode.cache.query.types;
 
 /**
  * Represents the type of a collection, an object that can contain element

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/types/MapType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/types/MapType.java b/geode-core/src/main/java/org/apache/geode/cache/query/types/MapType.java
index d532f53..ea555d1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/types/MapType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/types/MapType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.types;
+package org.apache.geode.cache.query.types;
 
 /**
  * Represents the type of a Map, a collection that contains keys as well

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/types/ObjectType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/types/ObjectType.java b/geode-core/src/main/java/org/apache/geode/cache/query/types/ObjectType.java
index 92ce907..2057a9c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/types/ObjectType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/types/ObjectType.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.types;
+package org.apache.geode.cache.query.types;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * An ObjectType represents the type of an object in a query.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/types/StructType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/types/StructType.java b/geode-core/src/main/java/org/apache/geode/cache/query/types/StructType.java
index 92c3d59..ef0390f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/types/StructType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/types/StructType.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.types;
+package org.apache.geode.cache.query.types;
 
 
 /**
  * Describes the field names and types for each field in a {@link
- * com.gemstone.gemfire.cache.query.Struct}.
+ * org.apache.geode.cache.query.Struct}.
  *
  * @since GemFire 4.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java b/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
index 57d7984..910f34d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.ClientSession;
-import com.gemstone.gemfire.cache.InterestRegistrationListener;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.cache.server.internal.ConnectionCountProbe;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.ClientSession;
+import org.apache.geode.cache.InterestRegistrationListener;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.server.ClientSubscriptionConfig;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.cache.server.internal.ConnectionCountProbe;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * A cache server that serves the contents of a
@@ -34,8 +34,8 @@ import com.gemstone.gemfire.distributed.DistributedMember;
  * client {@link Pool} to connect two regions
  * that reside in different distributed systems.
  *
- * @see com.gemstone.gemfire.cache.Cache#addCacheServer
- * @see com.gemstone.gemfire.cache.Cache#getCacheServers
+ * @see org.apache.geode.cache.Cache#addCacheServer
+ * @see org.apache.geode.cache.Cache#getCacheServers
  *
  * @since GemFire 5.7
  */
@@ -175,7 +175,7 @@ public interface CacheServer {
    * <p>Setting a specific bind address will cause the cache server to always
    * use this address and ignore any address specified by "server-bind-address"
    * or "bind-address" in the <code>gemfire.properties</code> file
-   * (see {@link com.gemstone.gemfire.distributed.DistributedSystem}
+   * (see {@link org.apache.geode.distributed.DistributedSystem}
    * for a description of these properties).
    * <p> The value <code>""</code> does not override the <code>gemfire.properties</code>.
    * It will cause the local machine's default address to be listened on if the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java b/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
index 9a4316c..62a9401 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
 /**
  * Used to configure queuing on a cache server for client subscriptions.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoad.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoad.java b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoad.java
index a0247f9..d94e0a9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoad.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoad.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbe.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbe.java b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbe.java
index 0848e94..03cdd92 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbe.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbe.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbeAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbeAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbeAdapter.java
index e64629a..905df15 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbeAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ServerLoadProbeAdapter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/ServerMetrics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ServerMetrics.java b/geode-core/src/main/java/org/apache/geode/cache/server/ServerMetrics.java
index 081cfb0..aba4b4a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ServerMetrics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ServerMetrics.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server;
+package org.apache.geode.cache.server;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/internal/ConnectionCountProbe.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/internal/ConnectionCountProbe.java b/geode-core/src/main/java/org/apache/geode/cache/server/internal/ConnectionCountProbe.java
index 59052f4..1754e7e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/internal/ConnectionCountProbe.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/internal/ConnectionCountProbe.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server.internal;
+package org.apache.geode.cache.server.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Properties;
 
-import com.gemstone.gemfire.DataSerializable;
-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.internal.cache.xmlcache.Declarable2;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.cache.server.ServerLoadProbeAdapter;
+import org.apache.geode.cache.server.ServerMetrics;
+import org.apache.geode.internal.cache.xmlcache.Declarable2;
 
 /**
  * A load probe which returns load as a function of the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/internal/LoadMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/internal/LoadMonitor.java b/geode-core/src/main/java/org/apache/geode/cache/server/internal/LoadMonitor.java
index f98e2e1..2de4932 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/internal/LoadMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/internal/LoadMonitor.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server.internal;
+package org.apache.geode.cache.server.internal;
 
 import java.util.ArrayList;
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.client.internal.CacheServerLoadMessage;
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.cache.server.ServerLoadProbe;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.internal.cache.CacheServerAdvisor;
-import com.gemstone.gemfire.internal.cache.tier.Acceptor;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerStats;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ConnectionListener;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.client.internal.CacheServerLoadMessage;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.cache.server.ServerLoadProbe;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.internal.cache.CacheServerAdvisor;
+import org.apache.geode.internal.cache.tier.Acceptor;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerStats;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ConnectionListener;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A class which monitors the load on a bridge server and 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/internal/ServerMetricsImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/internal/ServerMetricsImpl.java b/geode-core/src/main/java/org/apache/geode/cache/server/internal/ServerMetricsImpl.java
index bcfc4af..b63455d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/server/internal/ServerMetricsImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/internal/ServerMetricsImpl.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.server.internal;
+package org.apache.geode.cache.server.internal;
 
 import java.util.concurrent.atomic.AtomicInteger;
 
-import com.gemstone.gemfire.cache.server.ServerMetrics;
+import org.apache.geode.cache.server.ServerMetrics;
 
 /**
  * Metrics describing the load on a  bridge server.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/server/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/package.html b/geode-core/src/main/java/org/apache/geode/cache/server/package.html
index 42db083..d323ad0 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/server/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/package.html
@@ -17,25 +17,25 @@ limitations under the License.
 -->
 <HTML>
   <HEAD>
-    <TITLE>com.gemstone.gemfire.cache.server package</TITLE>
+    <TITLE>org.apache.geode.cache.server package</TITLE>
   </HEAD>
   <BODY>
-  The <code>com.gemstone.gemfire.cache.server</code> package provides APIs used
+  The <code>org.apache.geode.cache.server</code> package provides APIs used
   for the server side of client/server caching.
 <p>
-A {@link com.gemstone.gemfire.cache.server.CacheServer cache server} can be
+A {@link org.apache.geode.cache.server.CacheServer cache server} can be
 declared using the <code>cache-server</code> element described in the
 <code>cache6_5.dtd</code>.
 <p>
-Or it can be created by calling {@link com.gemstone.gemfire.cache.Cache#addCacheServer}.
+Or it can be created by calling {@link org.apache.geode.cache.Cache#addCacheServer}.
 <p>
 Another option is to use the <code>cacheserver</code> executable which can be found
 in the GemFire <code>bin</code> directory.
 <p>
 To obtain an instance of <code>CacheServer</code> that has already been created
-use {@link com.gemstone.gemfire.cache.Cache#getCacheServers}.
+use {@link org.apache.geode.cache.Cache#getCacheServers}.
 <p>
-See the <a href="{@docRoot}/com/gemstone/gemfire/cache/client/package-summary.html#package_description">client</a> package for information
+See the <a href="{@docRoot}/org/apache/geode/cache/client/package-summary.html#package_description">client</a> package for information
 on how to create clients that will connect to and access the cache in your
 cache server.
   </BODY>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/CacheSnapshotService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/CacheSnapshotService.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/CacheSnapshotService.java
index 3c57817..7af469c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/CacheSnapshotService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/CacheSnapshotService.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.File;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.snapshot.SnapshotOptions.SnapshotFormat;
+import org.apache.geode.pdx.PdxSerializer;
 
 /**
  * Allows a snapshot of cache data to be imported and exported. Each region in 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/RegionSnapshotService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/RegionSnapshotService.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/RegionSnapshotService.java
index 32d8c45..ed9a214 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/RegionSnapshotService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/RegionSnapshotService.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.File;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.snapshot.SnapshotOptions.SnapshotFormat;
+import org.apache.geode.pdx.PdxSerializer;
 
 /**
  * Allows a snapshot of region data to be imported and exported. Example usage:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotFilter.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotFilter.java
index 0c7cc81..4fa7e4d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotFilter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.Serializable;
 import java.util.Map.Entry;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotIterator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotIterator.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotIterator.java
index 07206ca..30c566f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotIterator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotIterator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.IOException;
 import java.util.NoSuchElementException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
index 01b4196..b3f3386 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotReader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotReader.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotReader.java
index 31e4f99..695025a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotReader.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotReader.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.snapshot;
+package org.apache.geode.cache.snapshot;
 
 import java.io.File;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.internal.cache.snapshot.GFSnapshot;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.internal.cache.snapshot.GFSnapshot;
+import org.apache.geode.pdx.PdxSerializer;
 
 /**
  * Provides utilities for reading cache data.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/snapshot/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/package.html b/geode-core/src/main/java/org/apache/geode/cache/snapshot/package.html
index 6239302..a5801c9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/package.html
@@ -17,7 +17,7 @@ limitations under the License.
 -->
 <html>
 <head>
- <title>com.gemstone.gemfire.cache.snapshot</title>
+ <title>org.apache.geode.cache.snapshot</title>
 </head>
 <body>
 
@@ -25,18 +25,18 @@ limitations under the License.
 Each snapshot file contains the cache entries (key/value pairs) for a given 
 region.</p>
 
-<p>The {@link com.gemstone.gemfire.cache.snapshot.RegionSnapshotService} can be 
+<p>The {@link org.apache.geode.cache.snapshot.RegionSnapshotService} can be 
 obtained for an individual region using 
-{@link com.gemstone.gemfire.cache.Region#getSnapshotService}. To obtain a 
-{@link com.gemstone.gemfire.cache.snapshot.CacheSnapshotService} (across all 
-regions), invoke {@link com.gemstone.gemfire.cache.Cache#getSnapshotService}.</p>
+{@link org.apache.geode.cache.Region#getSnapshotService}. To obtain a 
+{@link org.apache.geode.cache.snapshot.CacheSnapshotService} (across all 
+regions), invoke {@link org.apache.geode.cache.Cache#getSnapshotService}.</p>
 
-<p>The {@link com.gemstone.gemfire.cache.snapshot.SnapshotOptions} can be used to
+<p>The {@link org.apache.geode.cache.snapshot.SnapshotOptions} can be used to
 configure the behavior of import and export operations.</p>
 
-<p>The {@link com.gemstone.gemfire.cache.snapshot.SnapshotReader} can be used to
+<p>The {@link org.apache.geode.cache.snapshot.SnapshotReader} can be used to
 programmatically read a snapshot created using the GEMFIRE
-{@link com.gemstone.gemfire.cache.snapshot.SnapshotOptions.SnapshotFormat} 
+{@link org.apache.geode.cache.snapshot.SnapshotOptions.SnapshotFormat} 
 format.</p>
 
 Example usage:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/CacheListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/CacheListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/CacheListenerAdapter.java
index ccbf5b5..4d23081 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/CacheListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/CacheListenerAdapter.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.CacheListener;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.RegionEvent;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.RegionEvent;
 
 /**
  * <p>Utility class that implements all methods in <code>CacheListener</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/CacheWriterAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/CacheWriterAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/CacheWriterAdapter.java
index 60f23ed..9917d1b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/CacheWriterAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/CacheWriterAdapter.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.RegionEvent;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.RegionEvent;
 
 /**
  * Utility class that implements all methods in <code>CacheWriter</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/CqListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/CqListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/CqListenerAdapter.java
index ef2397e..2df8d7e 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/util/CqListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/CqListenerAdapter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 /**
  * Abstract class for CqListener. 
@@ -26,8 +26,8 @@ package com.gemstone.gemfire.cache.util;
  * @since GemFire 5.1
  */
 
-import com.gemstone.gemfire.cache.query.CqListener;
-import com.gemstone.gemfire.cache.query.CqEvent;
+import org.apache.geode.cache.query.CqListener;
+import org.apache.geode.cache.query.CqEvent;
 
 public abstract class CqListenerAdapter implements CqListener {
   
@@ -58,7 +58,7 @@ public abstract class CqListenerAdapter implements CqListener {
   * <p>It is possible for this method to be called multiple times on a single
   * callback instance, so implementations must be tolerant of this.
   *
-  * @see com.gemstone.gemfire.cache.CacheCallback#close
+  * @see org.apache.geode.cache.CacheCallback#close
   */
   public void close() {
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/Gateway.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/Gateway.java b/geode-core/src/main/java/org/apache/geode/cache/util/Gateway.java
index 296bc02..b0a39df 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/Gateway.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/Gateway.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictHelper.java b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictHelper.java
index 255c710..19ed42d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 /**
  * GatewayConflictHelper is used by an GatewayConflictResolver to decide what to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictResolver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictResolver.java b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictResolver.java
index 208a225..41a3509 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictResolver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayConflictResolver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/GatewayEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayEvent.java b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayEvent.java
index a73b6d1..e0d131f 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/util/GatewayEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/GatewayEvent.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
 
 /**
  * Interface <code>GatewayEvent</code> represents <code>Cache</code> events
@@ -26,7 +26,7 @@ import com.gemstone.gemfire.cache.Region;
  *
  * @since GemFire 5.1
  * 
- * @deprecated as of GemFire 8.0. Use {@link com.gemstone.gemfire.cache.wan.GatewayQueueEvent} instead
+ * @deprecated as of GemFire 8.0. Use {@link org.apache.geode.cache.wan.GatewayQueueEvent} instead
  * 
  */
 @Deprecated

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizer.java b/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizer.java
index 895fa69..cf55e36 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizer.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizer.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.internal.size.ReflectionObjectSizer;
-import com.gemstone.gemfire.internal.size.SizeClassOnceObjectSizer;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.internal.size.ReflectionObjectSizer;
+import org.apache.geode.internal.size.SizeClassOnceObjectSizer;
 
 /**
  * The sizer interface defines a method that when called returns the size of the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizerImpl.java
index 8fbd0e8..d1ca256 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/ObjectSizerImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 /**
  * This class provides an implementation of the ObjectSizer interface. This

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/RegionMembershipListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/RegionMembershipListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/RegionMembershipListenerAdapter.java
index a4167bf..adf3f28 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/RegionMembershipListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/RegionMembershipListenerAdapter.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.RegionMembershipListener;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionEvent;
+import org.apache.geode.cache.RegionMembershipListener;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Utility class that implements all methods in <code>RegionMembershipListener</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/RegionRoleListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/RegionRoleListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/RegionRoleListenerAdapter.java
index db3cc2d..2bf1206 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/util/RegionRoleListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/RegionRoleListenerAdapter.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.RegionRoleListener;
-import com.gemstone.gemfire.cache.RoleEvent;
+import org.apache.geode.cache.RegionRoleListener;
+import org.apache.geode.cache.RoleEvent;
 
 /**
  * Utility class that implements all methods in 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/TimestampedEntryEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/TimestampedEntryEvent.java b/geode-core/src/main/java/org/apache/geode/cache/util/TimestampedEntryEvent.java
index c714d63..00a0e4d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/TimestampedEntryEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/TimestampedEntryEvent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
 /**
  * TimestampedEntryEvent is an EntryEvent that has additional information provided
@@ -24,7 +24,7 @@ package com.gemstone.gemfire.cache.util;
  * previous change to the entry.
  * @since GemFire 7.0
  */
-public interface TimestampedEntryEvent extends com.gemstone.gemfire.cache.EntryEvent {
+public interface TimestampedEntryEvent extends org.apache.geode.cache.EntryEvent {
   // note that this interface inherits the following methods, among others:
   // getRegion(), getOperation(), getCallbackArgument()
   // getKey()

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/TransactionListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/TransactionListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/util/TransactionListenerAdapter.java
index ab0e16e..7aaa426 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/TransactionListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/TransactionListenerAdapter.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.util;
+package org.apache.geode.cache.util;
 
-import com.gemstone.gemfire.cache.TransactionListener;
-import com.gemstone.gemfire.cache.TransactionEvent;
+import org.apache.geode.cache.TransactionListener;
+import org.apache.geode.cache.TransactionEvent;
 
 /**
  * Utility class that implements all methods in <code>TransactionListener</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/util/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/util/package.html b/geode-core/src/main/java/org/apache/geode/cache/util/package.html
index 9fc799f..b42ffb4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/util/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/util/package.html
@@ -21,7 +21,7 @@ limitations under the License.
   </HEAD>
   <BODY>
   Provides utilities for use with the Caching API in the
-<code>com.gemstone.gemfire.cache.util</code> package.
+<code>org.apache.geode.cache.util</code> package.
 <p>
 Adapter classes are provided for convenience in implementing the
 CacheListener, RegionMembershipListener, RegionRoleListener, TransactionListener, and CacheWriter interfaces. These adapter

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/EventSequenceID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/EventSequenceID.java b/geode-core/src/main/java/org/apache/geode/cache/wan/EventSequenceID.java
index 54590ba..90223fe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/EventSequenceID.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/EventSequenceID.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
 import java.io.ByteArrayInputStream;
 import java.io.DataInputStream;
 import java.util.Arrays;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * This class wraps 1) DistributedMembershipID 2) ThreadID 3) SequenceID



[38/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
index 22e58f6..e387a69 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -28,18 +28,18 @@ import java.util.concurrent.atomic.AtomicInteger;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.internal.cache.ClientServerObserver;
-import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.internal.cache.ClientServerObserver;
+import org.apache.geode.internal.cache.ClientServerObserverHolder;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.logging.LogService;
 
 public class QueueStateImpl implements QueueState {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
index b516fd7..a2983e2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Tells the server we are ready to receive server-to-client events
@@ -43,7 +43,7 @@ public class ReadyForEventsOp {
   
   private static class ReadyForEventsOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public ReadyForEventsOpImpl() {
       super(MessageType.CLIENT_READY, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterDataSerializersOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterDataSerializersOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterDataSerializersOp.java
index 869ad64..72b8b1b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterDataSerializersOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterDataSerializersOp.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.internal.InternalDataSerializer.SerializerAttributesHolder;
-import com.gemstone.gemfire.internal.cache.ClientServerObserver;
-import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SerializationException;
+import org.apache.geode.internal.InternalDataSerializer.SerializerAttributesHolder;
+import org.apache.geode.internal.cache.ClientServerObserver;
+import org.apache.geode.internal.cache.ClientServerObserverHolder;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.util.BlobHelper;
 
 public class RegisterDataSerializersOp {
 
@@ -51,7 +51,7 @@ public class RegisterDataSerializersOp {
   private static class RegisterDataSerializersOpImpl extends AbstractOp {
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public RegisterDataSerializersOpImpl(DataSerializer[] dataSerializers,
         EventID eventId) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInstantiatorsOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInstantiatorsOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInstantiatorsOp.java
index d7a6fa5..aa53dfc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInstantiatorsOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInstantiatorsOp.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.io.IOException;
 
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.internal.InternalInstantiator.InstantiatorAttributesHolder;
-import com.gemstone.gemfire.internal.cache.ClientServerObserver;
-import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.Instantiator;
+import org.apache.geode.SerializationException;
+import org.apache.geode.internal.InternalInstantiator.InstantiatorAttributesHolder;
+import org.apache.geode.internal.cache.ClientServerObserver;
+import org.apache.geode.internal.cache.ClientServerObserverHolder;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.util.BlobHelper;
 
 /**
  * Register a bunch of instantiators on a server
@@ -74,7 +74,7 @@ public class RegisterInstantiatorsOp {
   
   private static class RegisterInstantiatorsOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public RegisterInstantiatorsOpImpl(Instantiator[] instantiators,
                                        EventID eventId) {
@@ -101,7 +101,7 @@ public class RegisterInstantiatorsOp {
     }
 
     /**
-     * @throws com.gemstone.gemfire.SerializationException
+     * @throws org.apache.geode.SerializationException
      *           if serialization fails
      */
     public RegisterInstantiatorsOpImpl(Object[] holders,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestListOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestListOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestListOp.java
index 9497407..e043cbd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestListOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestListOp.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.client.internal.RegisterInterestOp.RegisterInterestOpImpl;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.client.internal.RegisterInterestOp.RegisterInterestOpImpl;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.MessageType;
 
 /**
  * Does a region registerInterestList on a server
@@ -110,7 +110,7 @@ public class RegisterInterestListOp {
   
   private static class RegisterInterestListOpImpl extends RegisterInterestOpImpl {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public RegisterInterestListOpImpl(String region,
                                       List keys,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestOp.java
index b790064..8bf45c5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestOp.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -128,7 +128,7 @@ public class RegisterInterestOp {
   protected static class RegisterInterestOpImpl extends AbstractOp {
     protected String region;
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public RegisterInterestOpImpl(String region,
                                   Object key,
@@ -157,7 +157,7 @@ public class RegisterInterestOp {
     }
     /**
      * This constructor is used by our subclass CreateCQWithIROpImpl
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     protected RegisterInterestOpImpl(String region, int msgType, int numParts) {
       super(msgType, numParts);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestTracker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestTracker.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestTracker.java
index 1ba5028..453921f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestTracker.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RegisterInterestTracker.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.List;
@@ -24,15 +24,15 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.UnregisterAllInterest;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.UnregisterAllInterest;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Used to keep track of what interest a client has registered.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RemoveAllOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RemoveAllOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RemoveAllOp.java
index 7e62d00..0ec5317 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RemoveAllOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RemoveAllOp.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -27,22 +27,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException.PutAllPartialResult;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ChunkedMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PutAllPartialResultException;
+import org.apache.geode.internal.cache.PutAllPartialResultException.PutAllPartialResult;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.ChunkedMessage;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Does a region removeAll on a server
@@ -246,7 +246,7 @@ public class RemoveAllOp {
     private final Object callbackArg;
     
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public RemoveAllOpImpl(Region region, Collection<Object> keys,
         EventID eventId, boolean prSingleHopEnabled, Object callbackArg) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/RollbackOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RollbackOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RollbackOp.java
index bdaea85..a434257 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/RollbackOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/RollbackOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Does a Rollback on the server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerBlackList.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerBlackList.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerBlackList.java
index 0edd260..8da1940 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerBlackList.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerBlackList.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerProxy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerProxy.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerProxy.java
index 137f596..c7db8f9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerProxy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerProxy.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * Used to send operations from a client to a server.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
index c2deb11..aed24ca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Collection;
 import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EntrySnapshot;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EntrySnapshot;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.TransactionalOperation;
 
 public interface ServerRegionDataAccess {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
index 8c6c1d4..3d17f08 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Collection;
 import java.util.HashMap;
@@ -25,37 +25,37 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheLoader;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.ContainsKeyOp.MODE;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.AbstractRegion;
-import com.gemstone.gemfire.internal.cache.ClientServerObserver;
-import com.gemstone.gemfire.internal.cache.ClientServerObserverHolder;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.EventIDHolder;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.TXStateProxy;
-import com.gemstone.gemfire.internal.cache.execute.ServerRegionFunctionExecutor;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList.Iterator;
-import com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.CacheLoader;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.ContainsKeyOp.MODE;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.AbstractRegion;
+import org.apache.geode.internal.cache.ClientServerObserver;
+import org.apache.geode.internal.cache.ClientServerObserverHolder;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.EventIDHolder;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.cache.TXStateProxy;
+import org.apache.geode.internal.cache.execute.ServerRegionFunctionExecutor;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList.Iterator;
+import org.apache.geode.internal.cache.tx.ClientTXStateStub;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Used to send region operations from a client to a server
@@ -105,7 +105,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
     }
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#get(java.lang.Object, java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#get(java.lang.Object, java.lang.Object)
    */
   public Object get(Object key, Object callbackArg, EntryEventImpl clientEvent) {
     recordTXOperation(ServerRegionOperation.GET, key, callbackArg);
@@ -198,7 +198,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#destroy(java.lang.Object, java.lang.Object, com.gemstone.gemfire.cache.Operation, com.gemstone.gemfire.internal.cache.EventID, java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#destroy(java.lang.Object, java.lang.Object, org.apache.geode.cache.Operation, org.apache.geode.internal.cache.EventID, java.lang.Object)
    */
   public Object destroy(Object key,
                       Object expectedOldValue,
@@ -275,7 +275,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#clear(com.gemstone.gemfire.internal.cache.EventID, java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#clear(org.apache.geode.internal.cache.EventID, java.lang.Object)
    */
   public void clear(EventID eventId,
                     Object callbackArg)
@@ -296,7 +296,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
     ClearOp.execute(con, this.pool, this.regionName, eventId, callbackArg);
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
    */
   public boolean containsKey(Object key) {
     recordTXOperation(ServerRegionOperation.CONTAINS_KEY, key);
@@ -304,7 +304,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
    */
   public boolean containsValueForKey(Object key) {
     recordTXOperation(ServerRegionOperation.CONTAINS_VALUE_FOR_KEY, key);
@@ -312,7 +312,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#containsKey(java.lang.Object)
    */
   public boolean containsValue(Object value) {
     recordTXOperation(ServerRegionOperation.CONTAINS_VALUE, null, value);
@@ -320,7 +320,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess#keySet()
+   * @see org.apache.geode.cache.client.internal.ServerRegionDataAccess#keySet()
    */
   public Set keySet() {
     recordTXOperation(ServerRegionOperation.KEY_SET, null);
@@ -844,7 +844,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   
   /**
    * Transaction synchronization notification to the servers
-   * @see com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub#beforeCompletion()
+   * @see org.apache.geode.internal.cache.tx.ClientTXStateStub#beforeCompletion()
    */
   public void beforeCompletion(int txId) {
     TXSynchronizationOp.execute(pool, 0, txId, TXSynchronizationOp.CompletionType.BEFORE_COMPLETION);
@@ -854,7 +854,7 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
    * Transaction synchronization notification to the servers
    * @param status
    * @return the server's TXCommitMessage
-   * @see com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub#afterCompletion(int)
+   * @see org.apache.geode.internal.cache.tx.ClientTXStateStub#afterCompletion(int)
    */
   public TXCommitMessage afterCompletion(int status, int txId) {
     return TXSynchronizationOp.execute(pool, status, txId, TXSynchronizationOp.CompletionType.AFTER_COMPLETION);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
index c13cfea..cff40ac 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.HashMap;
 import java.util.HashSet;
@@ -31,25 +31,25 @@ import java.util.concurrent.ThreadFactory;
 import java.util.concurrent.atomic.AtomicInteger;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.cache.client.internal.GetAllOp.GetAllOpImpl;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionInvocationTargetException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.execute.InternalFunctionInvocationTargetException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.GemFireException;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.cache.client.internal.GetAllOp.GetAllOpImpl;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionInvocationTargetException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PutAllPartialResultException;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class SingleHopClientExecutor {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
index a42ba8d..002d4bd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.concurrent.Callable;
 
-import com.gemstone.gemfire.cache.client.AllConnectionsInUseException;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
-import com.gemstone.gemfire.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.cache.client.AllConnectionsInUseException;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionOp.ExecuteRegionFunctionOpImpl;
+import org.apache.geode.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
+import org.apache.geode.distributed.internal.ServerLocation;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/SizeOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SizeOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SizeOp.java
index 170e846..1c8e8fe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SizeOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SizeOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Does a region size on a server
@@ -43,7 +43,7 @@ public class SizeOp {
   
   private static class SizeOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public SizeOpImpl(String region) {
       super(MessageType.SIZE, 1);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXFailoverOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXFailoverOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXFailoverOp.java
index 0c5628d..f5a8334 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXFailoverOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXFailoverOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 /**
  * Indicates to the server that a transaction is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
index ee348a8..c6dea22 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.SynchronizationCommitConflictException;
-import com.gemstone.gemfire.cache.client.ServerOperationException;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
+import org.apache.geode.GemFireException;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.SynchronizationCommitConflictException;
+import org.apache.geode.cache.client.ServerOperationException;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.sockets.Part;
 
 /**
  * TXSynchronizationOp sends JTA beforeCompletion and afterCompletion
@@ -101,7 +101,7 @@ public class TXSynchronizationOp {
 
     
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.cache.client.internal.AbstractOp#processResponse(com.gemstone.gemfire.internal.cache.tier.sockets.Message)
+     * @see org.apache.geode.cache.client.internal.AbstractOp#processResponse(org.apache.geode.internal.cache.tier.sockets.Message)
      */
     @Override
     protected Object processResponse(Message msg) throws Exception {
@@ -122,7 +122,7 @@ public class TXSynchronizationOp {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.cache.client.internal.AbstractOp#isErrorResponse(int)
+     * @see org.apache.geode.cache.client.internal.AbstractOp#isErrorResponse(int)
      */
     @Override
     protected boolean isErrorResponse(int msgType) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestListOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestListOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestListOp.java
index b408bf5..2d55c9d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestListOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestListOp.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
 
 import java.util.Iterator;
 import java.util.List;
@@ -52,7 +52,7 @@ public class UnregisterInterestListOp {
   
   private static class UnregisterInterestListOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public UnregisterInterestListOpImpl(String region,
                                         List keys,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestOp.java
index b266e60..3716587 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UnregisterInterestOp.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.cache.tier.InterestType;
 
 /**
  * Does a region unregisterInterest on a server
@@ -52,7 +52,7 @@ public class UnregisterInterestOp {
   
   private static class UnregisterInterestOpImpl extends AbstractOp {
     /**
-     * @throws com.gemstone.gemfire.SerializationException if serialization fails
+     * @throws org.apache.geode.SerializationException if serialization fails
      */
     public UnregisterInterestOpImpl(String region,
                                     Object key,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/UserAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UserAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UserAttributes.java
index cfb8d50..99939e1 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/UserAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/UserAttributes.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal;
+package org.apache.geode.cache.client.internal;
 
 import java.util.Properties;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 public class UserAttributes {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionRequest.java
index dee109e..729032d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionRequest.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 /**
  * A request from a client to the locator asking for a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionResponse.java
index 18d4037..d70a46a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientConnectionResponse.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 /**
  * A response from a locator to a client

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientReplacementRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientReplacementRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientReplacementRequest.java
index 5a2ba7f..c3898c3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientReplacementRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ClientReplacementRequest.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
 
 /**
  * A request from a client to the locator asking for a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
index 858675d..12bda7e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.internal.DataSerializableFixedID;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
index b50ab4a..7f9c6af 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,9 +22,9 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.DataSerializableFixedID;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
index 2128047..414292f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
index bed21ee..193363b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,8 +22,8 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusRequest.java
index 99f9191..5d93e68 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusRequest.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 /**
  * The LocatorStatusRequest class...
  * </p>
- * @see com.gemstone.gemfire.cache.client.internal.locator.ServerLocationRequest
- * @see com.gemstone.gemfire.internal.DataSerializableFixedID
+ * @see org.apache.geode.cache.client.internal.locator.ServerLocationRequest
+ * @see org.apache.geode.internal.DataSerializableFixedID
  * @since GemFire 7.0
  */
 public class LocatorStatusRequest extends ServerLocationRequest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusResponse.java
index 07aaf33..0affa8c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorStatusResponse.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,17 +26,17 @@ import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.process.PidUnavailableException;
-import com.gemstone.gemfire.internal.process.ProcessUtils;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.process.PidUnavailableException;
+import org.apache.geode.internal.process.ProcessUtils;
 
 /**
  * The LocatorStatusResponse class...
  * </p>
- * @see com.gemstone.gemfire.cache.client.internal.locator.ServerLocationResponse
+ * @see org.apache.geode.cache.client.internal.locator.ServerLocationResponse
  * @since GemFire 7.0
  */
 public class LocatorStatusResponse extends ServerLocationResponse {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionRequest.java
index cbbfe91..49e039e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionRequest.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 /**
  * A request from a client to locator asking for a server

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionResponse.java
index ed36883..356ff64 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/QueueConnectionResponse.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
 
 /**
  * A response from locator to client indicating the servers

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
index fbcdcf6..cee4e4d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,9 +26,9 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.BucketServerLocation66;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.BucketServerLocation66;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
index 8c963b7..aaf5919 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
index 23047ce..fc04b5f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator;
+package org.apache.geode.cache.client.internal.locator;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
index 3ee08a1..aae9b3d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.locator.wan;
+package org.apache.geode.cache.client.internal.locator.wan;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
 
 import java.util.Set;
 import java.util.concurrent.ConcurrentMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionDestroyedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionDestroyedException.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionDestroyedException.java
index 12e1959..643e1c8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionDestroyedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionDestroyedException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.pooling;
+package org.apache.geode.cache.client.internal.pooling;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Indicates that the current connection has already been destroyed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
index 2f25222..dc293a3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.pooling;
+package org.apache.geode.cache.client.internal.pooling;
 
 import java.util.Set;
 
 import java.util.concurrent.ScheduledExecutorService;
-import com.gemstone.gemfire.cache.client.AllConnectionsInUseException;
-import com.gemstone.gemfire.cache.client.NoAvailableServersException;
-import com.gemstone.gemfire.cache.client.internal.Connection;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
+import org.apache.geode.cache.client.AllConnectionsInUseException;
+import org.apache.geode.cache.client.NoAvailableServersException;
+import org.apache.geode.cache.client.internal.Connection;
+import org.apache.geode.distributed.internal.ServerLocation;
 
 /**
  * A pool for managing client to server connections. This interface

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
index e7eb3c0..4bc6dad 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.pooling;
+package org.apache.geode.cache.client.internal.pooling;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.GatewayConfigurationException;
-import com.gemstone.gemfire.cache.client.*;
-import com.gemstone.gemfire.cache.client.internal.*;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl.PoolTask;
-import com.gemstone.gemfire.distributed.PoolCancelledException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.internal.cache.PoolStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.GatewayConfigurationException;
+import org.apache.geode.cache.client.*;
+import org.apache.geode.cache.client.internal.*;
+import org.apache.geode.cache.client.internal.PoolImpl.PoolTask;
+import org.apache.geode.distributed.PoolCancelledException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.cache.PoolManagerImpl;
+import org.apache.geode.internal.cache.PoolStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.security.GemFireSecurityException;
 import org.apache.logging.log4j.Logger;
 
 import java.net.SocketException;
@@ -141,7 +141,7 @@ public class ConnectionManagerImpl implements ConnectionManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager#borrowConnection(long)
+   * @see org.apache.geode.cache.client.internal.pooling.ConnectionManager#borrowConnection(long)
    */
   public Connection borrowConnection(long acquireTimeout) throws AllConnectionsInUseException, NoAvailableServersException {
     
@@ -464,7 +464,7 @@ public class ConnectionManagerImpl implements ConnectionManager {
   
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager#invalidateServer(com.gemstone.gemfire.distributed.internal.ServerLocation)
+   * @see org.apache.geode.cache.client.internal.pooling.ConnectionManager#invalidateServer(org.apache.geode.distributed.internal.ServerLocation)
    */
   protected void invalidateServer(Endpoint endpoint) {
     Set badConnections = allConnectionsMap.removeEndpoint(endpoint);
@@ -524,7 +524,7 @@ public class ConnectionManagerImpl implements ConnectionManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager#returnConnection(com.gemstone.gemfire.cache.client.internal.Connection)
+   * @see org.apache.geode.cache.client.internal.pooling.ConnectionManager#returnConnection(org.apache.geode.cache.client.internal.Connection)
    */
   public void returnConnection(Connection connection) {
     returnConnection(connection, true);
@@ -611,7 +611,7 @@ public class ConnectionManagerImpl implements ConnectionManager {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.client.internal.pooling.ConnectionManager#close(boolean, long)
+   * @see org.apache.geode.cache.client.internal.pooling.ConnectionManager#close(boolean, long)
    */
   public void close(boolean keepAlive) {
     if(logger.isDebugEnabled()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
index 7dcbaad..fd469e7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/PooledConnection.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.client.internal.pooling;
+package org.apache.geode.cache.client.internal.pooling;
 
 import java.io.InputStream;
 import java.io.OutputStream;
@@ -23,14 +23,14 @@ import java.net.SocketException;
 import java.nio.ByteBuffer;
 import java.util.concurrent.atomic.AtomicBoolean;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.client.internal.Connection;
-import com.gemstone.gemfire.cache.client.internal.ConnectionImpl;
-import com.gemstone.gemfire.cache.client.internal.ConnectionStats;
-import com.gemstone.gemfire.cache.client.internal.Endpoint;
-import com.gemstone.gemfire.cache.client.internal.Op;
-import com.gemstone.gemfire.distributed.internal.ServerLocation;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerQueueStatus;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.client.internal.Connection;
+import org.apache.geode.cache.client.internal.ConnectionImpl;
+import org.apache.geode.cache.client.internal.ConnectionStats;
+import org.apache.geode.cache.client.internal.Endpoint;
+import org.apache.geode.cache.client.internal.Op;
+import org.apache.geode.distributed.internal.ServerLocation;
+import org.apache.geode.internal.cache.tier.sockets.ServerQueueStatus;
 
 /**
  * A connection managed by the connection manager. Keeps track

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/client/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/package.html b/geode-core/src/main/java/org/apache/geode/cache/client/package.html
index 9898040..598c7a4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/package.html
@@ -17,27 +17,27 @@ limitations under the License.
 -->
 <HTML>
   <HEAD>
-    <TITLE>com.gemstone.gemfire.cache.client package</TITLE>
+    <TITLE>org.apache.geode.cache.client package</TITLE>
   </HEAD>
   <BODY>
-  The <code>com.gemstone.gemfire.cache.client</code> package provides APIs used
+  The <code>org.apache.geode.cache.client</code> package provides APIs used
   for client connectivity and caching.
 <p>
 Most clients will only need to create a 
-{@link com.gemstone.gemfire.cache.client.ClientCache}
+{@link org.apache.geode.cache.client.ClientCache}
 using a
-{@link com.gemstone.gemfire.cache.client.ClientCacheFactory}.
+{@link org.apache.geode.cache.client.ClientCacheFactory}.
 <p>
 A client configures the servers it will connect to by creating one or more
-{@link com.gemstone.gemfire.cache.client.Pool pools}.
+{@link org.apache.geode.cache.client.Pool pools}.
 For most use cases one pool per client is all you need and the easiest
 way to get a single pool is to use
-{@link com.gemstone.gemfire.cache.client.ClientCacheFactory}.
+{@link org.apache.geode.cache.client.ClientCacheFactory}.
 If you do need more than one pool use a
-{@link com.gemstone.gemfire.cache.client.PoolFactory pool factory} obtained from the
-{@link com.gemstone.gemfire.cache.client.PoolManager pool manager} before you
+{@link org.apache.geode.cache.client.PoolFactory pool factory} obtained from the
+{@link org.apache.geode.cache.client.PoolManager pool manager} before you
 create the cache using 
-{@link com.gemstone.gemfire.cache.client.ClientCacheFactory}.
+{@link org.apache.geode.cache.client.ClientCacheFactory}.
 <p>
 An alternative to these APIs is to use the <code>pool</code> XML element
 as described in the <code>cache6_5.dtd</code>.
@@ -46,7 +46,7 @@ If you create more than one pool then for regions that will use a pool you
 need to configure the pool name on the regions.
 This can be done by setting the
 pool name on the region using the
-{@link com.gemstone.gemfire.cache.client.ClientRegionFactory#setPoolName API}
+{@link org.apache.geode.cache.client.ClientRegionFactory#setPoolName API}
 or using the <code>pool-name</code> attribute on the <code>region-attributes</code>
 as described in the <code>cache6_5.dtd</code>.
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceFactory.java b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceFactory.java
index 49ff30c..c2b3842 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.control;
+package org.apache.geode.cache.control;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceOperation.java b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceOperation.java
index 0051423..b3da0c9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.control;
+package org.apache.geode.cache.control;
 
 import java.util.concurrent.CancellationException;
 import java.util.concurrent.TimeUnit;
@@ -23,7 +23,7 @@ import java.util.concurrent.TimeoutException;
 
 /**
  * Operation for rebalancing resources used by the {@link 
- * com.gemstone.gemfire.cache.Cache}.
+ * org.apache.geode.cache.Cache}.
  * 
  * @since GemFire 6.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceResults.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceResults.java b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceResults.java
index be0d3d2..b2b1f79 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/control/RebalanceResults.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.control;
+package org.apache.geode.cache.control;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.partition.PartitionRebalanceInfo;
+import org.apache.geode.cache.partition.PartitionRebalanceInfo;
 
 /**
  * The results of rebalancing <code>Cache</code> resources.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/control/ResourceManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/control/ResourceManager.java b/geode-core/src/main/java/org/apache/geode/cache/control/ResourceManager.java
index 3226b24..1738be5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/control/ResourceManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/control/ResourceManager.java
@@ -15,20 +15,20 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.control;
+package org.apache.geode.cache.control;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Provides support for managing resources used by the local
- * {@link com.gemstone.gemfire.cache.Cache}.
+ * {@link org.apache.geode.cache.Cache}.
  * <p>
  * Re-balancing the GemFire Cache resources can be accomplished using a {@link
  * RebalanceOperation}:
@@ -95,7 +95,7 @@ public interface ResourceManager {
    * <li>{@link Region#create(Object, Object)}
    * <li>{@link Region#create(Object, Object, Object)}
    * <li>{@link Region#putAll(java.util.Map)}
-   * <li>{@linkplain QueryService#createIndex(String, com.gemstone.gemfire.cache.query.IndexType, String, String) index creation}
+   * <li>{@linkplain QueryService#createIndex(String, org.apache.geode.cache.query.IndexType, String, String) index creation}
    * <li>Execution of {@link Function}s whose {@link Function#optimizeForWrite()} returns true.
    * </ul>
    *
@@ -158,7 +158,7 @@ public interface ResourceManager {
    * <li>{@link Region#create(Object, Object)}
    * <li>{@link Region#create(Object, Object, Object)}
    * <li>{@link Region#putAll(java.util.Map)}
-   * <li>{@linkplain QueryService#createIndex(String, com.gemstone.gemfire.cache.query.IndexType, String, String) index creation}
+   * <li>{@linkplain QueryService#createIndex(String, org.apache.geode.cache.query.IndexType, String, String) index creation}
    * <li>Execution of {@link Function}s whose {@link Function#optimizeForWrite()} returns true.
    * </ul>
    *



[13/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfigValidator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfigValidator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfigValidator.java
index b3ca5e5..bb14576 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfigValidator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionRegionConfigValidator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.HashSet;
@@ -24,18 +24,18 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.DuplicatePrimaryPartitionException;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.DuplicatePrimaryPartitionException;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
index 175a284..6e4fcd5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
@@ -15,98 +15,98 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueImpl;
-import com.gemstone.gemfire.cache.client.internal.*;
-import com.gemstone.gemfire.cache.execute.*;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.cache.partition.PartitionNotAvailableException;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.cache.query.internal.index.*;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DisconnectListener;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRemoteToken;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MemberAttributes;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.SetUtils;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor.ServerBucketProfile;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DestroyPartitionedRegionMessage.DestroyPartitionedRegionResponse;
-import com.gemstone.gemfire.internal.cache.PutAllPartialResultException.PutAllPartialResult;
-import com.gemstone.gemfire.internal.cache.control.HeapMemoryMonitor;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.cache.execute.*;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.cache.partitioned.*;
-import com.gemstone.gemfire.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.DestroyMessage.DestroyResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.DumpB2NRegion.DumpB2NResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchBulkEntriesMessage.FetchBulkEntriesResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntriesMessage.FetchEntriesResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntryMessage.FetchEntryResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchKeysMessage.FetchKeysResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.GetMessage.GetResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.IdentityRequestMessage.IdentityResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.IdentityUpdateMessage.IdentityUpdateResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.InterestEventMessage.InterestEventResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.InvalidateMessage.InvalidateResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.PRUpdateEntryVersionMessage.UpdateEntryVersionResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage.PartitionResponse;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage.PutResult;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
-import com.gemstone.gemfire.internal.cache.partitioned.SizeMessage.SizeResponse;
-import com.gemstone.gemfire.internal.cache.persistence.PRPersistentConfig;
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
-import com.gemstone.gemfire.internal.cache.tier.sockets.BaseCommand;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tier.sockets.command.Get70;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderConfigurationException;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderException;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.sequencelog.RegionLogger;
-import com.gemstone.gemfire.internal.util.TransformUtils;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueImpl;
+import org.apache.geode.cache.client.internal.*;
+import org.apache.geode.cache.execute.*;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.cache.partition.PartitionNotAvailableException;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.cache.query.internal.index.*;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.DisconnectListener;
+import org.apache.geode.distributed.internal.locks.DLockRemoteToken;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MemberAttributes;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.BucketAdvisor.ServerBucketProfile;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DestroyPartitionedRegionMessage.DestroyPartitionedRegionResponse;
+import org.apache.geode.internal.cache.PutAllPartialResultException.PutAllPartialResult;
+import org.apache.geode.internal.cache.control.HeapMemoryMonitor;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryEvent;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.cache.execute.*;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.lru.HeapEvictor;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.partitioned.*;
+import org.apache.geode.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueResponse;
+import org.apache.geode.internal.cache.partitioned.DestroyMessage.DestroyResponse;
+import org.apache.geode.internal.cache.partitioned.DumpB2NRegion.DumpB2NResponse;
+import org.apache.geode.internal.cache.partitioned.FetchBulkEntriesMessage.FetchBulkEntriesResponse;
+import org.apache.geode.internal.cache.partitioned.FetchEntriesMessage.FetchEntriesResponse;
+import org.apache.geode.internal.cache.partitioned.FetchEntryMessage.FetchEntryResponse;
+import org.apache.geode.internal.cache.partitioned.FetchKeysMessage.FetchKeysResponse;
+import org.apache.geode.internal.cache.partitioned.GetMessage.GetResponse;
+import org.apache.geode.internal.cache.partitioned.IdentityRequestMessage.IdentityResponse;
+import org.apache.geode.internal.cache.partitioned.IdentityUpdateMessage.IdentityUpdateResponse;
+import org.apache.geode.internal.cache.partitioned.InterestEventMessage.InterestEventResponse;
+import org.apache.geode.internal.cache.partitioned.InvalidateMessage.InvalidateResponse;
+import org.apache.geode.internal.cache.partitioned.PRUpdateEntryVersionMessage.UpdateEntryVersionResponse;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage.PartitionResponse;
+import org.apache.geode.internal.cache.partitioned.PutMessage.PutResult;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor.PartitionProfile;
+import org.apache.geode.internal.cache.partitioned.SizeMessage.SizeResponse;
+import org.apache.geode.internal.cache.persistence.PRPersistentConfig;
+import org.apache.geode.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.sockets.BaseCommand;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tier.sockets.command.Get70;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderConfigurationException;
+import org.apache.geode.internal.cache.wan.GatewaySenderException;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
+import org.apache.geode.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.sequencelog.RegionLogger;
+import org.apache.geode.internal.util.TransformUtils;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;
@@ -2051,7 +2051,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#checkIfAboveThreshold(com.gemstone.gemfire.internal.cache.EntryEventImpl)
+   * @see org.apache.geode.internal.cache.LocalRegion#checkIfAboveThreshold(org.apache.geode.internal.cache.EntryEventImpl)
    */
   @Override
   public void checkIfAboveThreshold(EntryEventImpl evi)
@@ -5951,7 +5951,7 @@ public class PartitionedRegion extends LocalRegion implements
   /*
    * We yet don't have any stats for this operation.
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#basicUpdateEntryVersion(com.gemstone.gemfire.internal.cache.EntryEventImpl)
+   * @see org.apache.geode.internal.cache.LocalRegion#basicUpdateEntryVersion(org.apache.geode.internal.cache.EntryEventImpl)
    */
   @Override
   void basicUpdateEntryVersion(EntryEventImpl event)
@@ -8357,7 +8357,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.LocalRegion#dumpBackingMap()
+   * @see org.apache.geode.internal.cache.LocalRegion#dumpBackingMap()
    */
   @Override
   public void dumpBackingMap() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionBucketMgmtHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionBucketMgmtHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionBucketMgmtHelper.java
index 2d1ae19..79a397d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionBucketMgmtHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionBucketMgmtHelper.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.SetUtils;
-import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.SetUtils;
+import org.apache.geode.internal.cache.partitioned.Bucket;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataStore.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataStore.java
index 494c288..76de6ae 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataStore.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataStore.java
@@ -14,49 +14,49 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.cache.query.internal.index.IndexCreationData;
-import com.gemstone.gemfire.cache.query.internal.index.PartitionedIndex;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.BucketRegion.RawValue;
-import com.gemstone.gemfire.internal.cache.LocalRegion.RegionPerfStats;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.BucketLock;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.SizeEntry;
-import com.gemstone.gemfire.internal.cache.execute.BucketMovedException;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.execute.PartitionedRegionFunctionResultSender;
-import com.gemstone.gemfire.internal.cache.execute.RegionFunctionContextImpl;
-import com.gemstone.gemfire.internal.cache.partitioned.*;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveBucketMessage.RemoveBucketResponse;
-import com.gemstone.gemfire.internal.cache.persistence.BackupManager;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableReadLock;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableWriteLock;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.index.IndexCreationData;
+import org.apache.geode.cache.query.internal.index.PartitionedIndex;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.BucketRegion.RawValue;
+import org.apache.geode.internal.cache.LocalRegion.RegionPerfStats;
+import org.apache.geode.internal.cache.PartitionedRegion.BucketLock;
+import org.apache.geode.internal.cache.PartitionedRegion.SizeEntry;
+import org.apache.geode.internal.cache.execute.BucketMovedException;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.execute.PartitionedRegionFunctionResultSender;
+import org.apache.geode.internal.cache.execute.RegionFunctionContextImpl;
+import org.apache.geode.internal.cache.partitioned.*;
+import org.apache.geode.internal.cache.partitioned.RemoveBucketMessage.RemoveBucketResponse;
+import org.apache.geode.internal.cache.persistence.BackupManager;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySender;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.parallel.ConcurrentParallelGatewaySenderQueue;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableReadLock;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock.StoppableWriteLock;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;
@@ -70,10 +70,10 @@ import java.util.concurrent.locks.Lock;
 
 /**
  * Implementation of DataStore (DS) for a PartitionedRegion (PR). This will be
-import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySenderEventProcessor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderImpl;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
+import org.apache.geode.internal.cache.wan.AbstractGatewaySenderEventProcessor;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.parallel.ParallelGatewaySenderImpl;
+import org.apache.geode.internal.cache.wan.parallel.ParallelGatewaySenderQueue;
  * accessed via accessor of PartitionedRegion or PartionService thread which
  * will handle remote calls to this DataStore from other nodes participating in
  * this PartitionedRegion.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataView.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataView.java
index 02a84ee..e73f059 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataView.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionDataView.java
@@ -17,14 +17,14 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionException.java
index 6cb7ca0..1cbc932 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheRuntimeException;
 
 /**
  * RuntimeException propagated to invoking code to signal problem with remote

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionHelper.java
index 397f35f..d185187 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.IOException;
 import java.util.ArrayList;
@@ -29,41 +29,41 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.EntryOperation;
-import com.gemstone.gemfire.cache.FixedPartitionAttributes;
-import com.gemstone.gemfire.cache.FixedPartitionResolver;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.PartitionResolver;
-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.partition.PartitionNotAvailableException;
-import com.gemstone.gemfire.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.cache.util.CacheWriterAdapter;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-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.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
-import com.gemstone.gemfire.internal.cache.partitioned.PRLocallyDestroyedException;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.EntryOperation;
+import org.apache.geode.cache.FixedPartitionAttributes;
+import org.apache.geode.cache.FixedPartitionResolver;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.PartitionResolver;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionExistsException;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.partition.PartitionNotAvailableException;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.cache.util.CacheWriterAdapter;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.partitioned.Bucket;
+import org.apache.geode.internal.cache.partitioned.PRLocallyDestroyedException;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
index 987d8a0..7f12cc5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.cache.query.internal.IndexTrackingQueryObserver.IndexInfo;
-import com.gemstone.gemfire.cache.query.internal.utils.PDXUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.partitioned.QueryMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.StreamingPartitionOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CopyHelper;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.cache.query.internal.IndexTrackingQueryObserver.IndexInfo;
+import org.apache.geode.cache.query.internal.utils.PDXUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.partitioned.QueryMessage;
+import org.apache.geode.internal.cache.partitioned.StreamingPartitionOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 import it.unimi.dsi.fastutil.ints.IntOpenHashSet;
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenHashMap;
 import org.apache.logging.log4j.Logger;
@@ -346,7 +346,7 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
         if (isDebugEnabled) {
           logger.debug("Following remote members failed {} and retry flag is set to: {}", failedMembers, requiresRetry);
         }
-      } catch (com.gemstone.gemfire.cache.TimeoutException e) {  //Shobhit: Swallow remote exception if
+      } catch (org.apache.geode.cache.TimeoutException e) {  //Shobhit: Swallow remote exception if
                                                                  //         local exception is there.
         if (localFault == null) {
           throw new QueryException(e);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStats.java
index c6f1243..558176a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStats.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collections;
 import java.util.Map;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * Represents a statistics type that can be archived to vsd. Loading of this

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStatus.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStatus.java
index 193d7ba..2f7dc38 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionStatus.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Class <code>PartitionedRegionStatus</code> provides information about

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PeerTXStateStub.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PeerTXStateStub.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PeerTXStateStub.java
index a600a44..4ffbd0e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PeerTXStateStub.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PeerTXStateStub.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.TransactionDataRebalancedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.TransactionInDoubtException;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyException;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage.RemoteCommitResponse;
-import com.gemstone.gemfire.internal.cache.tx.DistributedTXRegionStub;
-import com.gemstone.gemfire.internal.cache.tx.PartitionedTXRegionStub;
-import com.gemstone.gemfire.internal.cache.tx.TXRegionStub;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.TransactionDataRebalancedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.TransactionInDoubtException;
+import org.apache.geode.cache.client.internal.ServerRegionDataAccess;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ReliableReplyException;
+import org.apache.geode.distributed.internal.ReliableReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXRemoteCommitMessage.RemoteCommitResponse;
+import org.apache.geode.internal.cache.tx.DistributedTXRegionStub;
+import org.apache.geode.internal.cache.tx.PartitionedTXRegionStub;
+import org.apache.geode.internal.cache.tx.TXRegionStub;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 public class PeerTXStateStub extends TXStateStub {
 
@@ -50,7 +50,7 @@ public class PeerTXStateStub extends TXStateStub {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#rollback()
+   * @see org.apache.geode.internal.cache.TXStateInterface#rollback()
    */
   @Override
   public void rollback() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PersistentOplogSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PersistentOplogSet.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PersistentOplogSet.java
index af84423..747f49d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PersistentOplogSet.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PersistentOplogSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import it.unimi.dsi.fastutil.longs.LongOpenHashSet;
 
@@ -36,20 +36,20 @@ import java.util.concurrent.atomic.AtomicLong;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.FileUtil;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.OplogEntryIdSet;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreFilter;
-import com.gemstone.gemfire.internal.cache.persistence.OplogType;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.FileUtil;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskStoreImpl.OplogEntryIdSet;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.persistence.DiskStoreFilter;
+import org.apache.geode.internal.cache.persistence.OplogType;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.sequencelog.EntryLogger;
 
 public class PersistentOplogSet implements OplogSet {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PlaceHolderDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PlaceHolderDiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PlaceHolderDiskRegion.java
index df858f6..b78f7b5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PlaceHolderDiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PlaceHolderDiskRegion.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskRegionView;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
    * Used to represent a recovered disk region. Once the region actually exists

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PoolFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolFactoryImpl.java
index 1b6ce7a..fea9e5c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolFactoryImpl.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.PoolFactory;
-import com.gemstone.gemfire.cache.client.internal.LocatorDiscoveryCallback;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.pdx.internal.TypeRegistry;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.PoolFactory;
+import org.apache.geode.cache.client.internal.LocatorDiscoveryCallback;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.pdx.internal.TypeRegistry;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PoolManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolManagerImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolManagerImpl.java
index bc5441b..97b926c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolManagerImpl.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collections;
 import java.util.HashMap;
@@ -25,25 +25,25 @@ import java.util.Map.Entry;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.PoolFactory;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.client.internal.RegisterDataSerializersOp;
-import com.gemstone.gemfire.cache.client.internal.RegisterInstantiatorsOp;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.InternalDataSerializer.SerializerAttributesHolder;
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.InternalInstantiator.InstantiatorAttributesHolder;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ServerConnection;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.PoolFactory;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.client.internal.RegisterDataSerializersOp;
+import org.apache.geode.cache.client.internal.RegisterInstantiatorsOp;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.InternalDataSerializer.SerializerAttributesHolder;
+import org.apache.geode.internal.InternalInstantiator;
+import org.apache.geode.internal.InternalInstantiator.InstantiatorAttributesHolder;
+import org.apache.geode.internal.cache.tier.sockets.ServerConnection;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Implementation used by PoolManager.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PoolStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolStats.java
index e53b61c..fcb8a2e 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PoolStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PoolStats.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
 
 /**
  * GemFire statistics about a Pool 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PreferBytesCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PreferBytesCachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PreferBytesCachedDeserializable.java
index 3a582ab..a58fd10 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PreferBytesCachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PreferBytesCachedDeserializable.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
 
 /**
  * This cache deserializable always keeps its byte[] in serialized form.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PrimaryBucketException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PrimaryBucketException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PrimaryBucketException.java
index 4a5696b..2bc7ad1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PrimaryBucketException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PrimaryBucketException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * An exception thrown if a bucket instance is not primary yet was requested

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ProfileExchangeProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ProfileExchangeProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ProfileExchangeProcessor.java
index fe0e6b0..ea82e84 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ProfileExchangeProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ProfileExchangeProcessor.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.HashSet;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.InitialImageAdvice;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.InitialImageAdvice;
 
 /**
  * Used to exchange profiles during region initialization and determine the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyBucketRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyBucketRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyBucketRegion.java
index 7078fe2..b8aad7a 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyBucketRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyBucketRegion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collections;
 import java.util.EnumSet;
@@ -26,32 +26,32 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.RegionService;
-import com.gemstone.gemfire.cache.persistence.PartitionOfflineException;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.BucketLock;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore.CreateBucketResult;
-import com.gemstone.gemfire.internal.cache.partitioned.Bucket;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMembershipView;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.RegionService;
+import org.apache.geode.cache.persistence.PartitionOfflineException;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.PartitionedRegion.BucketLock;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore.CreateBucketResult;
+import org.apache.geode.internal.cache.partitioned.Bucket;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMembershipView;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Empty shell for {@link BucketRegion} which exists only to maintain metadata

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyRegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyRegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyRegionMap.java
index 99d96ab..2e1ba3e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyRegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ProxyRegionMap.java
@@ -15,36 +15,36 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.Collections;
 import java.util.List;
 import java.util.Set;
 
-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.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.AbstractRegionMap.ARMLockTestHook;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionHolder;
-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.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.cache.CacheWriter;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.AbstractRegionMap.ARMLockTestHook;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionHolder;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * Internal implementation of {@link RegionMap}for regions whose DataPolicy is
@@ -532,7 +532,7 @@ final class ProxyRegionMap implements RegionMap {
       throw new UnsupportedOperationException(LocalizedStrings.ProxyRegionMap_NO_ENTRY_SUPPORT_ON_REGIONS_WITH_DATAPOLICY_0.toLocalizedString(DataPolicy.EMPTY));
     }
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.cache.RegionEntry#getSerializedValueOnDisk(com.gemstone.gemfire.internal.cache.LocalRegion)
+     * @see org.apache.geode.internal.cache.RegionEntry#getSerializedValueOnDisk(org.apache.geode.internal.cache.LocalRegion)
      */
     public Object getSerializedValueOnDisk(LocalRegion localRegion) {
       throw new UnsupportedOperationException(LocalizedStrings.ProxyRegionMap_NO_ENTRY_SUPPORT_ON_REGIONS_WITH_DATAPOLICY_0.toLocalizedString(DataPolicy.EMPTY));
@@ -588,7 +588,7 @@ final class ProxyRegionMap implements RegionMap {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.internal.cache.RegionEntry#concurrencyCheck(com.gemstone.gemfire.internal.cache.LocalRegion, com.gemstone.gemfire.internal.cache.versions.VersionTag, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember, com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember)
+     * @see org.apache.geode.internal.cache.RegionEntry#concurrencyCheck(org.apache.geode.internal.cache.LocalRegion, org.apache.geode.internal.cache.versions.VersionTag, org.apache.geode.distributed.internal.membership.InternalDistributedMember, org.apache.geode.distributed.internal.membership.InternalDistributedMember)
      */
     public void processVersionTag(LocalRegion r, VersionTag tag,
         InternalDistributedMember thisVM, InternalDistributedMember sender) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/PutAllPartialResultException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PutAllPartialResultException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PutAllPartialResultException.java
index 39e1a02..42b0f0c 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PutAllPartialResultException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PutAllPartialResultException.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.CancelException;
+import org.apache.geode.GemFireException;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
 import java.io.Serializable;
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/QueuedOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/QueuedOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/QueuedOperation.java
index 7be2bb9..40fcd3c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/QueuedOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/QueuedOperation.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.DistributedMember;
 import java.io.*;
 
 /**
@@ -42,7 +42,7 @@ public class QueuedOperation
 
   /**
    * Deserialization policies defined in AbstractUpdateOperation
-   * @see com.gemstone.gemfire.internal.cache.AbstractUpdateOperation
+   * @see org.apache.geode.internal.cache.AbstractUpdateOperation
    */
   private final byte deserializationPolicy;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionClearedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionClearedException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionClearedException.java
index 03d6759..088a51f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionClearedException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionClearedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Indicates that a Clear Operation happened while an entry operation

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
index 48ed5db..bee123d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_FILL_IN_VALUE;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_PREPARE_VALUE_FOR_CACHE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_FILL_IN_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ABSTRACT_REGION_ENTRY_PREPARE_VALUE_FOR_CACHE;
 
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-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.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  * Internal interface for a region entry.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryContext.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryContext.java
index 064c8f2..7d83586 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryContext.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryContext.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.compression.Compressor;
+import org.apache.geode.compression.Compressor;
 
 /**
  * Provides important contextual information that allows a {@link RegionEntry} to manage its state.
  * @since GemFire 8.0
  */
 public interface RegionEntryContext extends HasCachePerfStats {
-  public static final String DEFAULT_COMPRESSION_PROVIDER="com.gemstone.gemfire.compression.SnappyCompressor";
+  public static final String DEFAULT_COMPRESSION_PROVIDER="org.apache.geode.compression.SnappyCompressor";
   
   /**
    * Returns the compressor to be used by this region entry when storing the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryFactory.java
index a5d9d79..330c198 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntryFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEventImpl.java
index 333dfd2..dad8be0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEventImpl.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.lang.ClassNotFoundException;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * Implementation of a region event
@@ -126,7 +126,7 @@ public class RegionEventImpl
   /**
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.cache.CacheEvent#getRegion()
+   * @see org.apache.geode.cache.CacheEvent#getRegion()
    */
   public Region getRegion()
   {
@@ -152,7 +152,7 @@ public class RegionEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#getCallbackArgument()
+   * @see org.apache.geode.cache.CacheEvent#getCallbackArgument()
    */
   public Object getCallbackArgument()
   {
@@ -181,7 +181,7 @@ public class RegionEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#isOriginRemote()
+   * @see org.apache.geode.cache.CacheEvent#isOriginRemote()
    */
   public boolean isOriginRemote()
   {
@@ -199,7 +199,7 @@ public class RegionEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#isExpiration()
+   * @see org.apache.geode.cache.CacheEvent#isExpiration()
    */
   public boolean isExpiration()
   {
@@ -207,7 +207,7 @@ public class RegionEventImpl
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.CacheEvent#isDistributed()
+   * @see org.apache.geode.cache.CacheEvent#isDistributed()
    */
   public boolean isDistributed()
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEvictorTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEvictorTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEvictorTask.java
index e47ae91..444cb4e 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEvictorTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEvictorTask.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.lru.HeapEvictor;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.lru.HeapEvictor;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionExpiryTask.java
index 2e97065..0fbe869 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionExpiryTask.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * RegionExpiryTask represents a timeout event for region expiration
  */
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.ExpirationAttributes;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TimeoutException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TimeoutException;
 
 abstract class RegionExpiryTask extends ExpiryTask
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionFactoryImpl.java
index 254d37d..536cbca 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionFactoryImpl.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.File;
 import java.util.Properties;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.client.ClientNotReadyException;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.client.ClientNotReadyException;
 
 /**
  * <code>RegionFactoryImpl</code> extends RegionFactory

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionIdleExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionIdleExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionIdleExpiryTask.java
index ca98f5f..8d6ff61 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionIdleExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionIdleExpiryTask.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionListener.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionListener.java
index dd66301..08721cf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionListener.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
 
 /**
  * Callback on a cache that receives notifications about region creates.


[36/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/package.html b/geode-core/src/main/java/org/apache/geode/cache/package.html
index 84a071b..5e0cd92 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/package.html
@@ -46,16 +46,16 @@ the programmer's guide for performance guidelines.</p>
 Top</a>
 
 <p>Function execution facilitates movement of behavior in the form of
-{@linkplain com.gemstone.gemfire.cache.execute.Function}s executed using the
-{@linkplain com.gemstone.gemfire.cache.execute.FunctionService
+{@linkplain org.apache.geode.cache.execute.Function}s executed using the
+{@linkplain org.apache.geode.cache.execute.FunctionService
 Function Execution Service}.  A Function may generate results from
-parallel execution on many {@linkplain com.gemstone.gemfire.cache.execute.FunctionService#onMembers(String...) members}
-, or several {@linkplain com.gemstone.gemfire.cache.execute.FunctionService#onServers(Pool)
+parallel execution on many {@linkplain org.apache.geode.cache.execute.FunctionService#onMembers(String...) members}
+, or several {@linkplain org.apache.geode.cache.execute.FunctionService#onServers(Pool)
 Cache Servers}, or perhaps evaluating {@link
-com.gemstone.gemfire.cache.execute.FunctionService#onRegion(Region) Region} data.  A {@linkplain
-com.gemstone.gemfire.cache.execute.ResultCollector} collects and
+org.apache.geode.cache.execute.FunctionService#onRegion(Region) Region} data.  A {@linkplain
+org.apache.geode.cache.execute.ResultCollector} collects and
 possibly processes those results for consumption.  For more information look to the
-<a href="{@docRoot}/com/gemstone/gemfire/cache/execute/package-summary.html#package_description">com.gemstone.gemfire.cache.execute</a> package.
+<a href="{@docRoot}/org/apache/geode/cache/execute/package-summary.html#package_description">org.apache.geode.cache.execute</a> package.
 </p>
 
 <a name="distcache"><h2>Distributed Caching</h2><a href="#top">Back to Top</a>
@@ -68,41 +68,41 @@ efficiently shared among multiple threads in a VM, multiple VMs
 running on the same physical machine, and multiple VMs running on
 multiple machines.  Cached data resides in "regions" whose
 contents are stored in a VM's heap.</p>
-<p>The {@link com.gemstone.gemfire.cache.CacheFactory} class provides
+<p>The {@link org.apache.geode.cache.CacheFactory} class provides
 the entry point to the caching API.  A <code>CacheFactory</code> is
-configured to create a {@linkplain com.gemstone.gemfire.cache.Cache
+configured to create a {@linkplain org.apache.geode.cache.Cache
 "cache instance"} that resides in the VM.  The cache factory also allows
-the {@link com.gemstone.gemfire.distributed.DistributedSystem} to be configured.</p>
+the {@link org.apache.geode.distributed.DistributedSystem} to be configured.</p>
 
 <a name="regions"><h2>Cache Regions</h2></a><a href="#top">Back to Top</a>
 
 <p>Application data is cached in a {@linkplain
-com.gemstone.gemfire.cache.Region "region"}.  The {@link
-com.gemstone.gemfire.cache.RegionFactory} class provides the simpliest
-entry point into the {@linkplain com.gemstone.gemfire.cache.Region}
-API. A {@link com.gemstone.gemfire.cache.Region} implements {@link java.util.Map},
+org.apache.geode.cache.Region "region"}.  The {@link
+org.apache.geode.cache.RegionFactory} class provides the simpliest
+entry point into the {@linkplain org.apache.geode.cache.Region}
+API. A {@link org.apache.geode.cache.Region} implements {@link java.util.Map},
 however, it also provides caching behavior such as data loading,
 eviction control, and distribution.  Every region has a name and
 regions may be nested to provide a cache-naming hierarchy ("parent
 regions" with "subregions").  The root regions of the naming hierarchy
 (that is, the regions with no parent) are obtained with the {@link
-com.gemstone.gemfire.cache.Cache#rootRegions} method.
+org.apache.geode.cache.Cache#rootRegions} method.
 Any region may be obtained with the {@link
-com.gemstone.gemfire.cache.Cache#getRegion} method.</p>
+org.apache.geode.cache.Cache#getRegion} method.</p>
 
 <p>Region properties such as the region's cache loader, data policy, and
 storage model are specified by an instance of {@link
-com.gemstone.gemfire.cache.RegionAttributes}.  A region
+org.apache.geode.cache.RegionAttributes}.  A region
 <code>RegionAttributes</code> object can be specified when {@linkplain
-com.gemstone.gemfire.cache.Region#createSubregion creating} a
+org.apache.geode.cache.Region#createSubregion creating} a
 region.</p>
 
 <a name="partition"><h2>Partitioned Regions</h2><a href="#top">Back to Top</a>
 
 <p>Region data can be partitioned across many distributed system members to create one large logical heap.
-The data policy must be set to {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}
-or {@link com.gemstone.gemfire.cache.DataPolicy#PERSISTENT_PARTITION}.
-{@link com.gemstone.gemfire.cache.PartitionAttributes} are used to configure
+The data policy must be set to {@link org.apache.geode.cache.DataPolicy#PARTITION}
+or {@link org.apache.geode.cache.DataPolicy#PERSISTENT_PARTITION}.
+{@link org.apache.geode.cache.PartitionAttributes} are used to configure
 a partitioned region.  A partitioned region can be configured to be
 highly available, surviving the loss of one or more system members, by
 maintaining copies of data.  These extra copies also benefit read operations by
@@ -115,13 +115,13 @@ the entire Region in the face of a full garbage collection cycle.</p>
 </p>
 
 <p>Partitioned Regions support custom partitioning with the use of a
-{@link com.gemstone.gemfire.cache.PartitionResolver} and can be
+{@link org.apache.geode.cache.PartitionResolver} and can be
 associated together or
-{@linkplain com.gemstone.gemfire.cache.PartitionAttributesFactory#setColocatedWith(String)
+{@linkplain org.apache.geode.cache.PartitionAttributesFactory#setColocatedWith(String)
 colocated} to allow for efficient data usage.
 </p>
 
-<p>A {@link com.gemstone.gemfire.cache.partition.PartitionRegionHelper}
+<p>A {@link org.apache.geode.cache.partition.PartitionRegionHelper}
 class provides methods to facilitate usage of Partitioned
 Regions with other features, for example when used in conjunction with <a
 href="#functions">function execution</a>.
@@ -132,13 +132,13 @@ href="#functions">function execution</a>.
 <!-- Life cycle, constrained keys -->
 
 <p>A region contains key/value pairs of objects known as the region's
-{@linkplain com.gemstone.gemfire.cache.Region.Entry "entries"}.  The
+{@linkplain org.apache.geode.cache.Region.Entry "entries"}.  The
 <code>Region</code> class provides a number of methods for
 manipulating the region's entries such as {@link
-com.gemstone.gemfire.cache.Region#create create}, {@link
-com.gemstone.gemfire.cache.Region#put put}, {@link
-com.gemstone.gemfire.cache.Region#invalidate invalidate}, and {@link
-com.gemstone.gemfire.cache.Region#destroy destroy} .  The following
+org.apache.geode.cache.Region#create create}, {@link
+org.apache.geode.cache.Region#put put}, {@link
+org.apache.geode.cache.Region#invalidate invalidate}, and {@link
+org.apache.geode.cache.Region#destroy destroy} .  The following
 diagram describes the life cycle of a region entry.</p>
 
 <CENTER>
@@ -149,9 +149,9 @@ diagram describes the life cycle of a region entry.</p>
 <a name="consistency"><h2>Distribution and Consistency Models</h2><a href="#top">Back to Top</a>
 
 <p>A region's {@linkplain
-com.gemstone.gemfire.cache.RegionAttributes#getScope scope} attribute
+org.apache.geode.cache.RegionAttributes#getScope scope} attribute
 determines how the region's entries will be distributed to other
-caches.  A region with {@linkplain com.gemstone.gemfire.cache.Scope#LOCAL local} scope
+caches.  A region with {@linkplain org.apache.geode.cache.Scope#LOCAL local} scope
 will not distribute any of its changes to any other members of the
 distributed system, nor will it receive changes when another cache
 instance is updated.</p>
@@ -162,25 +162,25 @@ that change is distributed to the other members of the distributed
 system that have created that region in their cache instance.  There
 are three kinds of distributed scope, each of which guarantees a
 different level of consistency for distributed data.  {@linkplain
-com.gemstone.gemfire.cache.Scope#GLOBAL "Global"
+org.apache.geode.cache.Scope#GLOBAL "Global"
 scope} provides the highest level of data consistency by obtaining a
-{@linkplain com.gemstone.gemfire.distributed.DistributedLockService
+{@linkplain org.apache.geode.distributed.DistributedLockService
 distributed lock} on a region entry before propagating a change to other
 members of the distributed system.  With globally-scoped regions, only
 one thread in the entire distributed system may modify the region entry at a
 time.</p>
 
-<p>{@linkplain com.gemstone.gemfire.cache.Scope#DISTRIBUTED_ACK
+<p>{@linkplain org.apache.geode.cache.Scope#DISTRIBUTED_ACK
 "Distributed ACK" scope} provides slightly weaker data consistency
 than global scope.  With distributed ACK scope, the method that
 modifies the region (such as a call to {@link
-com.gemstone.gemfire.cache.Region#destroy}) will not return until an
+org.apache.geode.cache.Region#destroy}) will not return until an
 acknowledgment of the change has been received from every member of
 the distributed system.  Multiple threads may modify the region
 concurrently, but the modifying thread may proceed knowing that its
 change to the region has been seen by all other members.</p>
 
-<p>{@linkplain com.gemstone.gemfire.cache.Scope#DISTRIBUTED_NO_ACK
+<p>{@linkplain org.apache.geode.cache.Scope#DISTRIBUTED_NO_ACK
 "Distributed NO ACK" scope} provides the weakest data consistency of
 all the scopes, but also provides the best performance.  A method invocation that
 modifies a region with distributed NO ACK scope will return
@@ -196,32 +196,32 @@ may be stored in either the JVM's heap or on a disk drive.
 
 <a name="dataPolicy"><h3>Data Policy</h3></a><a href="#top">Back to Top</a>
 
-<p>A region's {@linkplain com.gemstone.gemfire.cache.DataPolicy
+<p>A region's {@linkplain org.apache.geode.cache.DataPolicy
 "data policy" attribute} determines if data is stored in the local cache.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#NORMAL normal policy}
+The {@linkplain org.apache.geode.cache.DataPolicy#NORMAL normal policy}
 will store region data in the local cache.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#EMPTY empty policy}
+The {@linkplain org.apache.geode.cache.DataPolicy#EMPTY empty policy}
 will never store region data in the local cache. They act as proxy regions that
 distribute write operations to others and receive events from others.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#withReplication replication policies}
+The {@linkplain org.apache.geode.cache.DataPolicy#withReplication replication policies}
 may reduce the number of net searches that a caching application has to be perform,
 and can provide a backup mechanism. The replicated region initializes itself when
 it is created with the keys and value of the region as found in other caches.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#REPLICATE replicate policy} simply stores the relicate data in memory and
-the {@linkplain com.gemstone.gemfire.cache.DataPolicy#PERSISTENT_REPLICATE persistent replicate policy} stores the data in memory and disk.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#withPartitioning partition policies} are used for <a href="#partition">partitioned</a> regions.
-The {@linkplain com.gemstone.gemfire.cache.DataPolicy#PARTITION partition policy} simply stores the <a href="#partition">partitioned</a> data in memory and
-the {@linkplain com.gemstone.gemfire.cache.DataPolicy#PERSISTENT_PARTITION persistent partition policy} stores the <a href="#partition">partitioned</a> data in memory and disk.
+The {@linkplain org.apache.geode.cache.DataPolicy#REPLICATE replicate policy} simply stores the relicate data in memory and
+the {@linkplain org.apache.geode.cache.DataPolicy#PERSISTENT_REPLICATE persistent replicate policy} stores the data in memory and disk.
+The {@linkplain org.apache.geode.cache.DataPolicy#withPartitioning partition policies} are used for <a href="#partition">partitioned</a> regions.
+The {@linkplain org.apache.geode.cache.DataPolicy#PARTITION partition policy} simply stores the <a href="#partition">partitioned</a> data in memory and
+the {@linkplain org.apache.geode.cache.DataPolicy#PERSISTENT_PARTITION persistent partition policy} stores the <a href="#partition">partitioned</a> data in memory and disk.
 </p>
 
 <a name="storageOnDisk"><h3>Disk Storage</h3></a>
 
 <p>GemFire supports several modes of region persistence as determined by
-the {@linkplain com.gemstone.gemfire.cache.DataPolicy#withPersistence
+the {@linkplain org.apache.geode.cache.DataPolicy#withPersistence
 persistent data policies} and the {@link
-com.gemstone.gemfire.cache.RegionAttributes#getEvictionAttributes}'s {@linkplain
-com.gemstone.gemfire.cache.EvictionAction eviction action}
-of {@linkplain com.gemstone.gemfire.cache.EvictionAction#OVERFLOW_TO_DISK overflow-to-disk}.
+org.apache.geode.cache.RegionAttributes#getEvictionAttributes}'s {@linkplain
+org.apache.geode.cache.EvictionAction eviction action}
+of {@linkplain org.apache.geode.cache.EvictionAction#OVERFLOW_TO_DISK overflow-to-disk}.
 The following table summarizes the different modes and their configuration.</p>
 
 <table border="1">
@@ -254,7 +254,7 @@ The following table summarizes the different modes and their configuration.</p>
  <td>false</td>
  <td>Disk for persistence</td>
  <td>All data in the region is {@linkplain
-     com.gemstone.gemfire.cache.DiskStore scheduled to be
+     org.apache.geode.cache.DiskStore scheduled to be
      written} to disk as soon as it is placed in the region.  Thus,
      the data on disk contains a complete backup of the region.  No
      information about recently used data is maintained and,
@@ -269,7 +269,7 @@ The following table summarizes the different modes and their configuration.</p>
  <td>true</td>
  <td>Disk for overflow and persistence</td>
  <td>All data in the region is {@linkplain
-     com.gemstone.gemfire.cache.DiskStore scheduled to be
+     org.apache.geode.cache.DiskStore scheduled to be
      written} to disk as soon as it is placed in the region.  But
      unlike "disk for persistence" mode, the least recently used data will
      be removed from the VM once the eviction controller's
@@ -284,15 +284,15 @@ that store data on disk.</p>
 <UL>
 
 <LI>Operations (such as {@link
-com.gemstone.gemfire.cache.Region#invalidate invalidate} and {@link
-com.gemstone.gemfire.cache.Region#destroy}) that remove data from the
+org.apache.geode.cache.Region#invalidate invalidate} and {@link
+org.apache.geode.cache.Region#destroy}) that remove data from the
 cache also remove data from disk.  In order for data to be removed
 from the VM and not from disk, {@linkplain
-com.gemstone.gemfire.cache.EvictionAction#OVERFLOW_TO_DISK}
+org.apache.geode.cache.EvictionAction#OVERFLOW_TO_DISK}
 overflow} must be used.</LI>
 
 <LI>When disk overflow is enabled, only the {@linkplain
-com.gemstone.gemfire.cache.Region.Entry#getValue value} of the least
+org.apache.geode.cache.Region.Entry#getValue value} of the least
 recently used entry is removed from the VM.  That is, the entry's key
 and the entry itself remain in the VM.</LI>
 
@@ -306,40 +306,40 @@ the same region is created.</LI>
 <LI>GemFire will look for the value of a region entry on disk before
 it will look in other cache instances.  That is, it will not perform a
 net search or a {@linkplain
-com.gemstone.gemfire.cache.CacheLoader#load load} if the value exists
+org.apache.geode.cache.CacheLoader#load load} if the value exists
 on disk.</LI>
 
 <LI>When data is read from or written to disk, no {@linkplain
-com.gemstone.gemfire.cache.CacheEvent cache events} are fired.</LI>
+org.apache.geode.cache.CacheEvent cache events} are fired.</LI>
 
 <LI>Region operations such as {@linkplain
-com.gemstone.gemfire.cache.Region#destroy destroy} and {@linkplain
-com.gemstone.gemfire.cache.Region#invalidate invalidate} effect the
+org.apache.geode.cache.Region#destroy destroy} and {@linkplain
+org.apache.geode.cache.Region#invalidate invalidate} effect the
 data that is stored on disk in addition to the data stored in the VM.
 That is, if an entry is destroyed in the VM (even by an {@link
-com.gemstone.gemfire.cache.ExpirationAction}), it will also be destroyed on disk.</LI>
+org.apache.geode.cache.ExpirationAction}), it will also be destroyed on disk.</LI>
 
 </UL>
 
 <h3>Region backup and restore</h3>
 
 Any GemFire resource that stores data on disk does so by configuring itself
-to use a {@link com.gemstone.gemfire.cache.DiskStore disk store}.
+to use a {@link org.apache.geode.cache.DiskStore disk store}.
 Disk stores are created using the
-{@link com.gemstone.gemfire.cache.DiskStoreFactory disk store factory API} or by
+{@link org.apache.geode.cache.DiskStoreFactory disk store factory API} or by
 configuring them in XML using the "disk-store" element.
 
 Region's specify the disk store they are in by setting the
-{@link com.gemstone.gemfire.cache.RegionAttributes#getDiskStoreName disk store name region attribute}.
+{@link org.apache.geode.cache.RegionAttributes#getDiskStoreName disk store name region attribute}.
 
-<P>A {@linkplain com.gemstone.gemfire.cache.Region#put put} on a region
+<P>A {@linkplain org.apache.geode.cache.Region#put put} on a region
 that is configured to have a disk "backup" (by using a
-{@linkplain com.gemstone.gemfire.cache.DataPolicy#withPersistence
+{@linkplain org.apache.geode.cache.DataPolicy#withPersistence
 persistent data policy})
  will result in the immediate scheduling of a
 disk write according to the region's {@link
-com.gemstone.gemfire.cache.DiskStore disk store}
-and the  {@linkplain com.gemstone.gemfire.cache.RegionAttributes#isDiskSynchronous
+org.apache.geode.cache.DiskStore disk store}
+and the  {@linkplain org.apache.geode.cache.RegionAttributes#isDiskSynchronous
 disk synchronous region attribute}.</P>
 
 <P>The actual backup data is stored in each of the disk store's specified disk
@@ -381,15 +381,15 @@ data.</P>
 
 <!-- CacheLoader, netSearch, netLoad -->
 
-<p>A {@linkplain com.gemstone.gemfire.cache.CacheLoader cache loader}
+<p>A {@linkplain org.apache.geode.cache.CacheLoader cache loader}
 allows data from outside of the VM to be placed into a region.  When
-{@link com.gemstone.gemfire.cache.Region#get} is called for a region
+{@link org.apache.geode.cache.Region#get} is called for a region
 entry that has a <code>null</code> value, the {@link
-com.gemstone.gemfire.cache.CacheLoader#load load} method of the
+org.apache.geode.cache.CacheLoader#load load} method of the
 region's cache loader is invoked.  The <code>load</code> method
 creates the value for the desired key by performing an operation such
 as a database query.  The <code>load</code> may also perform a
-{@linkplain com.gemstone.gemfire.cache.LoaderHelper#netSearch net
+{@linkplain org.apache.geode.cache.LoaderHelper#netSearch net
 search} that will look for the value in a cache instance hosted by
 another member of the distributed system.</p>
 
@@ -404,7 +404,7 @@ the remote cache's region.</p>
 
 <a name="cachewriter"><h2>Cache Writers</h2><a href="#top">Back to Top</a>
 
-<p>The {@link com.gemstone.gemfire.cache.CacheWriter} is a type of event handler
+<p>The {@link org.apache.geode.cache.CacheWriter} is a type of event handler
 that is invoked <em>synchronously before</em> the cache is modified, and has
 the ability to abort the operation. Only one CacheWriter in the distributed system
 is invoked before the operation that would modify a cache. A CacheWriter
@@ -413,13 +413,13 @@ is typically used to update an external database.</p>
 <a name="expiration"><h2>Expiration</h2></a><a href="#top">Back to Top</a>
 
 <p>Sometimes cached data has a limited lifetime.  The region attributes
-{@linkplain com.gemstone.gemfire.cache.RegionAttributes#getRegionTimeToLive
+{@linkplain org.apache.geode.cache.RegionAttributes#getRegionTimeToLive
 regionTimeToLive}, {@linkplain
-com.gemstone.gemfire.cache.RegionAttributes#getRegionIdleTimeout
+org.apache.geode.cache.RegionAttributes#getRegionIdleTimeout
 regionIdleTimeout}, {@linkplain
-com.gemstone.gemfire.cache.RegionAttributes#getEntryTimeToLive
+org.apache.geode.cache.RegionAttributes#getEntryTimeToLive
 entryTimeToLive}, and {@linkplain
-com.gemstone.gemfire.cache.RegionAttributes#getEntryIdleTimeout
+org.apache.geode.cache.RegionAttributes#getEntryIdleTimeout
 entryIdleTimeout}, specify how data is handled when it becomes too
 old.  There are two conditions under which cache data is considered
 too old: data has resided unchanged in a region for a given amount of time
@@ -430,25 +430,25 @@ time").  GemFire's caching implementation launches an "expiration
 thread" that periodically monitors region entries and will expire
 those that have become too old.  When a region entry expires, it can
 either be {@linkplain
-com.gemstone.gemfire.cache.ExpirationAction#INVALIDATE
+org.apache.geode.cache.ExpirationAction#INVALIDATE
 invalidated},  {@linkplain
-com.gemstone.gemfire.cache.ExpirationAction#DESTROY
+org.apache.geode.cache.ExpirationAction#DESTROY
 destroyed}, {@linkplain
-com.gemstone.gemfire.cache.ExpirationAction#LOCAL_INVALIDATE locally
+org.apache.geode.cache.ExpirationAction#LOCAL_INVALIDATE locally
 invalidated}, or {@linkplain
-com.gemstone.gemfire.cache.ExpirationAction#LOCAL_DESTROY locally destroyed}.</p>
+org.apache.geode.cache.ExpirationAction#LOCAL_DESTROY locally destroyed}.</p>
 
 <a name="event"><h2>Cache Events</h2></a><a href="#top">Back to Top</a>
 
-<p>The {@link com.gemstone.gemfire.cache.CacheListener}
+<p>The {@link org.apache.geode.cache.CacheListener}
 interface provides callback methods that are invoked synchronously in
 response to certain operations (such as a <code>put</code> or
 <code>invalidate</code>) being performed on a region.  The event
 listener for a region is specified with the {@link
-com.gemstone.gemfire.cache.AttributesFactory#setCacheListener
+org.apache.geode.cache.AttributesFactory#setCacheListener
 setCacheListener} method.  Each callback method on the
 <code>CacheListener</code> receives a {@link
-com.gemstone.gemfire.cache.CacheEvent} describing the operation
+org.apache.geode.cache.CacheEvent} describing the operation
 that caused the callback to be invoked and possibly containing information
 relevant to the operation
 (such as the old and new values of a region entry).</p>
@@ -462,7 +462,7 @@ instance, an eviction controller could keep track of the sizes of the
 entry values.  Before a new entry is added, the eviction controller
 could remove the entry with the largest value to free up space in
 the cache instance for new data.  GemFire provides {@link
-com.gemstone.gemfire.cache.EvictionAttributes} that will create an eviction controller
+org.apache.geode.cache.EvictionAttributes} that will create an eviction controller
 that destroys the "least recently used" Region Entry once the Region
 exceeds a given number of entries.</p>
 
@@ -470,7 +470,7 @@ exceeds a given number of entries.</p>
 
 <!-- API statistics and VSD statistics -->
 
-<p>The {@link com.gemstone.gemfire.cache.CacheStatistics} class
+<p>The {@link org.apache.geode.cache.CacheStatistics} class
 provides statistics information about the usage of a region or entry.
 Statistics are often used by eviction controllers to determine which
 entries should be invalidated or destroyed when the region reaches its
@@ -497,13 +497,13 @@ href="{@docRoot}/javadoc-images/example3-cache.xml">example3</A>.
 In this configuration, GemFire cache regions are configured as
 clients to regions in GemFire server caches running in a separate
 distributed system.
-The GemFire <a href="{@docRoot}/com/gemstone/gemfire/cache/server/package-summary.html#package_description">servers</a>
+The GemFire <a href="{@docRoot}/org/apache/geode/cache/server/package-summary.html#package_description">servers</a>
 are generally run as cacheserver processes.
-<a href="{@docRoot}/com/gemstone/gemfire/cache/client/package-summary.html#package_description">Clients</a>
+<a href="{@docRoot}/org/apache/geode/cache/client/package-summary.html#package_description">Clients</a>
 are configured with a
-{@linkplain com.gemstone.gemfire.cache.client.ClientCache client cache}
+{@linkplain org.apache.geode.cache.client.ClientCache client cache}
 which has a default
-{@linkplain com.gemstone.gemfire.cache.client.Pool pool}
+{@linkplain org.apache.geode.cache.client.Pool pool}
 that manages connections to the server caches
 which are used by the client regions.
 When a client updates its region, the update is forwarded to the server.
@@ -511,9 +511,9 @@ When a client get results in a local cache miss,
 the get request is forwarded to the server.
 The clients may also subscribe to server-side events.
 For more information on the client see the
-<a href="{@docRoot}/com/gemstone/gemfire/cache/client/package-summary.html#package_description">client</a>.
+<a href="{@docRoot}/org/apache/geode/cache/client/package-summary.html#package_description">client</a>.
 For more information on the server see the
-<a href="{@docRoot}/com/gemstone/gemfire/cache/server/package-summary.html#package_description">server</a>.</p>
+<a href="{@docRoot}/org/apache/geode/cache/server/package-summary.html#package_description">server</a>.</p>
 
 <a name="tx"><h2>Cache Transactions</h2><a href="#top">Back to Top</a>
 
@@ -561,45 +561,45 @@ one action reflecting the sum of all three.
 
 <p>The GemFire region can be configured to require the
 presence of one or more user-defined membership roles.  Each {@link
-com.gemstone.gemfire.distributed.Role} is assigned to any number of
+org.apache.geode.distributed.Role} is assigned to any number of
 applications when each application connects to the GemFire distributed
-system.  {@link com.gemstone.gemfire.cache.MembershipAttributes} are
+system.  {@link org.apache.geode.cache.MembershipAttributes} are
 then used to specify which {@linkplain
-com.gemstone.gemfire.cache.MembershipAttributes#getRequiredRoles roles
+org.apache.geode.cache.MembershipAttributes#getRequiredRoles roles
 are required} to be online and present in that region's membership
 for access to the cache region being configured.</p>
 
 <p>In addition to specifying which roles are required,
 <code>MembershipAttributes</code> are used to specify the {@link
-com.gemstone.gemfire.cache.LossAction}. The loss action determines how
+org.apache.geode.cache.LossAction}. The loss action determines how
 access to the region is affected when one or more required roles are
 offline and no longer present in the system membership. The region can be
 made completely {@linkplain
-com.gemstone.gemfire.cache.LossAction#NO_ACCESS "NO_ACCESS"},
+org.apache.geode.cache.LossAction#NO_ACCESS "NO_ACCESS"},
 which means that the application cannot read from or write to that region.
-{@linkplain com.gemstone.gemfire.cache.LossAction#LIMITED_ACCESS
+{@linkplain org.apache.geode.cache.LossAction#LIMITED_ACCESS
 "LIMITED_ACCESS"} means that the application cannot write to that region.
-{@linkplain com.gemstone.gemfire.cache.LossAction#FULL_ACCESS
+{@linkplain org.apache.geode.cache.LossAction#FULL_ACCESS
 "FULL_ACCESS"} means that the application can read from and write to that
 region as normal. If "FULL_ACCESS" is selected,
 then the application would only be aware of the missing required role if it
-registered a {@link com.gemstone.gemfire.cache.RegionRoleListener}.
+registered a {@link org.apache.geode.cache.RegionRoleListener}.
 This listener provides callbacks to notify the application when required
 roles are gained or lost, thus providing for custom integration of required
 roles with the application.</p>
 
-<p>{@link com.gemstone.gemfire.cache.ResumptionAction} defined in the
+<p>{@link org.apache.geode.cache.ResumptionAction} defined in the
 <code>MembershipAttributes</code> specifies how the application responds
 to having a missing required role return to the distributed membership.
-{@linkplain com.gemstone.gemfire.cache.ResumptionAction#NONE "None"}
+{@linkplain org.apache.geode.cache.ResumptionAction#NONE "None"}
 results in no special action, while {@linkplain
-com.gemstone.gemfire.cache.ResumptionAction#REINITIALIZE "Reinitialize"}
+org.apache.geode.cache.ResumptionAction#REINITIALIZE "Reinitialize"}
 causes the region to be reinitialized.  Reinitializing the region will
 clear all entries from that region.  If it is a replicate, the
 region will repopulate with entries available from other distributed
 members.</p>
 
-<p>{@link com.gemstone.gemfire.cache.RequiredRoles} provides methods to
+<p>{@link org.apache.geode.cache.RequiredRoles} provides methods to
 check for missing required roles for a region and to wait until all required
 roles are present. In addition, this class can be used to check if a role
 is currently present in a region's membership.</p>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListener.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListener.java
index 44696f6..9a9124c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListener.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.Region;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListenerAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListenerAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListenerAdapter.java
index f10f8ef..147de78 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListenerAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionListenerAdapter.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.Region;
 
 /**
  * <p>Utility class that implements all methods in <code>PartitionListener</code>
  * with empty implementations. Applications can subclass this class and only
  * override the methods of interest.<p>
  * 
- * <p>Subclasses declared in a Cache XML file, it must also implement {@link com.gemstone.gemfire.cache.Declarable}
+ * <p>Subclasses declared in a Cache XML file, it must also implement {@link org.apache.geode.cache.Declarable}
  * </p>
  * 
  * Note : Please request help on the Geode developer mailing list

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionMemberInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionMemberInfo.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionMemberInfo.java
index 1057d20..10e0536 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionMemberInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionMemberInfo.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Describes a member that has been configured to provide storage space for
@@ -38,7 +38,7 @@ public interface PartitionMemberInfo {
   
   /**
    * Returns the {@link 
-   * com.gemstone.gemfire.cache.PartitionAttributes#getLocalMaxMemory() max 
+   * org.apache.geode.cache.PartitionAttributes#getLocalMaxMemory() max 
    * memory} in bytes that the member was configured to provide for storage
    * of data for the partitioned region.
    * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionNotAvailableException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionNotAvailableException.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionNotAvailableException.java
index 395e9b4..a7c4a7b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionNotAvailableException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionNotAvailableException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * This exception is thrown when for the given fixed partition, datastore

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRebalanceInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRebalanceInfo.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRebalanceInfo.java
index 7b5f914..4e7d996 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRebalanceInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRebalanceInfo.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
 import java.util.Set;
 
@@ -27,7 +27,7 @@ import java.util.Set;
 public interface PartitionRebalanceInfo {
   
   /**
-   * Returns the {@link com.gemstone.gemfire.cache.Region#getFullPath() 
+   * Returns the {@link org.apache.geode.cache.Region#getFullPath() 
    * full path} of the partitioned region that these details describe.
    * 
    * @return the full name of partioned region that these details describe.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
index f3852a9..38f2622 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
 import java.util.Collections;
 import java.util.HashSet;
@@ -23,31 +23,31 @@ import java.util.Map;
 import java.util.Set;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.PartitionAttributes;
-import com.gemstone.gemfire.cache.PartitionAttributesFactory;
-import com.gemstone.gemfire.cache.PartitionResolver;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.control.RebalanceResults;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.cache.ColocationHelper;
-import com.gemstone.gemfire.internal.cache.FixedPartitionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalDataSet;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.RecoveryLock;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.cache.control.RebalanceResultsImpl;
-import com.gemstone.gemfire.internal.cache.execute.InternalRegionFunctionContext;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionRebalanceOp;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.ExplicitMoveDirector;
-import com.gemstone.gemfire.internal.cache.partitioned.rebalance.PercentageMoveDirector;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.PartitionAttributes;
+import org.apache.geode.cache.PartitionAttributesFactory;
+import org.apache.geode.cache.PartitionResolver;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.control.RebalanceResults;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.RegionFunctionContext;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.cache.ColocationHelper;
+import org.apache.geode.internal.cache.FixedPartitionAttributesImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalDataSet;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegion.RecoveryLock;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.cache.control.RebalanceResultsImpl;
+import org.apache.geode.internal.cache.execute.InternalRegionFunctionContext;
+import org.apache.geode.internal.cache.partitioned.PartitionedRegionRebalanceOp;
+import org.apache.geode.internal.cache.partitioned.rebalance.ExplicitMoveDirector;
+import org.apache.geode.internal.cache.partitioned.rebalance.PercentageMoveDirector;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Utility methods for handling partitioned Regions, for example

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionInfo.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionInfo.java
index 223e5cd..406fba1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionInfo.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.partition;
+package org.apache.geode.cache.partition;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.control.ResourceManager;
+import org.apache.geode.cache.control.ResourceManager;
 
 /**
  * Information describing the data storage and distribution of a 
@@ -34,7 +34,7 @@ import com.gemstone.gemfire.cache.control.ResourceManager;
 public interface PartitionRegionInfo {
 
   /**
-   * Returns the {@link com.gemstone.gemfire.cache.Region#getFullPath() 
+   * Returns the {@link org.apache.geode.cache.Region#getFullPath() 
    * full path} of the partitioned region that this object describes.
    * 
    * @return the full path of the partitioned region that this info describes
@@ -52,7 +52,7 @@ public interface PartitionRegionInfo {
   
   /**
    * Returns the {@link 
-   * com.gemstone.gemfire.cache.PartitionAttributes#getTotalNumBuckets()
+   * org.apache.geode.cache.PartitionAttributes#getTotalNumBuckets()
    * configured number of buckets} for the partitioned region.
    * 
    * @return the configured number of buckets
@@ -81,7 +81,7 @@ public interface PartitionRegionInfo {
   
   /**
    * Returns the number of {@link 
-   * com.gemstone.gemfire.cache.PartitionAttributes#getRedundantCopies()
+   * org.apache.geode.cache.PartitionAttributes#getRedundantCopies()
    * redundant copies} the partitioned region was configured for.
    * 
    * @return the number of redundant copies the partitioned region was 
@@ -101,9 +101,9 @@ public interface PartitionRegionInfo {
   public int getActualRedundantCopies();
   
   /**
-   * Returns the {@link com.gemstone.gemfire.cache.Region#getFullPath() 
+   * Returns the {@link org.apache.geode.cache.Region#getFullPath() 
    * full path} of the partitioned region that this region has been configured 
-   * to be {@link com.gemstone.gemfire.cache.PartitionAttributes#getColocatedWith() 
+   * to be {@link org.apache.geode.cache.PartitionAttributes#getColocatedWith() 
    * colocated with} or null if it is not colocated.
    * 
    * @return the full path of the partitioned region that the region is 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/ConflictingPersistentDataException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/ConflictingPersistentDataException.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/ConflictingPersistentDataException.java
index f65ffc8..26f16ec 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/ConflictingPersistentDataException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/ConflictingPersistentDataException.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
+import org.apache.geode.GemFireException;
+import org.apache.geode.admin.AdminDistributedSystem;
 
 /**
  * Thrown when a member with persistence is recovering, and it discovers that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/PartitionOfflineException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/PartitionOfflineException.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/PartitionOfflineException.java
index 20d2a50..fe30bce 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/PartitionOfflineException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/PartitionOfflineException.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Thrown when a paritioned region is configured for disk persistence,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentID.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentID.java
index d0169dc..256e208 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentID.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentID.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
 import java.net.InetAddress;
 import java.util.UUID;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.cache.DataPolicy;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.admin.AdminDistributedSystem;
+import org.apache.geode.cache.DataPolicy;
 
 /**
  * A pattern describing a single member's a set of persistent files for a region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentReplicatesOfflineException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentReplicatesOfflineException.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentReplicatesOfflineException.java
index f53ecb1..a51c979 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentReplicatesOfflineException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/PersistentReplicatesOfflineException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Thrown when a replicated region is configured for persistence

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokeFailedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokeFailedException.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokeFailedException.java
index 5d3bcde..88fbf81 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokeFailedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokeFailedException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Thrown when a member tries to revoke a persistent ID, but the member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokedPersistentDataException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokedPersistentDataException.java b/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokedPersistentDataException.java
index e9b0d11..35a8ea5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokedPersistentDataException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/persistence/RevokedPersistentDataException.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.persistence;
+package org.apache.geode.cache.persistence;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
+import org.apache.geode.GemFireException;
+import org.apache.geode.admin.AdminDistributedSystem;
 
 /**
  * Thrown when a member with persistence is recovering, and it discovers that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java b/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
index 6991e53..d4dba92 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Behavior of a user-defined aggregator. Aggregates values and returns a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/AmbiguousNameException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/AmbiguousNameException.java b/geode-core/src/main/java/org/apache/geode/cache/query/AmbiguousNameException.java
index 3e54278..5715e9e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/AmbiguousNameException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/AmbiguousNameException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if an attribute or method name in a query can be resolved to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributes.java
index 7a70d61..fff4a33 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributes.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /** 
  * This interface holds all attribute values for a CQ and provides methods for 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesFactory.java
index 1e0c88a..d47250e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesFactory.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.List;
 
-import com.gemstone.gemfire.cache.query.internal.cq.CqAttributesImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.internal.cq.CqAttributesImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * The factory class for the CqAttributes instance. This provides the CqListener 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesMutator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesMutator.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesMutator.java
index 05f64e4..40969f6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesMutator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqAttributesMutator.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * This interface is used to modify the listeners that are associated with a CQ. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqClosedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqClosedException.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqClosedException.java
index 3adb761..2e5f25d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqClosedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqClosedException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheRuntimeException;
 
 /**
  * Thrown if the CqQuery on which the operation performed is closed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqEvent.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqEvent.java
index dccb383..57e83d4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqEvent.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.Operation;
+import org.apache.geode.cache.Operation;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqException.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqException.java
index 0f0f2fd..c02c71a 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown during continuous query creation, execution time.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqExistsException.java
index 66ffd08..31774cb 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqExistsException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if a CQ by this name already exists on this client 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqListener.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqListener.java
index b68d976..7b0a8d3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqListener.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 /**
  * Application plug-in interface for handling continuous query events after 
@@ -43,7 +43,7 @@ public interface CqListener extends CacheCallback {
    * operation and CQ registration to avoid duplicate event being 
    * delivered.   
    * 
-   * @see com.gemstone.gemfire.cache.query.CqQuery#executeWithInitialResults
+   * @see org.apache.geode.cache.query.CqQuery#executeWithInitialResults
    */
   public void onEvent(CqEvent aCqEvent);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqQuery.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqQuery.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqQuery.java
index 691a7d0..5282706 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqQuery.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqQuery.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqResults.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqResults.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqResults.java
index f11e4e5..80a5f96 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqResults.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Represents the results of a CQ query that is executed using 
- * {@linkplain com.gemstone.gemfire.cache.query.CqQuery#executeWithInitialResults()}
+ * {@linkplain org.apache.geode.cache.query.CqQuery#executeWithInitialResults()}
  * The result will contain the instances of {@link Struct} having key and value 
  * of the region entry that satisfy the CQ query condition.
  * <pre>
@@ -41,8 +41,8 @@ package com.gemstone.gemfire.cache.query;
  *
  * </pre>
  * 
- * @see com.gemstone.gemfire.cache.query.Query#execute()
- * @see com.gemstone.gemfire.cache.query.CqQuery#executeWithInitialResults()
+ * @see org.apache.geode.cache.query.Query#execute()
+ * @see org.apache.geode.cache.query.CqQuery#executeWithInitialResults()
  * 
  * @since GemFire 6.5
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
index b1477f2..533eb9c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * This class provides methods to get aggregate statistical information 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqState.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqState.java
index 0ade80d..fa900de 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqState.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqState.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * This interface gives information on the state of a CqQuery. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqStatistics.java
index 1189179..a0128e5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * This class provides methods to get statistical information about a registered Continuous Query (CQ)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/CqStatusListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqStatusListener.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqStatusListener.java
index 0f1e372..35a6a90 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqStatusListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqStatusListener.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/FunctionDomainException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/FunctionDomainException.java b/geode-core/src/main/java/org/apache/geode/cache/query/FunctionDomainException.java
index d6fe92d..3a1379b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/FunctionDomainException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/FunctionDomainException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if the domain of a function is not legal.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/Index.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/Index.java b/geode-core/src/main/java/org/apache/geode/cache/query/Index.java
index 56593f4..f4f4c21 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/Index.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/Index.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 //import java.util.*;
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  * An index that is built over the data stored in a GemFire {@link

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexCreationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexCreationException.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexCreationException.java
index 75613e8..88bdee6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexCreationException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexCreationException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 /**
  * This class is used to represent any partitioned index creation exceptions.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexExistsException.java
index 5a0c317..2fe9d83 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexExistsException.java
@@ -20,7 +20,7 @@
  * Created on February 15, 2005, 10:20 AM
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown while creating the new index if there exists an Index with

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexInvalidException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexInvalidException.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexInvalidException.java
index 0426cd1..1f246a9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexInvalidException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexInvalidException.java
@@ -20,9 +20,9 @@
  * Created on March 16, 2005, 7:40 PM
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Thrown if the index definition is not valid.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexMaintenanceException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexMaintenanceException.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexMaintenanceException.java
index 3dda5b4..44f71d0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexMaintenanceException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexMaintenanceException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheRuntimeException;
 /**
  * Thrown if an error occurs while updating query indexes during
  * region modification.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexNameConflictException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexNameConflictException.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexNameConflictException.java
index a4b13ed..5e6264b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexNameConflictException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexNameConflictException.java
@@ -20,7 +20,7 @@
  * Created on February 15, 2005, 10:20 AM
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown while creating the new index if there exists an Index with

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexStatistics.java
index 1148b61..5cfd1c5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexStatistics.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/IndexType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/IndexType.java b/geode-core/src/main/java/org/apache/geode/cache/query/IndexType.java
index 362de5a..be62f13 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/IndexType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/IndexType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * @deprecated As of 6.6.1. Check {@link QueryService} for changes.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/MultiIndexCreationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/MultiIndexCreationException.java b/geode-core/src/main/java/org/apache/geode/cache/query/MultiIndexCreationException.java
index 42563fc..92a1d05 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/MultiIndexCreationException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/MultiIndexCreationException.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 import java.util.HashMap;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.internal.DefaultQueryService;
+import org.apache.geode.cache.query.internal.DefaultQueryService;
 
 /**
  * Consists a map of index names and Exceptions thrown during index creation

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/NameNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/NameNotFoundException.java b/geode-core/src/main/java/org/apache/geode/cache/query/NameNotFoundException.java
index aad2ec3..a65d1c6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/NameNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/NameNotFoundException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/NameResolutionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/NameResolutionException.java b/geode-core/src/main/java/org/apache/geode/cache/query/NameResolutionException.java
index ffb5c16..c02a2a3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/NameResolutionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/NameResolutionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if an attribute or method name in a query cannot be resolved.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/ParameterCountInvalidException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/ParameterCountInvalidException.java b/geode-core/src/main/java/org/apache/geode/cache/query/ParameterCountInvalidException.java
index c91dceb..91600c2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/ParameterCountInvalidException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/ParameterCountInvalidException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown when the number of bound paramters for a query does not match the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/Query.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/Query.java b/geode-core/src/main/java/org/apache/geode/cache/query/Query.java
index fdd71b0..e27687d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/Query.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/Query.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.RegionFunctionContext;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.RegionFunctionContext;
 
 /**
  * Interface for query objects. Supports execution of queries with optional

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryException.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryException.java
index 3ddd320..db7faa8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * Thrown during by the query engine during parsing or execution.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionLowMemoryException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionLowMemoryException.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionLowMemoryException.java
index c0ba18d..0c57ea6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionLowMemoryException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionLowMemoryException.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.control.ResourceManager;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.control.ResourceManager;
 /**
  * Thrown when the query is executing and the critical heap percentage is met.
  * @see ResourceManager#setCriticalHeapPercentage(float)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionTimeoutException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionTimeoutException.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionTimeoutException.java
index a8689bb..01c3645 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionTimeoutException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryExecutionTimeoutException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
+import org.apache.geode.cache.CacheRuntimeException;
 /**
  * Thrown when the query execution takes more than the specified max time.
  * The Max query execution time is set using the system  variable 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvalidException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvalidException.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvalidException.java
index 0f6116e..ba3b0e4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvalidException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvalidException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Thrown if the query language syntax is not valid.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvocationTargetException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvocationTargetException.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvocationTargetException.java
index 47aea3c..1bff735 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvocationTargetException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryInvocationTargetException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if an exception is thrown when a method is invoked during query execution.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
index 28646a4..badca42 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.internal.Undefined;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.internal.Undefined;
 
 /**
  * Interface for the query service, which is used for instantiating queries, 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/QueryStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryStatistics.java
index c305573..b0f1275 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryStatistics.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Provides statistical information about a query performed on a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/RegionNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/RegionNotFoundException.java b/geode-core/src/main/java/org/apache/geode/cache/query/RegionNotFoundException.java
index a52f54c..22d2376 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/RegionNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/RegionNotFoundException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if a region referenced by name in a query cannot be found.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java b/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
index b7359e6..1b8d9a4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.types.*;
+import org.apache.geode.cache.query.types.*;
 
 /**
- * Contains the results of a {@linkplain com.gemstone.gemfire.cache.query.Query#execute() executing} a
+ * Contains the results of a {@linkplain org.apache.geode.cache.query.Query#execute() executing} a
  * <code>SELECT</code> expression within a query. A <code>SELECT</code>
  * expression results in <code>SelectResults</code> that contain instances of
  * {@link Struct} if: (a) there is more than one projection in the projection
@@ -60,7 +60,7 @@ import com.gemstone.gemfire.cache.query.types.*;
  *
  * </pre>
  *
- * @see com.gemstone.gemfire.cache.query.Query#execute()
+ * @see org.apache.geode.cache.query.Query#execute()
  *
  * @since GemFire 4.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/Struct.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/Struct.java b/geode-core/src/main/java/org/apache/geode/cache/query/Struct.java
index 8ff6a15..493ab41 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/Struct.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/Struct.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 //import java.util.*;
-import com.gemstone.gemfire.cache.query.types.StructType;
+import org.apache.geode.cache.query.types.StructType;
 
 /**
  * An immutable and thread-safe data type used by the result of some

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/TypeMismatchException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/TypeMismatchException.java b/geode-core/src/main/java/org/apache/geode/cache/query/TypeMismatchException.java
index 6c6e0aa..90a3646 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/TypeMismatchException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/TypeMismatchException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query;
+package org.apache.geode.cache.query;
 
 /**
  * Thrown if type consistency is violated while a query is being executed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
index b6136dc..2388545 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractCompiledValue.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
-//import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
+//import org.apache.geode.cache.query.internal.types.TypeUtils;
 /**
  * Class Description
  * 



[21/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleDisconnectMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleDisconnectMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleDisconnectMessage.java
index a1d3680..057432f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleDisconnectMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleDisconnectMessage.java
@@ -16,7 +16,7 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,15 +24,15 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A message that is sent to a particular distribution manager to let

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleMessage.java
index cba8313..d963670 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminConsoleMessage.java
@@ -16,7 +16,7 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,13 +24,13 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.ManagerLogWriter;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.admin.Alert;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.ManagerLogWriter;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LogWriterLogger;
 
 /**
  * A message that is sent to a particular distribution manager to let

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminFailureResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminFailureResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminFailureResponse.java
index a50ff60..36301b8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminFailureResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminFailureResponse.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A response to a failed request.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminMultipleReplyProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminMultipleReplyProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminMultipleReplyProcessor.java
index cb56f27..7a8f916 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminMultipleReplyProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminMultipleReplyProcessor.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.util.Collection;
 
-import com.gemstone.gemfire.CancelCriterion;
-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.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRegion.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRegion.java
index 982bd55..88786e4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRegion.java
@@ -16,19 +16,19 @@
  */
 
 
-package com.gemstone.gemfire.internal.admin.remote;
-
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.snapshot.RegionSnapshotService;
-import com.gemstone.gemfire.internal.cache.snapshot.RegionSnapshotServiceImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-//import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.util.*;
+package org.apache.geode.internal.admin.remote;
+
+//import org.apache.geode.*;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.snapshot.RegionSnapshotService;
+import org.apache.geode.internal.cache.snapshot.RegionSnapshotServiceImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+//import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.util.*;
 
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminReplyProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminReplyProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminReplyProcessor.java
index 7624dc9..3f64f16 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminReplyProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminReplyProcessor.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A <code>ReplyProcessor</code> that is used by an {@link
  * AdminRequest} to wait for an {@link AdminResponse}.  If 
- * {@link com.gemstone.gemfire.distributed.internal.ReplyProcessor21#waitForReplies()} 
+ * {@link org.apache.geode.distributed.internal.ReplyProcessor21#waitForReplies()} 
  * returns saying that we didn't time out and there
  * is no response, it means that the member for which we were awaiting
  * a response has left the distributed system.  This helps us fix bug

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRequest.java
index 6e7db0e..bda0fc1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminRequest.java
@@ -16,26 +16,26 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
-//import com.gemstone.gemfire.internal.*;
+//import org.apache.geode.internal.*;
 import java.io.DataOutput;
 import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
 //import java.util.*;
 //import java.net.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A message that is sent to a particular distribution manager to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminResponse.java
index 692deed..d0ae242 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminResponse.java
@@ -16,15 +16,15 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A message that is sent as a reply to a {@link AdminRequest}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminWaiters.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminWaiters.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminWaiters.java
index eae45cd..8d1c6ed 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminWaiters.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AdminWaiters.java
@@ -16,20 +16,20 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.OperationCancelledException;
-import com.gemstone.gemfire.admin.RuntimeAdminException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.admin.OperationCancelledException;
+import org.apache.geode.admin.RuntimeAdminException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Used by {@link AdminRequest} to wait for a {@link AdminResponse}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertLevelChangeMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertLevelChangeMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertLevelChangeMessage.java
index 7047079..ae61950 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertLevelChangeMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertLevelChangeMessage.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.AlertLevel;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.admin.AlertLevel;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.admin.Alert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message that is sent to make members of the distributed system

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertListenerMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertListenerMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertListenerMessage.java
index 5892d35..37e81bc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertListenerMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertListenerMessage.java
@@ -16,18 +16,18 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.AlertLevel;
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.management.internal.AlertDetails;
+import org.apache.geode.*;
+import org.apache.geode.admin.AlertLevel;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.management.internal.AlertDetails;
 
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent to a particular console distribution manager

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertsNotificationMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertsNotificationMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertsNotificationMessage.java
index 44b020d..7f8a7e9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertsNotificationMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AlertsNotificationMessage.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.admin.jmx.internal.StatAlertsAggregator;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.admin.StatAlert;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.admin.jmx.internal.StatAlertsAggregator;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.admin.StatAlert;
 
 /**
  * Distribution message to be sent to alert aggregator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AppCacheSnapshotMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AppCacheSnapshotMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AppCacheSnapshotMessage.java
index b1c6aec..c1b70d3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AppCacheSnapshotMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AppCacheSnapshotMessage.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.cache.*;
+import org.apache.geode.*;
 //import java.util.*;
 
 public final class AppCacheSnapshotMessage extends RegionAdminMessage {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerRequest.java
index b19d91c..8e3098d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerRequest.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.admin.CacheInfo;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.admin.CacheInfo;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerResponse.java
index f9e5258..0198278 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/BridgeServerResponse.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.CacheServerImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 import java.io.*;
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigRequest.java
index 0e9c4df..7653900 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigRequest.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 //import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigResponse.java
index 3933e44..c95722b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheConfigResponse.java
@@ -16,18 +16,18 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.*;
 import java.io.*;
 //import java.net.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent in response to a {@link CacheConfigRequest}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheDisplay.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheDisplay.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheDisplay.java
index a82e0ab..8a0ff5a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheDisplay.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheDisplay.java
@@ -16,11 +16,11 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.admin.GemFireVM;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public final class CacheDisplay {
   public static Object getCachedObjectDisplay(Object obj, int inspectionType) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoRequest.java
index 66fb5cb..215f48f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoResponse.java
index 354c2e9..b29e656 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CacheInfoResponse.java
@@ -16,18 +16,18 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.*;
 import java.io.*;
 //import java.net.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent in response to a {@link CacheInfoRequest}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerRequest.java
index 73aff24..1c6007b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerResponse.java
index a223524..319a501 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancelStatListenerResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
 
 /**
  * A message that is sent to a particular distribution manager to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/Cancellable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/Cancellable.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/Cancellable.java
index 447e1f6..c8db2f1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/Cancellable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/Cancellable.java
@@ -16,7 +16,7 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 /**
  * This interface is implemented by AdminMessages that want

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationMessage.java
index 5364eb7..738b215 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationMessage.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A message that is sent to a particular distribution manager to cancel an

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationRegistry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationRegistry.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationRegistry.java
index 9af7442..6ddc109 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationRegistry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CancellationRegistry.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This class provides a way for a {@link CancellationMessage} to find its prey.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ChangeRefreshIntervalMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ChangeRefreshIntervalMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ChangeRefreshIntervalMessage.java
index 77662a6..f9eb1fe 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ChangeRefreshIntervalMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ChangeRefreshIntervalMessage.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.internal.admin.StatAlertsManager;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.internal.admin.StatAlertsManager;
 
 /**
  * Distribution message, sets refresh time interval in member's alerts manager

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CliLegacyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CliLegacyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CliLegacyMessage.java
index 2018d71..fa58100 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CliLegacyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CliLegacyMessage.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ClientHealthStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ClientHealthStats.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ClientHealthStats.java
index 64d5632..e91c3e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ClientHealthStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ClientHealthStats.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,10 +24,10 @@ import java.util.Date;
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.Map.Entry;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.management.internal.beans.CacheServerBridge;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.management.internal.beans.CacheServerBridge;
+import org.apache.geode.DataSerializer;
 
 /**
  * Bean class act as container for client stats

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactRequest.java
index fdbaaa8..49ef1b7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,16 +26,16 @@ import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.util.ArrayUtils;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.cache.DiskStoreImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.util.ArrayUtils;
 
 /**
  * An instruction to all members with cache that they should 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactResponse.java
index 9115d2c..24d5ee8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/CompactResponse.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.HashSet;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyEntryMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyEntryMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyEntryMessage.java
index c618ba7..e904f80 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyEntryMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyEntryMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,15 +24,15 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.ExpirationAction;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.ExpirationAction;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A message that is sent to a particular distribution manager to let

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyRegionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyRegionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyRegionMessage.java
index 694c8a2..b376af6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyRegionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DestroyRegionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,15 +23,15 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.ExpirationAction;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.ExpirationAction;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 //import java.util.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DistributionLocatorId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DistributionLocatorId.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DistributionLocatorId.java
index 60d740a..d4e8519 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DistributionLocatorId.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DistributionLocatorId.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.SSLConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.SSLConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.net.InetAddress;
 import java.net.UnknownHostException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DummyEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DummyEntry.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DummyEntry.java
index 258f66b..830a2f7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DummyEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DummyEntry.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
- * This implementation of {@link com.gemstone.gemfire.cache.Region.Entry}
- * does nothing but provide an instance of {@link com.gemstone.gemfire.cache.CacheStatistics}
+ * This implementation of {@link org.apache.geode.cache.Region.Entry}
+ * does nothing but provide an instance of {@link org.apache.geode.cache.CacheStatistics}
  */
 public class DummyEntry implements Region.Entry {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoRequest.java
index 76efe96..2b10f9b 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoRequest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.*; // import
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.*; // import
 import java.io.*;
 
 /**
@@ -86,7 +86,7 @@ public class DurableClientInfoRequest extends AdminRequest
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return DURABLE_CLIENT_INFO_REQUEST;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoResponse.java
index 273dff5..1921cc9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/DurableClientInfoResponse.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-// import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*; // import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.cache.*;
+// import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*; // import org.apache.geode.internal.*;
+import org.apache.geode.internal.cache.*;
 
 import java.io.*; // import java.net.*;
 // import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent in response to a {@link DurableClientInfoRequest}.
@@ -100,7 +100,7 @@ public class DurableClientInfoResponse extends AdminResponse
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return DURABLE_CLIENT_INFO_RESPONSE;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/EntryValueNodeImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/EntryValueNodeImpl.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/EntryValueNodeImpl.java
index ab3d8be..f39448f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/EntryValueNodeImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/EntryValueNodeImpl.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.lang.reflect.*;
 import java.io.*;
@@ -30,7 +30,7 @@ import java.util.*;
  * stored in the cache.  They are built during construction of {@link
  * ObjectDetailsResponse} instances and returned to the console. This
  * class does not implement {@link
- * com.gemstone.gemfire.DataSerializable} since that
+ * org.apache.geode.DataSerializable} since that
  * mechanism gets confused by the often cyclical refrences between
  * instances of this class.
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoRequest.java
index da01381..b334205 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoResponse.java
index 151691b..2bd7f5e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchDistLockInfoResponse.java
@@ -16,17 +16,17 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.locks.*;
+import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.locks.*;
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 public final class FetchDistLockInfoResponse extends AdminResponse {
   // instance variables

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisRequest.java
index 22ee035..cbbc71a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealth;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealth;
 import java.io.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisResponse.java
index 19590ae..bac76c7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHealthDiagnosisResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealth;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealth;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * The response to fetching the health diagnosis.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostRequest.java
index 896e682..6f9bfa3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostRequest.java
@@ -16,10 +16,10 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostResponse.java
index a9712be..3ff7269 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchHostResponse.java
@@ -16,17 +16,17 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.CacheServerLauncher;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.internal.admin.remote;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.CacheServerLauncher;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -41,7 +41,7 @@ import java.net.UnknownHostException;
 
 /**
  * A message that is sent to a particular distribution manager to
- * get its current {@link com.gemstone.gemfire.internal.Config}
+ * get its current {@link org.apache.geode.internal.Config}
  */
 public final class FetchHostResponse extends AdminResponse {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesRequest.java
index f1895b0..c750d58 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesResponse.java
index 2507557..fd7aa1c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchResourceAttributesResponse.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
 import java.io.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 public final class FetchResourceAttributesResponse extends AdminResponse {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsRequest.java
index c43aac1..8053e15 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsResponse.java
index 1932857..e9a44d8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchStatsResponse.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.StatisticsVisitor;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Statistics;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.StatisticsVisitor;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,7 +28,7 @@ import java.util.ArrayList;
 import java.util.ConcurrentModificationException;
 import java.util.Iterator;
 import java.util.List;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Provides a response of remote statistic resources for a 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgRequest.java
index 5f9db76..ac1b14c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgRequest.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 
 /**
  * A message that is sent to a particular distribution manager to
- * get its current {@link com.gemstone.gemfire.internal.Config}.
+ * get its current {@link org.apache.geode.internal.Config}.
  */
 public final class FetchSysCfgRequest extends AdminRequest {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgResponse.java
index 0b94598..4d65e42 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FetchSysCfgResponse.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent to a particular distribution manager to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FlushAppCacheSnapshotMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FlushAppCacheSnapshotMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FlushAppCacheSnapshotMessage.java
index 828c74b..f5fa3c0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FlushAppCacheSnapshotMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/FlushAppCacheSnapshotMessage.java
@@ -16,11 +16,11 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/HealthListenerMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/HealthListenerMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/HealthListenerMessage.java
index fd34fa3..cb0d7b7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/HealthListenerMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/HealthListenerMessage.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealth;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealth;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/InspectionClasspathManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/InspectionClasspathManager.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/InspectionClasspathManager.java
index 41f853c..c1f3ac6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/InspectionClasspathManager.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/InspectionClasspathManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.IOException;
 import java.net.MalformedURLException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoRequest.java
index b218b6e..aff33cc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoResponse.java
index a17c785..9cbf5de 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/LicenseInfoResponse.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsRequest.java
index 0724464..1e3c521 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.IOException;
@@ -24,18 +24,18 @@ import java.util.Map;
 import java.util.Set;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
 
 /**
  * A request to all members for any persistent members that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsResponse.java
index bb58753..9cbbcea 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/MissingPersistentIDsResponse.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,12 +22,12 @@ import java.io.IOException;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
 
 /**
  * The MissingPersistentIdResonse we return 662 peers. This response

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsRequest.java
index baa125b..936af44 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsRequest.java
@@ -16,12 +16,12 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsResponse.java
index ad781c7..686a4f8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/ObjectDetailsResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Responds to {@link ObjectDetailsRequest}.



[29/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
index 2ed3ea6..b8620e2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 /**
  * Callback for users to filter out events before dispatching to remote

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventSubstitutionFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventSubstitutionFilter.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventSubstitutionFilter.java
index 7e37310..0ec894a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventSubstitutionFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventSubstitutionFilter.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.cache.CacheCallback;
-import com.gemstone.gemfire.cache.EntryEvent;
+import org.apache.geode.cache.CacheCallback;
+import org.apache.geode.cache.EntryEvent;
 
 /**
  * Interface <code>GatewayEventSubstitutionFilter</code> provides a way to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayQueueEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayQueueEvent.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayQueueEvent.java
index 07d92c9..8d9a8aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayQueueEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayQueueEvent.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.asyncqueue.AsyncEventListener;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.asyncqueue.AsyncEventListener;
 
 /**
  * Represents <code>Cache</code> events going through 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiver.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiver.java
index a80fbd4..55021d1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiver.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.io.IOException;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
index 38e0316..4a6a7a8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
index 04dc248..0b4c113 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
index 4ecf8ae..ec38f5c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
-import com.gemstone.gemfire.cache.wan.GatewaySender.OrderPolicy;
+import org.apache.geode.cache.wan.GatewaySender.OrderPolicy;
 
 /**
  * Factory to create SerialGatewaySender

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayTransportFilter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayTransportFilter.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayTransportFilter.java
index db76ba5..16dee89 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayTransportFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayTransportFilter.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.wan;
+package org.apache.geode.cache.wan;
 
 import java.io.InputStream;
 import java.io.OutputStream;
 
-import com.gemstone.gemfire.cache.CacheCallback;
+import org.apache.geode.cache.CacheCallback;
 
 public interface GatewayTransportFilter extends CacheCallback {
   public InputStream  getInputStream(InputStream stream);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/compression/CompressionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/compression/CompressionException.java b/geode-core/src/main/java/org/apache/geode/compression/CompressionException.java
index 0e3c26b..ebcc9c7 100644
--- a/geode-core/src/main/java/org/apache/geode/compression/CompressionException.java
+++ b/geode-core/src/main/java/org/apache/geode/compression/CompressionException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.compression;
+package org.apache.geode.compression;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * Wraps specific compression errors for {@link Compressor

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/compression/Compressor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/compression/Compressor.java b/geode-core/src/main/java/org/apache/geode/compression/Compressor.java
index ee06220..b50839e 100644
--- a/geode-core/src/main/java/org/apache/geode/compression/Compressor.java
+++ b/geode-core/src/main/java/org/apache/geode/compression/Compressor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.compression;
+package org.apache.geode.compression;
 
 /**
  * Interface for a compression codec.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/compression/SnappyCompressor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/compression/SnappyCompressor.java b/geode-core/src/main/java/org/apache/geode/compression/SnappyCompressor.java
index 63ec29d..0c601d2 100644
--- a/geode-core/src/main/java/org/apache/geode/compression/SnappyCompressor.java
+++ b/geode-core/src/main/java/org/apache/geode/compression/SnappyCompressor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.compression;
+package org.apache.geode.compression;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/AbstractLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/AbstractLauncher.java b/geode-core/src/main/java/org/apache/geode/distributed/AbstractLauncher.java
index 77e360b..110721f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/AbstractLauncher.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/AbstractLauncher.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
-
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.unsafe.RegisterSignalHandlerSupport;
-import com.gemstone.gemfire.internal.AvailablePort;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.ClassUtils;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.process.PidUnavailableException;
-import com.gemstone.gemfire.internal.process.ProcessUtils;
-import com.gemstone.gemfire.internal.util.SunAPINotFoundException;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonObject;
+package org.apache.geode.distributed;
+
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.unsafe.RegisterSignalHandlerSupport;
+import org.apache.geode.internal.AvailablePort;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.ClassUtils;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.process.PidUnavailableException;
+import org.apache.geode.internal.process.ProcessUtils;
+import org.apache.geode.internal.util.SunAPINotFoundException;
+import org.apache.geode.management.internal.cli.json.GfJsonObject;
 
 import java.io.*;
 import java.net.BindException;
@@ -46,7 +46,7 @@ import java.util.logging.FileHandler;
 import java.util.logging.Level;
 import java.util.logging.Logger;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * The AbstractLauncher class is a base class for implementing various launchers to construct and run different GemFire
@@ -54,7 +54,7 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
  * 
  * @see java.lang.Comparable
  * @see java.lang.Runnable
- * @see com.gemstone.gemfire.lang.Identifiable
+ * @see org.apache.geode.lang.Identifiable
  * @since GemFire 7.0
  */
 public abstract class AbstractLauncher<T extends Comparable<T>> implements Runnable {
@@ -120,7 +120,7 @@ public abstract class AbstractLauncher<T extends Comparable<T>> implements Runna
    * @param port an integer indicating the network port to listen for client network requests.
    * @throws BindException if the network address and port are not available.  Address defaults to localhost (or all
    * network interfaces on the local system) if null.
-   * @see com.gemstone.gemfire.internal.AvailablePort
+   * @see org.apache.geode.internal.AvailablePort
    */
   protected static void assertPortAvailable(final InetAddress bindAddress, final int port) throws BindException {
     if (!AvailablePort.isPortAvailable(port, AvailablePort.SOCKET, bindAddress)) {
@@ -714,7 +714,7 @@ public abstract class AbstractLauncher<T extends Comparable<T>> implements Runna
      * Gets the state of the GemFire service.
      * 
      * @return a Status enumerated type representing the state of the GemFire service.
-     * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status
+     * @see org.apache.geode.distributed.AbstractLauncher.Status
      */
     public Status getStatus() {
       return status;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/ClientSocketFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/ClientSocketFactory.java b/geode-core/src/main/java/org/apache/geode/distributed/ClientSocketFactory.java
index 906339a..6a0e30f 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/ClientSocketFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/ClientSocketFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import java.io.IOException;
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java b/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
index e02f470..385dca4 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import org.apache.geode.redis.GeodeRedisServer;
 import org.apache.geode.security.SecurableComponents;
@@ -141,7 +141,7 @@ public interface ConfigurationProperties {
    * <a name="cache-xml-file"/a></p>
    * <U>Description</U>: Specifies the name of the XML file or resource
    * to initialize the cache with when it is
-   * {@linkplain com.gemstone.gemfire.cache.CacheFactory#create created}.
+   * {@linkplain org.apache.geode.cache.CacheFactory#create created}.
    * Create will first look for a file that matches the value of this property.
    * If a file is not found then it will be searched for using
    * {@link java.lang.ClassLoader#getResource}.  If the value of this
@@ -288,7 +288,7 @@ public interface ConfigurationProperties {
    * <dt>delta-propagation</dt>
    * </a>
    * <U>Description</U>: "true" indicates that server propagates delta
-   * generated from {@link com.gemstone.gemfire.Delta} type of objects. If "false"
+   * generated from {@link org.apache.geode.Delta} type of objects. If "false"
    * then server propagates full object but not delta. </p>
    * <U>Default</U>: "true"</p>
    * <U>Allowed values</U>: true|false
@@ -1065,16 +1065,16 @@ public interface ConfigurationProperties {
   /**
    * The static String definition of the <i>"memcached-bind-address"</i> property
    * <a name="memcached-bind-address"/a></p>
-   * <U>Description</U>: Specifies the bind address used by {@link com.gemstone.gemfire.memcached.GemFireMemcachedServer}</p>
+   * <U>Description</U>: Specifies the bind address used by {@link org.apache.geode.memcached.GemFireMemcachedServer}</p>
    * <U>Default</U>: ""
    */
   String MEMCACHED_BIND_ADDRESS = "memcached-bind-address";
   /**
    * The static String definition of the <i>"memcached-port"</i> property
    * <a name="memcached-port"/a></p>
-   * <U>Description</U>: Specifies the port used by {@link com.gemstone.gemfire.memcached.GemFireMemcachedServer}
+   * <U>Description</U>: Specifies the port used by {@link org.apache.geode.memcached.GemFireMemcachedServer}
    * which enables memcached clients to connect and store data in GemFire distributed system.
-   * see {@link com.gemstone.gemfire.memcached.GemFireMemcachedServer} for other configuration options.</p>
+   * see {@link org.apache.geode.memcached.GemFireMemcachedServer} for other configuration options.</p>
    * <U>Default</U>: "0" disables GemFireMemcachedServer</p>
    * <U>Allowed values</U>: 0..65535
    */
@@ -1082,7 +1082,7 @@ public interface ConfigurationProperties {
   /**
    * The static String definition of the <i>"memcached-protocol"</i> property
    * <a name="memcached-protocol"/a></p>
-   * <U>Description</U>: Specifies the protocol used by {@link com.gemstone.gemfire.memcached.GemFireMemcachedServer}</p>
+   * <U>Description</U>: Specifies the protocol used by {@link org.apache.geode.memcached.GemFireMemcachedServer}</p>
    * <U>Default</U>: "ASCII"</p>
    * <U>Allowed values</U>: "ASCII" "BINARY"
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/DistributedLockService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/DistributedLockService.java b/geode-core/src/main/java/org/apache/geode/distributed/DistributedLockService.java
index 0d0fd0c..4ceefaa 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/DistributedLockService.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/DistributedLockService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.distributed.internal.locks.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.distributed.internal.locks.*;
+import org.apache.geode.distributed.internal.*;
 
 /**
  * <p>A named instance of DistributedLockService defines a space for
@@ -351,7 +351,7 @@ public abstract class DistributedLockService {
    * @throws IllegalArgumentException if <code>serviceName<code> does not
    * refer to any registered locking service in this process
    *
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#becomeLockGrantor()
+   * @see org.apache.geode.distributed.DistributedLockService#becomeLockGrantor()
    */
   public static void becomeLockGrantor(String serviceName)
   throws IllegalArgumentException {
@@ -362,7 +362,7 @@ public abstract class DistributedLockService {
    * Returns true if this member is currently the lock authority responsible
    * for granting locks for this service.  This can be explicitly requested by
    * calling {@link 
-   * com.gemstone.gemfire.distributed.DistributedLockService#becomeLockGrantor()}.
+   * org.apache.geode.distributed.DistributedLockService#becomeLockGrantor()}.
    * If no member has explicitly requested grantor authority, then one member 
    * participating in the service will be implicitly selected.  In either case, 
    * this method returns true if the calling member is the grantor.
@@ -383,7 +383,7 @@ public abstract class DistributedLockService {
    * @throws IllegalArgumentException if <code>serviceName<code> does not
    * refer to any registered locking service in this process
    *
-   * @see com.gemstone.gemfire.distributed.DistributedLockService#isLockGrantor()
+   * @see org.apache.geode.distributed.DistributedLockService#isLockGrantor()
    */
   public static boolean isLockGrantor(String serviceName)
   throws IllegalArgumentException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/DistributedMember.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/DistributedMember.java b/geode-core/src/main/java/org/apache/geode/distributed/DistributedMember.java
index 58c5094..7043bd1 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/DistributedMember.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/DistributedMember.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import java.util.List;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystem.java b/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystem.java
index cb6851f..7a19a70 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystem.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystem.java
@@ -15,24 +15,24 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-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.Assert;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+package org.apache.geode.distributed;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.LogWriter;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.tcp.ConnectionTable;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.security.GemFireSecurityException;
 
 import java.io.File;
 import java.net.InetAddress;
@@ -41,7 +41,7 @@ import java.net.URL;
 import java.util.*;
 import java.util.concurrent.TimeUnit;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * A "connection" to a GemFire distributed system.  A
@@ -49,9 +49,9 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
  * #connect} method with a configuration as described <a
  * href="#configuration">below</a>.  A <code>DistributedSystem</code>
  * is used when calling {@link
- * com.gemstone.gemfire.cache.CacheFactory#create}.  This class should
+ * org.apache.geode.cache.CacheFactory#create}.  This class should
  * not be confused with the {@link
- * com.gemstone.gemfire.admin.AdminDistributedSystem
+ * org.apache.geode.admin.AdminDistributedSystem
  * AdminDistributedSystem} interface that is used for administering a
  * distributed system.
  *
@@ -169,12 +169,12 @@ public abstract class DistributedSystem implements StatisticsFactory {
    *         If a <code>DistributedSystem</code> with a different
    *         configuration has already been created in this VM or if
    *         this VM is {@link
-   *         com.gemstone.gemfire.admin.AdminDistributedSystem
+   *         org.apache.geode.admin.AdminDistributedSystem
    *         administering} a distributed system.
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *         Problems while reading configuration properties file or
    *         while opening the log file.
-   * @throws com.gemstone.gemfire.GemFireConfigException
+   * @throws org.apache.geode.GemFireConfigException
    *         The distribution transport is not configured correctly
    *
    * @deprecated as of 6.5 use {@link CacheFactory#create} or {@link ClientCacheFactory#create} instead.
@@ -349,7 +349,7 @@ public abstract class DistributedSystem implements StatisticsFactory {
   }
 
   /**
-   * see {@link com.gemstone.gemfire.admin.AdminDistributedSystemFactory}
+   * see {@link org.apache.geode.admin.AdminDistributedSystemFactory}
    * @since GemFire 5.7
    */
   protected static void setEnableAdministrationOnly(boolean adminOnly) {
@@ -372,11 +372,11 @@ public abstract class DistributedSystem implements StatisticsFactory {
 //    *        used when connecting to the distributed system
 //    * @param callback
 //    *        A user-specified object that is delivered with the {@link
-//    *        com.gemstone.gemfire.admin.SystemMembershipEvent}
+//    *        org.apache.geode.admin.SystemMembershipEvent}
 //    *        triggered by connecting.
 //    *
 //    * @see #connect(Properties)
-//    * @see com.gemstone.gemfire.admin.SystemMembershipListener#memberJoined
+//    * @see org.apache.geode.admin.SystemMembershipListener#memberJoined
 //    *
 //    * @since GemFire 4.0
 //    */
@@ -441,7 +441,7 @@ public abstract class DistributedSystem implements StatisticsFactory {
   /**
    * Disconnects from this distributed system.  This operation will
    * close the distribution manager and render the {@link
-   * com.gemstone.gemfire.cache.Cache Cache} and all distributed
+   * org.apache.geode.cache.Cache Cache} and all distributed
    * collections obtained from this distributed system inoperable.
    * After a disconnect has completed, a VM may connect to another
    * distributed system.
@@ -476,7 +476,7 @@ public abstract class DistributedSystem implements StatisticsFactory {
    * Returns a string that uniquely identifies this connection to the
    * distributed system.
    *
-   * @see com.gemstone.gemfire.admin.SystemMembershipEvent#getMemberId
+   * @see org.apache.geode.admin.SystemMembershipEvent#getMemberId
    *
    * @since GemFire 4.0
    * @deprecated as of GemFire 5.0, use {@link #getDistributedMember} instead

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystemDisconnectedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystemDisconnectedException.java b/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystemDisconnectedException.java
index 2858780..dd48cf8 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystemDisconnectedException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/DistributedSystemDisconnectedException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a GemFire distributed system has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/DurableClientAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/DurableClientAttributes.java b/geode-core/src/main/java/org/apache/geode/distributed/DurableClientAttributes.java
index 12276dc..6b55731 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/DurableClientAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/DurableClientAttributes.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 /**
  * Class <code>DurableClientAttributes</code> represents durable member

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/FutureCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/FutureCancelledException.java b/geode-core/src/main/java/org/apache/geode/distributed/FutureCancelledException.java
index 42bb58c..56584c8 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/FutureCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/FutureCancelledException.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import java.util.concurrent.Future;
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a {@link Future} has been cancelled.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/GatewayCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/GatewayCancelledException.java b/geode-core/src/main/java/org/apache/geode/distributed/GatewayCancelledException.java
index 11d975f..285a40f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/GatewayCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/GatewayCancelledException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a GemFire WAN gateway has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/LeaseExpiredException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/LeaseExpiredException.java b/geode-core/src/main/java/org/apache/geode/distributed/LeaseExpiredException.java
index 03271d5..e5da73b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/LeaseExpiredException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/LeaseExpiredException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * A <code>LeaseExpiredException</code> is thrown when GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/Locator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/Locator.java b/geode-core/src/main/java/org/apache/geode/distributed/Locator.java
index 8795b71..ed42df2 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/Locator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/Locator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import java.io.File;
 import java.io.IOException;
@@ -23,9 +23,9 @@ import java.util.Collections;
 import java.util.List;
 import java.util.Properties;
 
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Represents a distribution locator server that provides discovery information
@@ -105,10 +105,10 @@ public abstract class Locator {
    *
    * @throws IllegalArgumentException
    *         If <code>port</code> is not in the range 0 to 65536
-   * @throws com.gemstone.gemfire.SystemIsRunningException
+   * @throws org.apache.geode.SystemIsRunningException
    *         If another locator is already running in
    *         <code>outputDir</code>
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *         If the directory containing the <code>logFile</code> does
    *         not exist or cannot be written to
    * @throws IOException
@@ -151,10 +151,10 @@ public abstract class Locator {
    * 
    * @throws IllegalArgumentException
    *                 If <code>port</code> is not in the range 0 to 65536
-   * @throws com.gemstone.gemfire.SystemIsRunningException
+   * @throws org.apache.geode.SystemIsRunningException
    *                 If another locator is already running in
    *                 <code>outputDir</code>
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *                 If the directory containing the <code>logFile</code> does
    *                 not exist or cannot be written to
    * @throws IOException
@@ -186,10 +186,10 @@ public abstract class Locator {
    *
    * @throws IllegalArgumentException
    *         If <code>port</code> is not in the range 0 to 65536
-   * @throws com.gemstone.gemfire.SystemIsRunningException
+   * @throws org.apache.geode.SystemIsRunningException
    *         If another locator is already running in
    *         <code>outputDir</code>
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *         If the directory containing the <code>logFile</code> does
    *         not exist or cannot be written to
    * @throws IOException
@@ -233,10 +233,10 @@ public abstract class Locator {
    *
    * @throws IllegalArgumentException
    *         If <code>port</code> is not in the range 0 to 65536
-   * @throws com.gemstone.gemfire.SystemIsRunningException
+   * @throws org.apache.geode.SystemIsRunningException
    *         If another locator is already running in
    *         <code>outputDir</code>
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *         If the directory containing the <code>logFile</code> does
    *         not exist or cannot be written to
    * @throws IOException
@@ -292,10 +292,10 @@ public abstract class Locator {
    *         If <code>port</code> is not in the range 0 to 65536
    *         or <code>peerLocator</code> and <code> serverLocator</code>
    *         are both false.
-   * @throws com.gemstone.gemfire.SystemIsRunningException
+   * @throws org.apache.geode.SystemIsRunningException
    *         If another locator is already running in
    *         <code>outputDir</code>
-   * @throws com.gemstone.gemfire.GemFireIOException
+   * @throws org.apache.geode.GemFireIOException
    *         If the directory containing the <code>logFile</code> does
    *         not exist or cannot be written to
    * @throws IOException
@@ -511,7 +511,7 @@ public abstract class Locator {
    * The <i>gemfire stop-locator</i> command can be used to stop
    * a locator that is started with this class.
    * <p>
-   * java com.gemstone.gemfire.distributed.Locator port [bind-address] [gemfire-properties-file] [peer] [server]
+   * java org.apache.geode.distributed.Locator port [bind-address] [gemfire-properties-file] [peer] [server]
    * <p>
    * port - the tcp/ip port that the locator should listen on.  This is the
    * port number that applications will refer to in their <i>locators</i> property
@@ -539,7 +539,7 @@ public abstract class Locator {
    * @since GemFire 5.0
    */
   public static void main(String args[]) {
-    com.gemstone.gemfire.internal.DistributionLocator.main(args);
+    org.apache.geode.internal.DistributionLocator.main(args);
   }
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/LocatorLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/LocatorLauncher.java b/geode-core/src/main/java/org/apache/geode/distributed/LocatorLauncher.java
index 81d874d..e4e8bf3 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/LocatorLauncher.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/LocatorLauncher.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
-
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorStatusResponse;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalLocator;
-import com.gemstone.gemfire.internal.DistributionLocator;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.process.*;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.lang.AttachAPINotFoundException;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonArray;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonException;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonObject;
+package org.apache.geode.distributed;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+import org.apache.geode.cache.client.internal.locator.LocatorStatusResponse;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.DistributionLocator;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.process.*;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.lang.AttachAPINotFoundException;
+import org.apache.geode.management.internal.cli.json.GfJsonArray;
+import org.apache.geode.management.internal.cli.json.GfJsonException;
+import org.apache.geode.management.internal.cli.json.GfJsonObject;
 import joptsimple.OptionException;
 import joptsimple.OptionParser;
 import joptsimple.OptionSet;
@@ -58,8 +58,8 @@ import java.util.logging.Level;
 /**
  * The LocatorLauncher class is a launcher for a GemFire Locator.
  * 
- * @see com.gemstone.gemfire.distributed.AbstractLauncher
- * @see com.gemstone.gemfire.distributed.ServerLauncher
+ * @see org.apache.geode.distributed.AbstractLauncher
+ * @see org.apache.geode.distributed.ServerLauncher
  * @since GemFire 7.0
  */
 @SuppressWarnings({ "unused" })
@@ -206,7 +206,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * 
    * @param builder an instance of LocatorLauncher.Builder for configuring and constructing an instance of the
    * LocatorLauncher.
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.Builder
+   * @see org.apache.geode.distributed.LocatorLauncher.Builder
    */
   private LocatorLauncher(final Builder builder) {
     this.command = builder.getCommand();
@@ -264,7 +264,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * Get the Locator launcher command used to invoke the Locator.
    * 
    * @return the Locator launcher command used to invoke the Locator.
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command
+   * @see org.apache.geode.distributed.LocatorLauncher.Command
    */
   public Command getCommand() {
     return this.command;
@@ -286,7 +286,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * if the user entered the "--help" option (switch) on the command-line.
    * 
    * @return a boolean value indicating if this launcher is used for displaying help information.
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command
+   * @see org.apache.geode.distributed.LocatorLauncher.Command
    */
   public boolean isHelping() {
     return this.help;
@@ -465,7 +465,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
   /**
    * Displays usage information on the proper invocation of the LocatorLauncher from the command-line to standard err.
    * 
-   * @see #help(com.gemstone.gemfire.distributed.LocatorLauncher.Command)
+   * @see #help(org.apache.geode.distributed.LocatorLauncher.Command)
    */
   public void usage() {
     info(StringUtils.wrap(helpMap.get("launcher"), 80, "\t"));
@@ -489,7 +489,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @see LocatorLauncher#status()
    * @see LocatorLauncher#stop()
    * @see LocatorLauncher#version()
-   * @see LocatorLauncher#help(com.gemstone.gemfire.distributed.LocatorLauncher.Command)
+   * @see LocatorLauncher#help(org.apache.geode.distributed.LocatorLauncher.Command)
    * @see LocatorLauncher#usage()
    */
   public void run() {
@@ -566,10 +566,10 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @see #stop()
    * @see #waitOnLocator()
    * @see #waitOnStatusResponse(long, long, java.util.concurrent.TimeUnit)
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.LocatorState
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status#NOT_RESPONDING
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status#ONLINE
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status#STARTING
+   * @see org.apache.geode.distributed.LocatorLauncher.LocatorState
+   * @see org.apache.geode.distributed.AbstractLauncher.Status#NOT_RESPONDING
+   * @see org.apache.geode.distributed.AbstractLauncher.Status#ONLINE
+   * @see org.apache.geode.distributed.AbstractLauncher.Status#STARTING
    */
   @SuppressWarnings("deprecation")
   public LocatorState start() {
@@ -681,8 +681,8 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @throws AssertionError if the Locator has not been started and the reference is null (assertions must be enabled
    * for the error to be thrown).
    * @see #failOnStart(Throwable)
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.LocatorState
+   * @see org.apache.geode.distributed.AbstractLauncher.Status
+   * @see org.apache.geode.distributed.LocatorLauncher.LocatorState
    */
   public LocatorState waitOnLocator() {
     Throwable t = null;
@@ -785,8 +785,8 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @return the Locator's state.
    * @see #start()
    * @see #stop()
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.LocatorState
+   * @see org.apache.geode.distributed.AbstractLauncher.Status
+   * @see org.apache.geode.distributed.LocatorLauncher.LocatorState
    */
   public LocatorState status() {
     final LocatorLauncher launcher = getInstance();
@@ -951,9 +951,9 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * @return a LocatorState indicating the state of the Locator after stop has been requested.
    * @see #start()
    * @see #status()
-   * @see com.gemstone.gemfire.distributed.LocatorLauncher.LocatorState
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status#NOT_RESPONDING
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.Status#STOPPED
+   * @see org.apache.geode.distributed.LocatorLauncher.LocatorState
+   * @see org.apache.geode.distributed.AbstractLauncher.Status#NOT_RESPONDING
+   * @see org.apache.geode.distributed.AbstractLauncher.Status#STOPPED
    */
   public LocatorState stop() {
     final LocatorLauncher launcher = getInstance();
@@ -1284,7 +1284,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * Iterates the list of arguments in search of the target Locator launcher command.
      * 
      * @param args an array of arguments from which to search for the Locator launcher command.
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command#valueOfName(String)
+     * @see org.apache.geode.distributed.LocatorLauncher.Command#valueOfName(String)
      * @see #parseArguments(String...)
      */
     protected void parseCommand(final String... args) {
@@ -1305,7 +1305,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * for the Locator in GemFire.
      * 
      * @param args the array of arguments from which to search for the Locator's member name in GemFire.
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command#isCommand(String)
+     * @see org.apache.geode.distributed.LocatorLauncher.Command#isCommand(String)
      * @see #parseArguments(String...)
      */
     protected void parseMemberName(final String[] args) {
@@ -1321,7 +1321,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * Gets the Locator launcher command used during the invocation of the LocatorLauncher.
      * 
      * @return the Locator launcher command used to invoke (run) the LocatorLauncher class.
-     * @see #setCommand(com.gemstone.gemfire.distributed.LocatorLauncher.Command)
+     * @see #setCommand(org.apache.geode.distributed.LocatorLauncher.Command)
      * @see LocatorLauncher.Command
      */
     public Command getCommand() {
@@ -1377,7 +1377,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * Gets the boolean value used by the Locator to determine if it should overwrite the PID file if it already exists.
      * 
      * @return the boolean value specifying whether or not to overwrite the PID file if it already exists.
-     * @see com.gemstone.gemfire.internal.process.LocalProcessLauncher
+     * @see org.apache.geode.internal.process.LocalProcessLauncher
      * @see #setForce(Boolean)
      */
     public Boolean getForce() {
@@ -1389,7 +1389,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * 
      * @param force a boolean value indicating whether to overwrite the PID file when it already exists.
      * @return this Builder instance.
-     * @see com.gemstone.gemfire.internal.process.LocalProcessLauncher
+     * @see org.apache.geode.internal.process.LocalProcessLauncher
      * @see #getForce()
      */
     public Builder setForce(final Boolean force) {
@@ -1706,7 +1706,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'start' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command#START
+     * @see org.apache.geode.distributed.LocatorLauncher.Command#START
      */
     protected void validateOnStart() {
       if (Command.START.equals(getCommand())) {
@@ -1729,7 +1729,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'status' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command#STATUS
+     * @see org.apache.geode.distributed.LocatorLauncher.Command#STATUS
      */
     protected void validateOnStatus() {
       if (Command.STATUS.equals(getCommand())) {
@@ -1739,7 +1739,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'stop' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher.Command#STOP
+     * @see org.apache.geode.distributed.LocatorLauncher.Command#STOP
      */
     protected void validateOnStop() {
       if (Command.STOP.equals(getCommand())) {
@@ -1752,7 +1752,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
      * 
      * @return a newly constructed instance of LocatorLauncher configured with this Builder.
      * @see #validate()
-     * @see com.gemstone.gemfire.distributed.LocatorLauncher
+     * @see org.apache.geode.distributed.LocatorLauncher
      */
     public LocatorLauncher build() {
       validate();
@@ -1874,7 +1874,7 @@ public final class LocatorLauncher extends AbstractLauncher<String> {
    * The LocatorState is an immutable type representing the state of the specified Locator at any given moment in time.
    * The state of the Locator is assessed at the exact moment an instance of this class is constructed.
    * 
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.ServiceState
+   * @see org.apache.geode.distributed.AbstractLauncher.ServiceState
    */
   public static final class LocatorState extends ServiceState<String> {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/LockNotHeldException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/LockNotHeldException.java b/geode-core/src/main/java/org/apache/geode/distributed/LockNotHeldException.java
index 7a52bee..62b88f1 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/LockNotHeldException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/LockNotHeldException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 /**
  * A <code>LockNotHeldException</code> is thrown when attempting

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/LockServiceDestroyedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/LockServiceDestroyedException.java b/geode-core/src/main/java/org/apache/geode/distributed/LockServiceDestroyedException.java
index db452bb..fd1ec90 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/LockServiceDestroyedException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/LockServiceDestroyedException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 /**
  * A <code>LockServiceDestroyedException</code> is thrown when attempting

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/OplogCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/OplogCancelledException.java b/geode-core/src/main/java/org/apache/geode/distributed/OplogCancelledException.java
index fa7cb58..92853bb 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/OplogCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/OplogCancelledException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a GemFire operation log has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/PoolCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/PoolCancelledException.java b/geode-core/src/main/java/org/apache/geode/distributed/PoolCancelledException.java
index 4cbd994..9c4236a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/PoolCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/PoolCancelledException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a GemFire connection pool has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/Role.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/Role.java b/geode-core/src/main/java/org/apache/geode/distributed/Role.java
index f095119..d8440b8 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/Role.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/Role.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 /**
  * Members of the distributed system can fill one or more user defined roles.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncher.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncher.java b/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncher.java
index cce482a..80ab26c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncher.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncher.java
@@ -15,33 +15,33 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed;
-
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.partition.PartitionRegionHelper;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.internal.DefaultServerLauncherCacheProvider;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerHelper;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.ObjectUtils;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.internal.process.*;
-import com.gemstone.gemfire.internal.util.IOUtils;
-import com.gemstone.gemfire.lang.AttachAPINotFoundException;
-import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonArray;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonException;
-import com.gemstone.gemfire.management.internal.cli.json.GfJsonObject;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+package org.apache.geode.distributed;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.partition.PartitionRegionHelper;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.internal.DefaultServerLauncherCacheProvider;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerHelper;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.ObjectUtils;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.internal.process.*;
+import org.apache.geode.internal.util.IOUtils;
+import org.apache.geode.lang.AttachAPINotFoundException;
+import org.apache.geode.management.internal.cli.i18n.CliStrings;
+import org.apache.geode.management.internal.cli.json.GfJsonArray;
+import org.apache.geode.management.internal.cli.json.GfJsonException;
+import org.apache.geode.management.internal.cli.json.GfJsonObject;
+import org.apache.geode.pdx.PdxSerializer;
 import joptsimple.OptionException;
 import joptsimple.OptionParser;
 import joptsimple.OptionSet;
@@ -60,14 +60,14 @@ import java.util.concurrent.TimeoutException;
 import java.util.concurrent.atomic.AtomicBoolean;
 import java.util.concurrent.atomic.AtomicReference;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.SERVER_BIND_ADDRESS;
+import static org.apache.geode.distributed.ConfigurationProperties.SERVER_BIND_ADDRESS;
 
 /**
  * The ServerLauncher class is a launcher class with main method to start a GemFire Server (implying a GemFire Cache
  * Server process).
  * 
- * @see com.gemstone.gemfire.distributed.AbstractLauncher
- * @see com.gemstone.gemfire.distributed.LocatorLauncher
+ * @see org.apache.geode.distributed.AbstractLauncher
+ * @see org.apache.geode.distributed.LocatorLauncher
  * @since GemFire 7.0
  */
 @SuppressWarnings({ "unused" })
@@ -219,7 +219,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * 
    * @param builder an instance of ServerLauncher.Builder for configuring and constructing an instance of the
    * ServerLauncher.
-   * @see com.gemstone.gemfire.distributed.ServerLauncher.Builder
+   * @see org.apache.geode.distributed.ServerLauncher.Builder
    */
   private ServerLauncher(final Builder builder) {
     this.cache = builder.getCache(); // testing
@@ -276,7 +276,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * Gets a reference to the Cache that was created when the GemFire Server was started.
    * 
    * @return a reference to the Cache created by the GemFire Server start operation.
-   * @see com.gemstone.gemfire.cache.Cache
+   * @see org.apache.geode.cache.Cache
    */
   final Cache getCache() {
     if (this.cache != null) {
@@ -325,7 +325,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * Get the Server launcher command used to invoke the Server.
    * 
    * @return the Server launcher command used to invoke the Server.
-   * @see com.gemstone.gemfire.distributed.ServerLauncher.Command
+   * @see org.apache.geode.distributed.ServerLauncher.Command
    */
   public Command getCommand() {
     return this.command;
@@ -365,7 +365,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * if the user entered the "--help" option (switch) on the command-line.
    * 
    * @return a boolean value indicating if this launcher is used for displaying help information.
-   * @see com.gemstone.gemfire.distributed.ServerLauncher.Command
+   * @see org.apache.geode.distributed.ServerLauncher.Command
    */
   public boolean isHelping() {
     return this.help;
@@ -513,7 +513,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * the GemFire Server on start.
    * <p>
    * @return a String indicating the location of the Spring XML configuration file.
-   * @see com.gemstone.gemfire.distributed.ServerLauncher.Builder#getSpringXmlLocation()
+   * @see org.apache.geode.distributed.ServerLauncher.Builder#getSpringXmlLocation()
    */
   public String getSpringXmlLocation() {
     return this.springXmlLocation;
@@ -606,7 +606,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
   /**
    * Displays usage information on the proper invocation of the ServerLauncher from the command-line to standard err.
    * 
-   * @see #help(com.gemstone.gemfire.distributed.ServerLauncher.Command)
+   * @see #help(org.apache.geode.distributed.ServerLauncher.Command)
    */
   public void usage() {
     info(StringUtils.wrap(helpMap.get("launcher"), 80, "\t"));
@@ -920,7 +920,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * Causes a rebalance operation to occur on the given Cache.
    * 
    * @param cache the reference to the Cache to rebalance.
-   * @see com.gemstone.gemfire.cache.control.ResourceManager#createRebalanceFactory()
+   * @see org.apache.geode.cache.control.ResourceManager#createRebalanceFactory()
    */
   private void rebalance(final Cache cache) {
     if (isRebalancing()) {
@@ -944,7 +944,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * Assigns buckets to individual Partitioned Regions of the Cache.
    * 
    * @param cache the Cache who's Partitioned Regions are accessed to assign buckets to.
-   * @see PartitionRegionHelper#assignBucketsToPartitions(com.gemstone.gemfire.cache.Region)
+   * @see PartitionRegionHelper#assignBucketsToPartitions(org.apache.geode.cache.Region)
    */
   final void assignBuckets(final Cache cache) {
     if (isAssignBucketsAllowed(cache)) {
@@ -1569,7 +1569,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * Iterates the list of arguments in search of the target Server launcher command.
      * 
      * @param args an array of arguments from which to search for the Server launcher command.
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command#valueOfName(String)
+     * @see org.apache.geode.distributed.ServerLauncher.Command#valueOfName(String)
      * @see #parseArguments(String...)
      */
     protected void parseCommand(final String... args) {
@@ -1590,7 +1590,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * for the Server in GemFire.
      * 
      * @param args the array of arguments from which to search for the Server's member name in GemFire.
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command#isCommand(String)
+     * @see org.apache.geode.distributed.ServerLauncher.Command#isCommand(String)
      * @see #parseArguments(String...)
      */
     protected void parseMemberName(final String... args) {
@@ -1617,8 +1617,8 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * Gets the Server launcher command used during the invocation of the ServerLauncher.
      * 
      * @return the Server launcher command used to invoke (run) the ServerLauncher class.
-     * @see #setCommand(com.gemstone.gemfire.distributed.ServerLauncher.Command)
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command
+     * @see #setCommand(org.apache.geode.distributed.ServerLauncher.Command)
+     * @see org.apache.geode.distributed.ServerLauncher.Command
      */
     public Command getCommand() {
       return ObjectUtils.defaultIfNull(this.command, DEFAULT_COMMAND);
@@ -1630,7 +1630,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * @param command the targeted Server launcher command used during the invocation (run) of ServerLauncher.
      * @return this Builder instance.
      * @see #getCommand()
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command
+     * @see org.apache.geode.distributed.ServerLauncher.Command
      */
     public Builder setCommand(final Command command) {
       this.command = command;
@@ -1728,7 +1728,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * Gets the boolean value used by the Server to determine if it should overwrite the PID file if it already exists.
      * 
      * @return the boolean value specifying whether or not to overwrite the PID file if it already exists.
-     * @see com.gemstone.gemfire.internal.process.LocalProcessLauncher
+     * @see org.apache.geode.internal.process.LocalProcessLauncher
      * @see #setForce(Boolean)
      */
     public Boolean getForce() {
@@ -1740,7 +1740,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * 
      * @param force a boolean value indicating whether to overwrite the PID file when it already exists.
      * @return this Builder instance.
-     * @see com.gemstone.gemfire.internal.process.LocalProcessLauncher
+     * @see org.apache.geode.internal.process.LocalProcessLauncher
      * @see #getForce()
      */
     public Builder setForce(final Boolean force) {
@@ -2259,7 +2259,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'start' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command#START
+     * @see org.apache.geode.distributed.ServerLauncher.Command#START
      */
     protected void validateOnStart() {
       if (Command.START.equals(getCommand())) {
@@ -2282,7 +2282,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'status' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command#STATUS
+     * @see org.apache.geode.distributed.ServerLauncher.Command#STATUS
      */
     protected void validateOnStatus() {
       if (Command.STATUS.equals(getCommand())) {
@@ -2293,7 +2293,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
     /**
      * Validates the arguments passed to the Builder when the 'stop' command has been issued.
      * 
-     * @see com.gemstone.gemfire.distributed.ServerLauncher.Command#STOP
+     * @see org.apache.geode.distributed.ServerLauncher.Command#STOP
      */
     protected void validateOnStop() {
       if (Command.STOP.equals(getCommand())) {
@@ -2307,7 +2307,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
      * 
      * @return a newly constructed instance of the ServerLauncher configured with this Builder.
      * @see #validate()
-     * @see com.gemstone.gemfire.distributed.ServerLauncher
+     * @see org.apache.geode.distributed.ServerLauncher
      */
     public ServerLauncher build() {
       validate();
@@ -2429,7 +2429,7 @@ public class ServerLauncher extends AbstractLauncher<String> {
    * The ServerState is an immutable type representing the state of the specified Locator at any given moment in time.
    * The state of the Locator is assessed at the exact moment an instance of this class is constructed.
    * 
-   * @see com.gemstone.gemfire.distributed.AbstractLauncher.ServiceState
+   * @see org.apache.geode.distributed.AbstractLauncher.ServiceState
    */
   public static final class ServerState extends ServiceState<String> {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncherCacheProvider.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncherCacheProvider.java b/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncherCacheProvider.java
index 5dad5fe..014c6da 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncherCacheProvider.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/ServerLauncherCacheProvider.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.Cache;
+import org.apache.geode.cache.Cache;
 
 /**
  * ServerLauncherCacheProvider is an extension point for overriding

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/TXManagerCancelledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/TXManagerCancelledException.java b/geode-core/src/main/java/org/apache/geode/distributed/TXManagerCancelledException.java
index eedefd1..94e2abd 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/TXManagerCancelledException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/TXManagerCancelledException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed;
+package org.apache.geode.distributed;
 
-import com.gemstone.gemfire.CancelException;
+import org.apache.geode.CancelException;
 
 /**
  * Thrown when a GemFire transaction manager has been terminated.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/AbstractDistributionConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/AbstractDistributionConfig.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/AbstractDistributionConfig.java
index d4c3b90..7b3dec2 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/AbstractDistributionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/AbstractDistributionConfig.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.lang.reflect.Method;
 import java.net.InetAddress;
@@ -31,17 +31,17 @@ import java.util.StringTokenizer;
 
 import org.apache.commons.lang.StringUtils;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.InvalidValueException;
-import com.gemstone.gemfire.UnmodifiableException;
-import com.gemstone.gemfire.internal.AbstractConfig;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogWriterImpl;
-import com.gemstone.gemfire.internal.security.SecurableComponent;
-import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.InvalidValueException;
+import org.apache.geode.UnmodifiableException;
+import org.apache.geode.internal.AbstractConfig;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogWriterImpl;
+import org.apache.geode.internal.security.SecurableComponent;
+import org.apache.geode.memcached.GemFireMemcachedServer;
 
 /**
  * Provides an implementation of <code>DistributionConfig</code> that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/AdminMessageType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/AdminMessageType.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/AdminMessageType.java
index 57e216f..8563d64 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/AdminMessageType.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/AdminMessageType.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * A marker interface that messages related to administation must implement.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/AtomicLongWithTerminalState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/AtomicLongWithTerminalState.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/AtomicLongWithTerminalState.java
index 85286da..6ef86f1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/AtomicLongWithTerminalState.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/AtomicLongWithTerminalState.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.concurrent.atomic.AtomicLong;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/CacheTime.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/CacheTime.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/CacheTime.java
index 08c1400..25bfac9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/CacheTime.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/CacheTime.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Provides a method to get the system millisecond clock time

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/CollectingReplyProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/CollectingReplyProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/CollectingReplyProcessor.java
index 2a7347b..163bf2d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/CollectingReplyProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/CollectingReplyProcessor.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.Collection;
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttribute.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttribute.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttribute.java
index de2573c..f5ce7bc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttribute.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttribute.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeChecker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeChecker.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeChecker.java
index 21e130d..5171fde 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeChecker.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeChecker.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeDesc.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeDesc.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeDesc.java
index bc6f017..c8e5769 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeDesc.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeDesc.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeGetter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeGetter.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeGetter.java
index 6e24074..f62dc3c 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeGetter.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeGetter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeSetter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeSetter.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeSetter.java
index 2cec022..0b9a2cc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeSetter.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConfigAttributeSetter.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.lang.annotation.ElementType;
 import java.lang.annotation.Retention;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ConflationKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConflationKey.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConflationKey.java
index 5360ebc..35450a1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ConflationKey.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ConflationKey.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.nio.ByteBuffer;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DM.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DM.java
index a3741a7..327ca37 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DM.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DM.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.NotSerializableException;
 import java.net.InetAddress;
@@ -25,13 +25,13 @@ import java.util.NoSuchElementException;
 import java.util.Set;
 import java.util.concurrent.ExecutorService;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.locks.ElderState;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.locks.ElderState;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.internal.Version;
 
 /**
  * This interface defines the services provided  by any class that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DMStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DMStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DMStats.java
index 1a230c7..1c70b6c 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DMStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DMStats.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Defines the interface used to access and modify DM statistics.


[73/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemberService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemberService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemberService.java
deleted file mode 100644
index 6a42c0d..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemberService.java
+++ /dev/null
@@ -1,132 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.TimeUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.math.BigDecimal;
-import java.math.RoundingMode;
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.List;
-
-/**
- * Class ClusterMemberService
- * 
- * This class contains implementations of getting Cluster Member's details
- * 
- * @since GemFire version 7.5
- */
-@Component
-// @Service("ClusterMember")
-@Service("ClusterMembers")
-@Scope("singleton")
-public class ClusterMemberService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  private final String HEAP_USAGE = "heapUsage";
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    Cluster.Member[] clusterMembersList = cluster.getMembers();
-
-    // create members json
-    ArrayNode memberListJson = mapper.createArrayNode();
-    for (Cluster.Member clusterMember : clusterMembersList) {
-      ObjectNode memberJSON = mapper.createObjectNode();
-      // getting members detail
-      memberJSON.put("gemfireVersion", clusterMember.getGemfireVersion());
-      memberJSON.put("memberId", clusterMember.getId());
-      memberJSON.put("name", clusterMember.getName());
-      memberJSON.put("host", clusterMember.getHost());
-
-      List<String> serverGroups = clusterMember.getServerGroups();
-      if(serverGroups.size() == 0){
-        serverGroups = new ArrayList<>();
-        serverGroups.add(PulseConstants.DEFAULT_SERVER_GROUP);
-      }
-
-      memberJSON.put("serverGroups", mapper.valueToTree(serverGroups));
-
-      List<String> redundancyZones = clusterMember.getRedundancyZones();
-      if(redundancyZones.size() == 0){
-        redundancyZones = new ArrayList<String>();
-        redundancyZones.add(PulseConstants.DEFAULT_REDUNDANCY_ZONE);
-      }
-      memberJSON.put("redundancyZones", mapper.valueToTree(redundancyZones));
-
-      long usedHeapSize = cluster.getUsedHeapSize();
-      long currentHeap = clusterMember.getCurrentHeapSize();
-      if (usedHeapSize > 0) {
-        double heapUsage = ((double) currentHeap / (double) usedHeapSize) * 100;
-        memberJSON.put(this.HEAP_USAGE, truncate(heapUsage, 2));
-      } else {
-        memberJSON.put(this.HEAP_USAGE, 0);
-      }
-      double currentCPUUsage = clusterMember.getCpuUsage();
-      double loadAvg = clusterMember.getLoadAverage();
-
-      memberJSON.put("cpuUsage", truncate(currentCPUUsage, 2));
-      memberJSON.put("currentHeapUsage", clusterMember.getCurrentHeapSize());
-      memberJSON.put("isManager", clusterMember.isManager());
-      memberJSON.put("uptime", TimeUtils.convertTimeSecondsToHMS(clusterMember.getUptime()));
-      memberJSON.put("loadAvg", truncate(loadAvg, 2));
-      memberJSON.put("sockets", clusterMember.getTotalFileDescriptorOpen());
-      memberJSON.put("threads", clusterMember.getNumThreads());
-
-      // Number of member clients
-      if (PulseController.getPulseProductSupport().equalsIgnoreCase(
-          PulseConstants.PRODUCT_NAME_SQLFIRE)){
-        memberJSON.put("clients", clusterMember.getNumSqlfireClients());
-      }else{
-        memberJSON.put("clients", clusterMember.getMemberClientsHMap().size());
-      }
-      memberJSON.put("queues", clusterMember.getQueueBacklog());
-
-      memberListJson.add(memberJSON);
-    }
-    // cluster's Members
-    responseJSON.put("members", memberListJson);
-    // Send json response
-    return responseJSON;
-  }
-
-  private double truncate(double value, int places) {
-    return new BigDecimal(value).setScale(places, RoundingMode.HALF_UP).doubleValue();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMembersRGraphService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMembersRGraphService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMembersRGraphService.java
deleted file mode 100644
index f8617cb..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMembersRGraphService.java
+++ /dev/null
@@ -1,359 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map;
-
-import javax.servlet.http.HttpServletRequest;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-
-/**
- * Class ClusterMembersRGraphService
- * 
- * This class contains implementations of getting List of Cluster members and
- * their details
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("ClusterMembersRGraph")
-@Scope("singleton")
-public class ClusterMembersRGraphService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String CLUSTER = "clustor";
-  private final String MEMBER_COUNT = "memberCount";
-  private final String ID = "id";
-  private final String NAME = "name";
-  private final String DATA = "data";
-  private final String MEMORY_USAGE = "memoryUsage";
-  private final String CPU_USAGE = "cpuUsage";
-  private final String REGIONS = "regions";
-  private final String HOST = "host";
-  private final String PORT = "port";
-  private final String CLIENTS = "clients";
-  private final String GC_PAUSES = "gcPauses";
-  private final String GATEWAY_SENDER = "gatewaySender";
-  private final String GATEWAY_RECEIVER = "gatewayReceiver";
-  private final String LOAD_AVG = "loadAvg";
-  private final String SOCKETS = "sockets";
-  private final String THREADS = "threads";
-  private final String NUM_THREADS = "numThreads";
-
-  private final String MEMBER_NODE_TYPE_NORMAL = "Normal";
-  private final String MEMBER_NODE_TYPE_WARNING = "Warning";
-  private final String MEMBER_NODE_TYPE_ERROR = "Error";
-  private final String MEMBER_NODE_TYPE_SEVERE = "Severe";
-  private final String CHILDREN = "children";
-
-  // traversing the alert array list and members which have severe, error or
-  // warnings
-  // alerts saving them in three different arraylists
-  private List<String> severeAlertList;
-  private List<String> errorAlertsList;
-  private List<String> warningAlertsList;
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // Reference to repository
-    Repository repository = Repository.get();
-
-    // get cluster object
-    Cluster cluster = repository.getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // cluster's Members
-    responseJSON.put(this.CLUSTER,
-        getPhysicalServerJson(cluster, repository.getJmxHost(), repository.getJmxPort()));
-    responseJSON.put(this.MEMBER_COUNT, cluster.getMemberCount());
-
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * function used for getting all members details in format of JSON Object
-   * array defined under a cluster. This function create json based on the
-   * relation of physical host and members related to it.
-   * 
-   * @param cluster
-   * @param host
-   * @param port
-   * @return Array list of JSON objects for required fields of members in
-   *         cluster
-   */
-  private ObjectNode getPhysicalServerJson(Cluster cluster, String host, String port) {
-    Map<String, List<Cluster.Member>> physicalToMember = cluster.getPhysicalToMember();
-
-    ObjectNode clusterTopologyJSON = mapper.createObjectNode();
-
-    clusterTopologyJSON.put(this.ID, cluster.getClusterId());
-    clusterTopologyJSON.put(this.NAME, cluster.getClusterId());
-    ObjectNode data1 = mapper.createObjectNode();
-    clusterTopologyJSON.put(this.DATA, data1);
-    ArrayNode childHostArray = mapper.createArrayNode();
-    DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
-
-    updateAlertLists(cluster);
-
-    for (Map.Entry<String, List<Cluster.Member>> physicalToMem : physicalToMember.entrySet()) {
-      String hostName = physicalToMem.getKey();
-      double hostCpuUsage = 0.0;
-      long hostMemoryUsage = 0;
-      double hostLoadAvg = 0.0;
-      int hostNumThreads = 0;
-      long hostSockets = 0;
-      boolean hostSevere = false;
-      boolean hostError = false;
-      boolean hostWarning = false;
-      String hostStatus;
-      ObjectNode childHostObject = mapper.createObjectNode();
-      childHostObject.put(this.ID, hostName);
-      childHostObject.put(this.NAME, hostName);
-
-      ArrayNode membersArray = mapper.createArrayNode();
-
-      List<Cluster.Member> memberList = physicalToMem.getValue();
-      for (Cluster.Member member : memberList) {
-        ObjectNode memberJSONObj = mapper.createObjectNode();
-
-        memberJSONObj.put(this.ID, member.getId());
-        memberJSONObj.put(this.NAME, member.getName());
-
-        ObjectNode memberData = mapper.createObjectNode();
-
-        memberData.put("gemfireVersion", member.getGemfireVersion());
-
-        Long currentHeap = member.getCurrentHeapSize();
-        Long usedHeapSize = cluster.getUsedHeapSize();
-
-        if (usedHeapSize > 0) {
-          double heapUsage = (currentHeap.doubleValue() / usedHeapSize.doubleValue()) * 100;
-
-          memberData.put(this.MEMORY_USAGE,
-              Double.valueOf(df2.format(heapUsage)));
-        } else
-          memberData.put(this.MEMORY_USAGE, 0);
-
-        double currentCPUUsage = member.getCpuUsage();
-
-        memberData.put(this.CPU_USAGE,
-            Double.valueOf(df2.format(currentCPUUsage)));
-        memberData.put(this.REGIONS, member.getMemberRegions().size());
-        memberData.put(this.HOST, member.getHost());
-        if ((member.getMemberPort() == null)
-            || (member.getMemberPort().equals(""))) {
-          memberData.put(this.PORT, "-");
-        } else {
-          memberData.put(this.PORT, member.getMemberPort());
-        }
-        memberData.put(this.CLIENTS, member.getMemberClientsHMap().size());
-        memberData.put(this.GC_PAUSES, member.getGarbageCollectionCount());
-        memberData.put(this.NUM_THREADS, member.getNumThreads());
-
-        // Host CPU Usage is aggregate of all members cpu usage
-        // hostCpuUsage = hostCpuUsage + currentCPUUsage;
-        hostCpuUsage = member.getHostCpuUsage();
-        hostMemoryUsage = hostMemoryUsage + member.getCurrentHeapSize();
-        hostLoadAvg = member.getLoadAverage();
-        hostNumThreads = member.getNumThreads();
-        hostSockets = member.getTotalFileDescriptorOpen();
-
-        // defining the status of Member Icons for R Graph based on the alerts
-        // created for that member
-        String memberNodeType = "";
-        // for severe alert
-        if (severeAlertList.contains(member.getName())) {
-          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_SEVERE);
-          if (!hostSevere) {
-            hostSevere = true;
-          }
-        } else if (errorAlertsList.contains(member.getName())) {
-          // for error alerts
-          memberNodeType = getMemberNodeType(member,
-              this.MEMBER_NODE_TYPE_ERROR);
-          if (!hostError) {
-            hostError = true;
-          }
-        }
-        // for warning alerts
-        else if (warningAlertsList.contains(member.getName())) {
-          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_WARNING);
-          if (!hostWarning) {
-            hostWarning = true;
-          }
-        } else {
-          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_NORMAL);
-        }
-
-        memberData.put("nodeType", memberNodeType);
-        memberData.put("$type", memberNodeType);
-        memberData.put(this.GATEWAY_SENDER, member.getGatewaySenderList().size());
-        if (member.getGatewayReceiver() != null) {
-          memberData.put(this.GATEWAY_RECEIVER, 1);
-        } else {
-          memberData.put(this.GATEWAY_RECEIVER, 0);
-        }
-        memberJSONObj.put(this.DATA, memberData);
-        memberJSONObj.put(this.CHILDREN, mapper.createArrayNode());
-        membersArray.add(memberJSONObj);
-      }
-      ObjectNode data = mapper.createObjectNode();
-
-      data.put(this.LOAD_AVG, Double.valueOf(df2.format(hostLoadAvg)));
-      data.put(this.SOCKETS, hostSockets);
-      data.put(this.THREADS, hostNumThreads);
-      data.put(this.CPU_USAGE, Double.valueOf(df2.format(hostCpuUsage)));
-      data.put(this.MEMORY_USAGE, hostMemoryUsage);
-
-      String hostNodeType;
-      // setting physical host status
-      if (hostSevere) {
-        hostStatus = this.MEMBER_NODE_TYPE_SEVERE;
-        hostNodeType = "hostSevereNode";
-      } else if (hostError) {
-        hostStatus = this.MEMBER_NODE_TYPE_ERROR;
-        hostNodeType = "hostErrorNode";
-      } else if (hostWarning) {
-        hostStatus = this.MEMBER_NODE_TYPE_WARNING;
-        hostNodeType = "hostWarningNode";
-      } else {
-        hostStatus = this.MEMBER_NODE_TYPE_NORMAL;
-        hostNodeType = "hostNormalNode";
-      }
-      data.put("hostStatus", hostStatus);
-      data.put("$type", hostNodeType);
-
-      childHostObject.put(this.DATA, data);
-
-      childHostObject.put(this.CHILDREN, membersArray);
-      childHostArray.add(childHostObject);
-    }
-    clusterTopologyJSON.put(this.CHILDREN, childHostArray);
-
-    return clusterTopologyJSON;
-  }
-
-  /**
-   * used for getting member node type based on member's current state
-   * 
-   * @param member
-   *          Member
-   * @param memberState
-   *          i.e Severe, Error, Warning or Normal
-   * @return
-   */
-  private String getMemberNodeType(Cluster.Member member, String memberState) {
-    String memberNodeType = "";
-
-    if ((member.isLocator()) && (member.isServer()) && (member.isManager())) {
-      memberNodeType = "memberLocatorManagerServer" + memberState + "Node";
-    } else if ((member.isLocator()) && (member.isServer())
-        && !(member.isManager())) {
-      memberNodeType = "memberLocatorServer" + memberState + "Node";
-    } else if ((member.isLocator()) && !(member.isServer())
-        && (member.isManager())) {
-      memberNodeType = "memberLocatorManager" + memberState + "Node";
-    } else if ((member.isLocator()) && !(member.isServer())
-        && !(member.isManager())) {
-      memberNodeType = "memberLocator" + memberState + "Node";
-    } else if (!(member.isLocator()) && (member.isServer())
-        && (member.isManager())) {
-      memberNodeType = "memberManagerServer" + memberState + "Node";
-    } else if (!(member.isLocator()) && (member.isServer())
-        && !(member.isManager())) {
-      memberNodeType = "memberServer" + memberState + "Node";
-    } else if (!(member.isLocator()) && !(member.isServer())
-        && (member.isManager())) {
-      memberNodeType = "memberManager" + memberState + "Node";
-    } else if (!(member.isLocator()) && !(member.isServer())
-        && !(member.isManager())) {
-      memberNodeType = "member" + memberState + "Node";
-    }
-    return memberNodeType;
-  }
-
-  /**
-   * function used for getting list of all the alerts and save the member names
-   * in respective error, warning and severe alert lists
-   * 
-   * @param cluster
-   */
-  private void updateAlertLists(Cluster cluster) {
-
-    severeAlertList = new ArrayList<String>();
-    errorAlertsList = new ArrayList<String>();
-    warningAlertsList = new ArrayList<String>();
-
-    Cluster.Alert[] alertsList = cluster.getAlertsList();
-
-    for (Cluster.Alert alert : alertsList) {
-      // if alert is severe
-      if (alert.getSeverity() == Cluster.Alert.SEVERE) {
-        if (errorAlertsList.contains(alert.getMemberName())) {
-          errorAlertsList.remove(alert.getMemberName());
-        } else if (warningAlertsList.contains(alert.getMemberName())) {
-          warningAlertsList.remove(alert.getMemberName());
-        }
-        if (!severeAlertList.contains(alert.getMemberName())) {
-          severeAlertList.add(alert.getMemberName());
-        }
-      }
-      // if alert is error
-      else if (alert.getSeverity() == Cluster.Alert.ERROR) {
-        if (!severeAlertList.contains(alert.getMemberName())) {
-          if (warningAlertsList.contains(alert.getMemberName())) {
-            warningAlertsList.remove(alert.getMemberName());
-          }
-          if (!errorAlertsList.contains(alert.getMemberName())) {
-            errorAlertsList.add(alert.getMemberName());
-          }
-        }
-      }
-      // if alert is warning
-      else if (alert.getSeverity() == Cluster.Alert.WARNING) {
-        if (!severeAlertList.contains(alert.getMemberName())) {
-          if (!errorAlertsList.contains(alert.getMemberName())) {
-            if (!warningAlertsList.contains(alert.getMemberName())) {
-              warningAlertsList.add(alert.getMemberName());
-            }
-          }
-        }
-      }
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemoryUsageService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemoryUsageService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemoryUsageService.java
deleted file mode 100644
index 519deb1..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterMemoryUsageService.java
+++ /dev/null
@@ -1,65 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class ClusterMemoryUsageService
- * 
- * This class contains implementations of getting Cluster's overall current
- * memory usage details and its trend over the time.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterMemoryUsage")
-@Scope("singleton")
-public class ClusterMemoryUsageService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // cluster's Memory Usage trend added to json response object
-
-    responseJSON.put("currentMemoryUsage", cluster.getUsedHeapSize());
-    responseJSON.put("memoryUsageTrend",
-        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_MEMORY_USAGE)));
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionService.java
deleted file mode 100644
index 1723a98..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionService.java
+++ /dev/null
@@ -1,211 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Comparator;
-import java.util.List;
-import java.util.Map;
-
-/**
- * Class ClusterRegionService
- *
- * This class contains implementations of getting Cluster's regions details
- *
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterRegion")
-@Scope("singleton")
-public class ClusterRegionService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String ENTRY_SIZE = "entrySize";
-
-  // Comparator based upon regions entry count
-  private static Comparator<Cluster.Region> regionEntryCountComparator = (r1, r2) -> {
-    long r1Cnt = r1.getSystemRegionEntryCount();
-    long r2Cnt = r2.getSystemRegionEntryCount();
-    if (r1Cnt < r2Cnt) {
-      return -1;
-    } else if (r1Cnt > r2Cnt) {
-      return 1;
-    } else {
-      return 0;
-    }
-  };
-
-  @Override
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    String userName = request.getUserPrincipal().getName();
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // getting cluster's Regions
-    responseJSON.put("clusterName", cluster.getServerName());
-    responseJSON.put("userName", userName);
-    responseJSON.put("region", getRegionJson(cluster));
-
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * This method is used to get various regions associated with the given
-   * cluster and create json for each region fields and returns Array List for
-   * all the regions associated with given cluster
-   *
-   * @param cluster
-   * @return ArrayNode Array List
-   */
-  private ArrayNode getRegionJson(Cluster cluster) {
-
-    Long totalHeapSize = cluster.getTotalHeapSize();
-    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
-
-    Map<String, Cluster.Region> clusterRegions = cluster.getClusterRegions();
-
-    List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
-    clusterRegionsList.addAll(clusterRegions.values());
-
-    Collections.sort(clusterRegionsList, regionEntryCountComparator);
-
-    ArrayNode regionListJson = mapper.createArrayNode();
-    for (int count = 0; count < clusterRegionsList.size(); count++) {
-      Cluster.Region reg = clusterRegionsList.get(count);
-      ObjectNode regionJSON = mapper.createObjectNode();
-
-      regionJSON.put("name", reg.getName());
-      regionJSON.put("totalMemory", totalHeapSize);
-      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
-      regionJSON.put("memberCount", reg.getMemberCount());
-
-      final String regionType = reg.getRegionType();
-      regionJSON.put("type", regionType);
-      regionJSON.put("getsRate", reg.getGetsRate());
-      regionJSON.put("putsRate", reg.getPutsRate());
-
-      Cluster.Member[] clusterMembersList = cluster.getMembers();
-
-      ArrayNode memberNameArray = mapper.createArrayNode();
-      for (String memberName : reg.getMemberName()) {
-        for (Cluster.Member member : clusterMembersList) {
-          String name = member.getName();
-          name = name.replace(":", "-");
-          String id = member.getId();
-          id = id.replace(":", "-");
-
-          if ((memberName.equals(id)) || (memberName.equals(name))) {
-            ObjectNode regionMember = mapper.createObjectNode();
-            regionMember.put("id", member.getId());
-            regionMember.put("name", member.getName());
-            memberNameArray.add(regionMember);
-            break;
-          }
-        }
-      }
-
-      regionJSON.put("memberNames", memberNameArray);
-      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
-
-      Boolean persistent = reg.getPersistentEnabled();
-      if (persistent) {
-        regionJSON.put("persistence", VALUE_ON);
-      } else {
-        regionJSON.put("persistence", VALUE_OFF);
-      }
-
-      Boolean isEnableOffHeapMemory = reg.isEnableOffHeapMemory();
-      if (isEnableOffHeapMemory) {
-        regionJSON.put("isEnableOffHeapMemory", VALUE_ON);
-      } else {
-        regionJSON.put("isEnableOffHeapMemory", VALUE_OFF);
-      }
-
-      String regCompCodec = reg.getCompressionCodec();
-      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
-        regionJSON.put("compressionCodec", reg.getCompressionCodec());
-      } else {
-        regionJSON.put("compressionCodec", VALUE_NA);
-      }
-
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
-          .getPulseProductSupport())) {
-        // Convert region path to dot separated region path
-        regionJSON.put("regionPath",
-            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
-      } else {
-        regionJSON.put("regionPath", reg.getFullPath());
-      }
-
-      regionJSON.put("memoryReadsTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
-      regionJSON.put("memoryWritesTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
-      regionJSON.put("diskReadsTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
-      regionJSON.put("diskWritesTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
-      regionJSON.put("emptyNodes", reg.getEmptyNode());
-      Long entrySize = reg.getEntrySize();
-      DecimalFormat form = new DecimalFormat(
-          PulseConstants.DECIMAL_FORMAT_PATTERN_2);
-      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
-
-      if (entrySize < 0) {
-        regionJSON.put(this.ENTRY_SIZE, VALUE_NA);
-      } else {
-        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
-      }
-      regionJSON.put("dataUsage", reg.getDiskUsage());
-      regionJSON.put("wanEnabled", reg.getWanEnabled());
-      regionJSON.put("totalDataUsage", totalDiskUsage);
-
-      regionJSON.put("memoryUsage", entrySizeInMB);
-
-      regionListJson.add(regionJSON);
-    }
-
-    return regionListJson;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionsService.java
deleted file mode 100644
index 0568451..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterRegionsService.java
+++ /dev/null
@@ -1,206 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Comparator;
-import java.util.List;
-import java.util.Map;
-
-/**
- * Class ClusterRegionsService
- * 
- * This class contains implementations of getting Cluster's regions details
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterRegions")
-@Scope("singleton")
-public class ClusterRegionsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String ENTRY_SIZE = "entrySize";
-
-  // Comparator based upon regions entry count
-  private static Comparator<Cluster.Region> regionEntryCountComparator = (r1, r2) -> {
-    long r1Cnt = r1.getSystemRegionEntryCount();
-    long r2Cnt = r2.getSystemRegionEntryCount();
-    if (r1Cnt < r2Cnt) {
-      return -1;
-    } else if (r1Cnt > r2Cnt) {
-      return 1;
-    } else {
-      return 0;
-    }
-  };
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // getting cluster's Regions
-    responseJSON.put("regions", getRegionJson(cluster));
-
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * This method is used to get various regions associated with the given
-   * cluster and create json for each region fields and returns Array List for
-   * all the regions associated with given cluster
-   * 
-   * @param cluster
-   * @return JSONObject Array List
-   */
-  private ArrayNode getRegionJson(Cluster cluster) {
-
-    Long totalHeapSize = cluster.getTotalHeapSize();
-    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
-
-    Map<String, Cluster.Region> clusterRegions = cluster.getClusterRegions();
-
-    List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
-    clusterRegionsList.addAll(clusterRegions.values());
-
-    Collections.sort(clusterRegionsList, regionEntryCountComparator);
-
-    ArrayNode regionListJson = mapper.createArrayNode();
-    for (int count = 0; count < clusterRegionsList.size(); count++) {
-      Cluster.Region reg = clusterRegionsList.get(count);
-      ObjectNode regionJSON = mapper.createObjectNode();
-
-      regionJSON.put("name", reg.getName());
-      regionJSON.put("totalMemory", totalHeapSize);
-      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
-      regionJSON.put("memberCount", reg.getMemberCount());
-
-      final String regionType = reg.getRegionType();
-      regionJSON.put("type", regionType);
-      regionJSON.put("getsRate", reg.getGetsRate());
-      regionJSON.put("putsRate", reg.getPutsRate());
-
-      Cluster.Member[] clusterMembersList = cluster.getMembers();
-
-      ArrayNode memberNameArray = mapper.createArrayNode();
-      for (String memberName : reg.getMemberName()) {
-        for (Cluster.Member member : clusterMembersList) {
-          String name = member.getName();
-          name = name.replace(":", "-");
-          String id = member.getId();
-          id = id.replace(":", "-");
-
-          if ((memberName.equals(id)) || (memberName.equals(name))) {
-            ObjectNode regionMember = mapper.createObjectNode();
-            regionMember.put("id", member.getId());
-            regionMember.put("name", member.getName());
-            memberNameArray.add(regionMember);
-            break;
-          }
-        }
-      }
-
-      regionJSON.put("memberNames", memberNameArray);
-      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
-
-      Boolean persistent = reg.getPersistentEnabled();
-      if (persistent) {
-        regionJSON.put("persistence", this.VALUE_ON);
-      } else {
-        regionJSON.put("persistence", this.VALUE_OFF);
-      }
-
-      Boolean isEnableOffHeapMemory = reg.isEnableOffHeapMemory();
-      if (isEnableOffHeapMemory) {
-        regionJSON.put("isEnableOffHeapMemory", this.VALUE_ON);
-      } else {
-        regionJSON.put("isEnableOffHeapMemory", this.VALUE_OFF);
-      }
-
-      String regCompCodec = reg.getCompressionCodec();
-      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
-        regionJSON.put("compressionCodec", reg.getCompressionCodec());
-      } else {
-        regionJSON.put("compressionCodec", this.VALUE_NA);
-      }
-
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
-        // Convert region path to dot separated region path
-        regionJSON.put("regionPath",
-            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
-        regionJSON.put("id",
-            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
-      } else {
-        regionJSON.put("regionPath", reg.getFullPath());
-        regionJSON.put("id", reg.getFullPath());
-      }
-
-      regionJSON.put("memoryReadsTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
-      regionJSON.put("memoryWritesTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
-      regionJSON.put("diskReadsTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
-      regionJSON.put("diskWritesTrend",
-          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
-      regionJSON.put("emptyNodes", reg.getEmptyNode());
-      Long entrySize = reg.getEntrySize();
-      DecimalFormat form = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN_2);
-      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
-
-      if (entrySize < 0) {
-        regionJSON.put(this.ENTRY_SIZE, this.VALUE_NA);
-      } else {
-        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
-      }
-      regionJSON.put("dataUsage", reg.getDiskUsage());
-      regionJSON.put("wanEnabled", reg.getWanEnabled());
-      regionJSON.put("totalDataUsage", totalDiskUsage);
-
-      regionJSON.put("memoryUsage", entrySizeInMB);
-
-      regionListJson.add(regionJSON);
-    }
-
-    return regionListJson;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionService.java
deleted file mode 100644
index 4dfc941..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionService.java
+++ /dev/null
@@ -1,237 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import com.vmware.geode.tools.pulse.internal.util.TimeUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Comparator;
-import java.util.List;
-
-/**
- * Class ClusterSelectedRegionService
- *
- * This class contains implementations of getting Cluster's selected region details
- *
- * @since GemFire version 7.5 cedar  2014-03-01
- */
-
-@Component
-@Service("ClusterSelectedRegion")
-@Scope("singleton")
-public class ClusterSelectedRegionService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String ENTRY_SIZE = "entrySize";
-
-  // Comparator based upon regions entry count
-  private static Comparator<Cluster.Member> memberCurrentHeapUsageComparator = (m1, m2) -> {
-    long m1HeapUsage = m1.getCurrentHeapSize();
-    long m2HeapUsage = m2.getCurrentHeapSize();
-    if (m1HeapUsage < m2HeapUsage) {
-      return -1;
-    } else if (m1HeapUsage > m2HeapUsage) {
-      return 1;
-    } else {
-      return 0;
-    }
-  };
-
-  @Override
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    String userName = request.getUserPrincipal().getName();
-    String pulseData = request.getParameter("pulseData");
-    JsonNode parameterMap = mapper.readTree(pulseData);
-    String selectedRegionFullPath = parameterMap.get("ClusterSelectedRegion").get("regionFullPath").textValue();
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // getting cluster's Regions
-    responseJSON.put("clusterName", cluster.getServerName());
-    responseJSON.put("userName", userName);
-    responseJSON.put("selectedRegion", getSelectedRegionJson(cluster, selectedRegionFullPath));
-
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * Create JSON for selected cluster region
-   *
-   * @param cluster
-   * @return ObjectNode Array List
-   */
-  private ObjectNode getSelectedRegionJson(Cluster cluster, String selectedRegionFullPath) {
-    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-    Long totalHeapSize = cluster.getTotalHeapSize();
-    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
-
-    Cluster.Region reg = cluster.getClusterRegion(selectedRegionFullPath);
-    if (reg != null){
-      ObjectNode regionJSON = mapper.createObjectNode();
-
-      regionJSON.put("name", reg.getName());
-      regionJSON.put("path", reg.getFullPath());
-      regionJSON.put("totalMemory", totalHeapSize);
-      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
-      regionJSON.put("memberCount", reg.getMemberCount());
-
-      final String regionType = reg.getRegionType();
-      regionJSON.put("type", regionType);
-      regionJSON.put("getsRate", reg.getGetsRate());
-      regionJSON.put("putsRate", reg.getPutsRate());
-      regionJSON.put("lruEvictionRate", reg.getLruEvictionRate());
-
-      DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
-      Cluster.Member[] clusterMembersList = cluster.getMembers();
-
-      // collect members of this region
-      List<Cluster.Member> clusterMembersL = new ArrayList<Cluster.Member>();
-      for (String memberName : reg.getMemberName()) {
-       for (Cluster.Member member : clusterMembersList) {
-          String name = member.getName();
-          name = name.replace(":", "-");
-          String id = member.getId();
-          id = id.replace(":", "-");
-
-          if ((memberName.equals(id)) || (memberName.equals(name))) {
-             clusterMembersL.add(member);
-          }
-        }
-      }
-
-      // sort members of this region
-      Collections.sort(clusterMembersL, memberCurrentHeapUsageComparator);
-
-      // return sorted member list by heap usage
-      ArrayNode memberArray = mapper.createArrayNode();
-      for (Cluster.Member member : clusterMembersL) {
-          ObjectNode regionMember = mapper.createObjectNode();
-          regionMember.put("memberId", member.getId());
-          regionMember.put("name", member.getName());
-          regionMember.put("host", member.getHost());
-
-          long usedHeapSize = cluster.getUsedHeapSize();
-          long currentHeap = member.getCurrentHeapSize();
-          if (usedHeapSize > 0) {
-            double heapUsage = ((double) currentHeap / (double) usedHeapSize) * 100;
-            regionMember.put("heapUsage", Double.valueOf(df2.format(heapUsage)));
-          } else {
-            regionMember.put("heapUsage", 0);
-          }
-          double currentCPUUsage = member.getCpuUsage();
-          double loadAvg = member.getLoadAverage();
-
-          regionMember.put("cpuUsage", Double.valueOf(df2.format(currentCPUUsage)));
-          regionMember.put("currentHeapUsage", member.getCurrentHeapSize());
-          regionMember.put("isManager", member.isManager());
-          regionMember.put("uptime", TimeUtils.convertTimeSecondsToHMS(member.getUptime()));
-
-          regionMember.put("loadAvg", Double.valueOf(df2.format(loadAvg)));
-          regionMember.put("sockets", member.getTotalFileDescriptorOpen());
-          regionMember.put("threads", member.getNumThreads());
-
-          if (PulseController.getPulseProductSupport().equalsIgnoreCase(
-              PulseConstants.PRODUCT_NAME_SQLFIRE)){
-            regionMember.put("clients", member.getNumSqlfireClients());
-          }else{
-            regionMember.put("clients", member.getMemberClientsHMap().size());
-          }
-          regionMember.put("queues", member.getQueueBacklog());
-          memberArray.add(regionMember);
-      }
-
-      regionJSON.put("members", memberArray);
-      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
-
-      regionJSON.put("persistence", reg.getPersistentEnabled() ? PulseService.VALUE_ON : PulseService.VALUE_OFF);
-
-      regionJSON.put("isEnableOffHeapMemory", reg.isEnableOffHeapMemory() ? PulseService.VALUE_ON : PulseService.VALUE_OFF);
-
-      String regCompCodec = reg.getCompressionCodec();
-      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
-        regionJSON.put("compressionCodec", reg.getCompressionCodec());
-      } else {
-        regionJSON.put("compressionCodec", PulseService.VALUE_NA);
-      }
-
-      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
-        // Convert region path to dot separated region path
-        regionJSON.put("regionPath", StringUtils.getTableNameFromRegionName(reg.getFullPath()));
-      } else {
-        regionJSON.put("regionPath", reg.getFullPath());
-      }
-
-      regionJSON.put("memoryReadsTrend",
-          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
-      regionJSON.put("memoryWritesTrend",
-          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
-      regionJSON.put("diskReadsTrend",
-          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
-      regionJSON.put("diskWritesTrend",
-          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
-
-      regionJSON.put("emptyNodes", reg.getEmptyNode());
-      Long entrySize = reg.getEntrySize();
-      DecimalFormat form = new DecimalFormat(
-          PulseConstants.DECIMAL_FORMAT_PATTERN_2);
-      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
-      if (entrySize < 0) {
-        regionJSON.put(this.ENTRY_SIZE, PulseService.VALUE_NA);
-      } else {
-        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
-      }
-      regionJSON.put("dataUsage", reg.getDiskUsage());
-      regionJSON.put("wanEnabled", reg.getWanEnabled());
-      regionJSON.put("totalDataUsage", totalDiskUsage);
-      regionJSON.put("memoryUsage", entrySizeInMB);
-
-      LOGGER.fine("calling getSelectedRegionJson :: regionJSON = " + regionJSON);
-      return regionJSON;
-    } else {
-      ObjectNode responseJSON = mapper.createObjectNode();
-      responseJSON.put("errorOnRegion", "Region [" + selectedRegionFullPath + "] is not available");
-      return responseJSON;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
deleted file mode 100644
index 1f3ffd6..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
+++ /dev/null
@@ -1,143 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Cluster.RegionOnMember;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.Comparator;
-import java.util.List;
-
-/**
- * Class ClusterSelectedRegionsMemberService
- *
- * This class contains implementations of getting Cluster's selected region's member specific details
- * for all members in that region
- *
- * @since GemFire version 7.5 cedar 2014-03-01
- */
-
-@Component
-@Service("ClusterSelectedRegionsMember")
-@Scope("singleton")
-public class ClusterSelectedRegionsMemberService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  //Comparator based upon regions entry count
-  private static Comparator<Cluster.RegionOnMember> romEntryCountComparator = (m1, m2) -> {
-      long m1EntryCount = m1.getEntryCount();
-      long m2EntryCount = m2.getEntryCount();
-      if (m1EntryCount < m2EntryCount) {
-        return -1;
-      } else if (m1EntryCount > m2EntryCount) {
-        return 1;
-      } else {
-        return 0;
-      }
-    };
-
-  @Override
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-    String userName = request.getUserPrincipal().getName();
-    String pulseData = request.getParameter("pulseData");
-    JsonNode parameterMap = mapper.readTree(pulseData);
-    String selectedRegionFullPath = parameterMap.get("ClusterSelectedRegionsMember").get("regionFullPath").textValue();
-    LOGGER.finest("ClusterSelectedRegionsMemberService selectedRegionFullPath = " + selectedRegionFullPath);
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // getting cluster's Regions
-    responseJSON.put("clusterName", cluster.getServerName());
-    responseJSON.put("userName", userName);
-    responseJSON.put("selectedRegionsMembers", getSelectedRegionsMembersJson(cluster, selectedRegionFullPath));
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * Create JSON for selected cluster region's all members
-   */
-  private ObjectNode getSelectedRegionsMembersJson(Cluster cluster, String selectedRegionFullPath) {
-    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-    Cluster.Region reg = cluster.getClusterRegion(selectedRegionFullPath);
-
-    if (reg != null){
-      ObjectNode regionMemberJSON = mapper.createObjectNode();
-      RegionOnMember[] regionOnMembers = reg.getRegionOnMembers();
-
-      //sort on entry count
-      List<RegionOnMember> romList = Arrays.asList(regionOnMembers);
-      Collections.sort(romList, romEntryCountComparator);
-
-      for(RegionOnMember rom : romList) {
-        ObjectNode memberJSON = mapper.createObjectNode();
-        memberJSON.put("memberName", rom.getMemberName());
-        memberJSON.put("regionFullPath", rom.getRegionFullPath());
-        memberJSON.put("entryCount", rom.getEntryCount());
-        memberJSON.put("entrySize", rom.getEntrySize());
-
-        memberJSON.put("accessor", ((rom.getLocalMaxMemory() == 0) ? "True" : "False"));
-        LOGGER.finest("calling getSelectedRegionsMembersJson :: rom.getLocalMaxMemory() = " + rom.getLocalMaxMemory());
-
-        memberJSON.put("memoryReadsTrend",
-            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND)));
-        LOGGER.finest("memoryReadsTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND).length);
-
-        memberJSON.put("memoryWritesTrend",
-            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND)));
-        LOGGER.finest("memoryWritesTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND).length);
-
-        memberJSON.put("diskReadsTrend",
-            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND)));
-        LOGGER.finest("diskReadsTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND).length);
-
-        memberJSON.put("diskWritesTrend",
-            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND)));
-        LOGGER.finest("diskWritesTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND).length);
-
-        regionMemberJSON.put(rom.getMemberName(), memberJSON);
-      }
-
-      LOGGER.fine("calling getSelectedRegionsMembersJson :: regionJSON = " + regionMemberJSON);
-      return regionMemberJSON;
-    } else {
-      ObjectNode responseJSON = mapper.createObjectNode();
-      responseJSON.put("errorOnRegion", "Region [" + selectedRegionFullPath + "] is not available");
-      return responseJSON;
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterWANInfoService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterWANInfoService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterWANInfoService.java
deleted file mode 100644
index 7e26724..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterWANInfoService.java
+++ /dev/null
@@ -1,75 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.util.Map;
-
-/**
- * Class ClusterWANInfoService
- * 
- * This class contains implementations of getting Cluster's WAN Informations
- * (connected clusters)
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("ClusterWANInfo")
-@Scope("singleton")
-public class ClusterWANInfoService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // members list
-    ArrayNode connectedClusterListJson = mapper.createArrayNode();
-
-    for (Map.Entry<String, Boolean> entry : cluster.getWanInformation()
-        .entrySet()) {
-      ObjectNode clusterJSON = mapper.createObjectNode();
-      clusterJSON.put("clusterId", entry.getKey());
-      clusterJSON.put("name", entry.getKey());
-      clusterJSON.put("status", entry.getValue());
-
-      connectedClusterListJson.add(clusterJSON);
-    }
-    // Response JSON
-    responseJSON.put("connectedClusters", connectedClusterListJson);
-    // Send json response
-    return responseJSON;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberAsynchEventQueuesService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
deleted file mode 100644
index 5fe6785..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
+++ /dev/null
@@ -1,99 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberAsynchEventQueuesService
- * 
- * This class contains implementations of getting Asynchronous Event Queues
- * details of Cluster Member.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberAsynchEventQueues")
-@Scope("singleton")
-public class MemberAsynchEventQueuesService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberAsynchEventQueues").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      Cluster.AsyncEventQueue[] asyncEventQueues = clusterMember
-          .getMemberAsyncEventQueueList();
-      ArrayNode asyncEventQueueJsonList = mapper.createArrayNode();
-
-      if (asyncEventQueues != null && asyncEventQueues.length > 0) {
-        responseJSON.put("isAsyncEventQueuesPresent", true);
-
-        for (Cluster.AsyncEventQueue asyncEventQueue : asyncEventQueues) {
-          ObjectNode asyncEventQueueJSON = mapper.createObjectNode();
-          asyncEventQueueJSON.put("id", asyncEventQueue.getId());
-          asyncEventQueueJSON.put("primary", asyncEventQueue.getPrimary());
-          asyncEventQueueJSON.put("senderType", asyncEventQueue.isParallel());
-          asyncEventQueueJSON
-              .put("batchSize", asyncEventQueue.getBatchSize());
-          asyncEventQueueJSON.put("batchTimeInterval",
-              asyncEventQueue.getBatchTimeInterval());
-          asyncEventQueueJSON.put("batchConflationEnabled",
-              asyncEventQueue.isBatchConflationEnabled());
-          asyncEventQueueJSON.put("asyncEventListener",
-              asyncEventQueue.getAsyncEventListener());
-          asyncEventQueueJSON.put("queueSize",
-              asyncEventQueue.getEventQueueSize());
-
-          asyncEventQueueJsonList.add(asyncEventQueueJSON);
-        }
-        responseJSON.put("asyncEventQueues", asyncEventQueueJsonList);
-      } else {
-        responseJSON.put("isAsyncEventQueuesPresent", false);
-      }
-
-    }
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberClientsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberClientsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberClientsService.java
deleted file mode 100644
index 41f3684..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberClientsService.java
+++ /dev/null
@@ -1,101 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import com.vmware.geode.tools.pulse.internal.util.TimeUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberClientsService
- * 
- * This class contains implementations of getting Memeber's Clients.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberClients")
-@Scope("singleton")
-public class MemberClientsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String NAME = "name";
-  private final String HOST = "host";
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberClients").get("memberName").textValue();
-
-    ArrayNode clientListJson = mapper.createArrayNode();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-    if (clusterMember != null) {
-      responseJSON.put("memberId", clusterMember.getId());
-      responseJSON.put(this.NAME, clusterMember.getName());
-      responseJSON.put(this.HOST, clusterMember.getHost());
-
-      // member's clients
-
-      Cluster.Client[] memberClients = clusterMember.getMemberClients();
-      for (Cluster.Client memberClient : memberClients) {
-        ObjectNode regionJSON = mapper.createObjectNode();
-        regionJSON.put("clientId", memberClient.getId());
-        regionJSON.put(this.NAME, memberClient.getName());
-        regionJSON.put(this.HOST, memberClient.getHost());
-        regionJSON.put("queueSize", memberClient.getQueueSize());
-        regionJSON.put("clientCQCount", memberClient.getClientCQCount());
-        regionJSON.put("isConnected", memberClient.isConnected() ? "Yes" : "No");
-        regionJSON.put("isSubscriptionEnabled", memberClient.isSubscriptionEnabled() ? "Yes" : "No");
-        regionJSON.put("uptime", TimeUtils.convertTimeSecondsToHMS(memberClient.getUptime()));
-
-        regionJSON.put("cpuUsage", String.format("%.4f", memberClient.getCpuUsage()).toString());
-        // regionJSON.put("cpuUsage", memberClient.getCpuUsage());
-        regionJSON.put("threads", memberClient.getThreads());
-        regionJSON.put("gets", memberClient.getGets());
-        regionJSON.put("puts", memberClient.getPuts());
-
-        clientListJson.add(regionJSON);
-      }
-      responseJSON.put("memberClients", clientListJson);
-    }
-    // Send json response
-    return responseJSON;
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDetailsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDetailsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDetailsService.java
deleted file mode 100644
index c4f2ff7..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDetailsService.java
+++ /dev/null
@@ -1,122 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-
-/**
- * Class MemberDetailsService
- * 
- * This class contains implementations of getting Memeber's Statistics.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberDetails")
-@Scope("singleton")
-public class MemberDetailsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    String userName = request.getUserPrincipal().getName();
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberDetails").get("memberName").textValue();
-    DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils
-        .makeCompliantName(memberName));
-    if (clusterMember != null) {
-      responseJSON.put("memberId", clusterMember.getId());
-      responseJSON.put("name", clusterMember.getName());
-      responseJSON.put("host", clusterMember.getHost());
-      responseJSON.put("clusterId", cluster.getId());
-      responseJSON.put("clusterName", cluster.getServerName());
-      responseJSON.put("userName", userName);
-      double loadAvg = clusterMember.getLoadAverage();
-      responseJSON.put("loadAverage", Double.valueOf(df2.format(loadAvg)));
-      responseJSON.put("sockets", clusterMember.getTotalFileDescriptorOpen());
-      responseJSON.put("threads", clusterMember.getNumThreads());
-      responseJSON.put("offHeapFreeSize", clusterMember.getOffHeapFreeSize());
-      responseJSON.put("offHeapUsedSize", clusterMember.getOffHeapUsedSize());
-      responseJSON.put("regionsCount", clusterMember.getMemberRegionsList().length);
-
-      // Number of member clients
-      if (PulseController.getPulseProductSupport().equalsIgnoreCase(
-          PulseConstants.PRODUCT_NAME_SQLFIRE)){
-        responseJSON.put("numClients", clusterMember.getNumSqlfireClients());
-      } else {
-        responseJSON.put("numClients", clusterMember.getMemberClientsHMap().size());
-      }
-
-      Long diskUsageVal = clusterMember.getTotalDiskUsage();
-      Double diskUsage = diskUsageVal.doubleValue() / 1024;
-
-      responseJSON.put("diskStorageUsed", Double.valueOf(df2.format(diskUsage)));
-
-      Cluster.Alert[] alertsList = cluster.getAlertsList();
-
-      String status = "Normal";
-
-      for (Cluster.Alert alert : alertsList) {
-        if (clusterMember.getName().equals(alert.getMemberName())) {
-          if (alert.getSeverity() == Cluster.Alert.SEVERE) {
-            status = "Severe";
-            break;
-          } else if (alert.getSeverity() == Cluster.Alert.ERROR) {
-            status = "Error";
-          } else if (alert.getSeverity() == Cluster.Alert.WARNING) {
-            status = "Warning";
-          }
-        }
-      }
-
-      responseJSON.put("status", status);
-
-    } else {
-      responseJSON.put("errorOnMember", "Member [" + memberName
-          + "] is not available");
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDiskThroughputService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDiskThroughputService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDiskThroughputService.java
deleted file mode 100644
index 2dd8b55..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberDiskThroughputService.java
+++ /dev/null
@@ -1,76 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberDiskThroughputService
- * 
- * This class contains implementations for getting Memeber's current Disk
- * Throughput trends over the time.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberDiskThroughput")
-@Scope("singleton")
-public class MemberDiskThroughputService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // members list
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberDiskThroughput").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      responseJSON.put("throughputWrites", clusterMember.getThroughputWrites());
-      responseJSON.put("throughputWritesTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_THROUGHPUT_WRITES)));
-      responseJSON.put("throughputReads", clusterMember.getThroughputWrites());
-      responseJSON.put("throughputReadsTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_THROUGHPUT_READS)));
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGCPausesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGCPausesService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGCPausesService.java
deleted file mode 100644
index 5b34c73..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGCPausesService.java
+++ /dev/null
@@ -1,73 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberGCPausesService
- * 
- * This class contains implementations of getting Memeber's GC Pauses (JVM
- * Pauses) details and its trend over the time.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("MemberGCPauses")
-@Scope("singleton")
-public class MemberGCPausesService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // members list
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberGCPauses").get("memberName").textValue();
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      responseJSON.put("gcPausesTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_GARBAGE_COLLECTION)));
-      responseJSON.put("gcPausesCount", clusterMember.getGarbageCollectionCount());
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}


[12/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMap.java
index cce0b73..ebb2627 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMap.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.CacheCallback;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.internal.cache.AbstractRegionMap.ARMLockTestHook;
-import com.gemstone.gemfire.internal.cache.lru.LRUMapCallbacks;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionHolder;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.cache.CacheCallback;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.internal.cache.AbstractRegionMap.ARMLockTestHook;
+import org.apache.geode.internal.cache.lru.LRUMapCallbacks;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionHolder;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * Internal interface used by {@link LocalRegion} to access the map that holds

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMapFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMapFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMapFactory.java
index cfbe4e6..305bfd7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMapFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionMapFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueue.java
index 44e03bd..50b0296 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueue.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueueException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueueException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueueException.java
index ed6c7e5..97b6296 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueueException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionQueueException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.CacheException;
+import org.apache.geode.cache.CacheException;
 /**
  * An exception thrown by a <code>RegionQueue</code>.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionStatus.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionStatus.java
index 80a16ac..6983abc 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionStatus.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionStatus.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.Region;
 
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RegionTTLExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionTTLExpiryTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionTTLExpiryTask.java
index d8fd905..991966c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionTTLExpiryTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionTTLExpiryTask.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
+import org.apache.geode.cache.*;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ReleaseClearLockMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ReleaseClearLockMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ReleaseClearLockMessage.java
index 0596dd8..d477d37 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ReleaseClearLockMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ReleaseClearLockMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,17 +23,17 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 public class ReleaseClearLockMessage extends
   HighPriorityDistributionMessage implements MessageWithReply {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableDistributionData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableDistributionData.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableDistributionData.java
index a60b7f9..70f8892 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableDistributionData.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableDistributionData.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueue.java
index f26470d..a2f1c5d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueue.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.Role;
+import org.apache.geode.distributed.Role;
 
 import java.util.Set;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactory.java
index 5a86a8f..6103e20 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Represents a factory for instances of {@link ReliableMessageQueue}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactoryImpl.java
index 57ed7d0..8c25554 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ReliableMessageQueueFactoryImpl.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteContainsKeyValueMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteContainsKeyValueMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteContainsKeyValueMessage.java
index d5a52d4..392f8bf 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteContainsKeyValueMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteContainsKeyValueMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,23 +24,23 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is used be a replicate region to send a contains key/value request
@@ -69,8 +69,8 @@ public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageW
 
   /**
    * Sends a ReplicateRegion message for either
-   * {@link com.gemstone.gemfire.cache.Region#containsKey(Object)}or
-   * {@link com.gemstone.gemfire.cache.Region#containsValueForKey(Object)}
+   * {@link org.apache.geode.cache.Region#containsKey(Object)}or
+   * {@link org.apache.geode.cache.Region#containsValueForKey(Object)}
    * depending on the <code>valueCheck</code> argument
    * 
    * @param recipient
@@ -81,9 +81,9 @@ public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageW
    *          the key to be queried
    * @param valueCheck
    *          true if
-   *          {@link com.gemstone.gemfire.cache.Region#containsValueForKey(Object)}
+   *          {@link org.apache.geode.cache.Region#containsValueForKey(Object)}
    *          is desired, false if
-   *          {@link com.gemstone.gemfire.cache.Region#containsKey(Object)}is
+   *          {@link org.apache.geode.cache.Region#containsKey(Object)}is
    *          desired
    * @return the processor used to read the returned keys
    */
@@ -270,7 +270,7 @@ public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageW
 
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.RemoteContainsKeyValueMessage.RemoteContainsKeyValueReplyMessage}
+   * org.apache.geode.internal.cache.RemoteContainsKeyValueMessage.RemoteContainsKeyValueReplyMessage}
    * 
    * @since GemFire 6.5
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteDestroyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteDestroyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteDestroyMessage.java
index 2bec70f..cf0fca2 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteDestroyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteDestroyMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,42 +27,42 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.OldValueImporter;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_OBJECT;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.EntryEventImpl.OldValueImporter;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_OBJECT;
 
 /**
  * A class that specifies a destroy operation.
@@ -299,7 +299,7 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
 
   /**
    * Sends a RemoteDestroyMessage
-   * {@link com.gemstone.gemfire.cache.Region#destroy(Object)}message to the
+   * {@link org.apache.geode.cache.Region#destroy(Object)}message to the
    * recipient
    * 
    * @param recipient the recipient of the message
@@ -309,7 +309,7 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
    * @param processorType the type of executor to use in processing the message
    * @param useOriginRemote TODO
    * @return the processor used to await the potential
-   *         {@link com.gemstone.gemfire.cache.CacheException}
+   *         {@link org.apache.geode.cache.CacheException}
    */
   public static RemoteDestroyReplyProcessor send(DistributedMember recipient,
                                        LocalRegion r,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchEntryMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchEntryMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchEntryMessage.java
index b7a4a81..6bbf8f9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchEntryMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchEntryMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,34 +25,34 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.OperationCancelledException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.OperationCancelledException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is used as the request for a
- * {@link com.gemstone.gemfire.cache.Region#getEntry(Object)}operation. The
+ * {@link org.apache.geode.cache.Region#getEntry(Object)}operation. The
  * reply is sent in a {@link 
- * com.gemstone.gemfire.internal.cache.RemoteFetchEntryMessage.FetchEntryReplyMessage}.
+ * org.apache.geode.internal.cache.RemoteFetchEntryMessage.FetchEntryReplyMessage}.
  * 
  * @since GemFire 5.1
  */
@@ -76,7 +76,7 @@ public final class RemoteFetchEntryMessage extends RemoteOperationMessage
 
   /**
    * Sends a LocalRegion
-   * {@link com.gemstone.gemfire.cache.Region#getEntry(Object)} message   
+   * {@link org.apache.geode.cache.Region#getEntry(Object)} message   
    * 
    * @param recipient
    *          the member that the getEntry message is sent to
@@ -309,7 +309,7 @@ public final class RemoteFetchEntryMessage extends RemoteOperationMessage
 
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.RemoteFetchEntryMessage.FetchEntryReplyMessage}
+   * org.apache.geode.internal.cache.RemoteFetchEntryMessage.FetchEntryReplyMessage}
    * 
    */
   public static class FetchEntryResponse extends RemoteOperationResponse

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchVersionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchVersionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchVersionMessage.java
index 124c9b5..4209d57 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchVersionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteFetchVersionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,22 +24,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is used to request a VersionTag from a remote member.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteGetMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteGetMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteGetMessage.java
index 05d62d4..47f509c 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteGetMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteGetMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,35 +25,35 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.BucketRegion.RawValue;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.util.BlobHelper;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.BucketRegion.RawValue;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.util.BlobHelper;
 
 /**
  * This message is used as the request for a
- * {@link com.gemstone.gemfire.cache.Region#get(Object)}operation. The reply is
- * sent in a {@link com.gemstone.gemfire.internal.cache.RemoteGetMessage.GetReplyMessage}. 
+ * {@link org.apache.geode.cache.Region#get(Object)}operation. The reply is
+ * sent in a {@link org.apache.geode.internal.cache.RemoteGetMessage.GetReplyMessage}. 
  * 
  * Replicate regions can use this message to send a Get request to another peer.
  * 
@@ -187,7 +187,7 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
 
   /**
    * Sends a ReplicateRegion
-   * {@link com.gemstone.gemfire.cache.Region#get(Object)} message   
+   * {@link org.apache.geode.cache.Region#get(Object)} message   
    * 
    * @param recipient
    *          the member that the get message is sent to
@@ -218,10 +218,10 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
 
   /**
    * This message is used for the reply to a
-   * {@link com.gemstone.gemfire.cache.Region#get(Object)}operation This is the
+   * {@link org.apache.geode.cache.Region#get(Object)}operation This is the
    * reply to a {@link RemoteGetMessage}.
    * 
-   * Since the {@link com.gemstone.gemfire.cache.Region#get(Object)}operation
+   * Since the {@link org.apache.geode.cache.Region#get(Object)}operation
    * is used <bold>very </bold> frequently the performance of this class is
    * critical.
    * 
@@ -358,7 +358,7 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
 
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.RemoteGetMessage.GetReplyMessage}
+   * org.apache.geode.internal.cache.RemoteGetMessage.GetReplyMessage}
    * 
    * @since GemFire 5.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteInvalidateMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteInvalidateMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteInvalidateMessage.java
index a4e020e..1366dd7 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteInvalidateMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteInvalidateMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,41 +27,41 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
 
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
 
 public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
 
   private static final Logger logger = LogService.getLogger();
   
   /**
-   * Empty constructor to satisfy {@link com.gemstone.gemfire.DataSerializer}
+   * Empty constructor to satisfy {@link org.apache.geode.DataSerializer}
    * requirements
    */
   public RemoteInvalidateMessage() {
@@ -139,7 +139,7 @@ public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
 
   /**
    * Sends a transactional RemoteInvalidateMessage
-   * {@link com.gemstone.gemfire.cache.Region#invalidate(Object)}message to the
+   * {@link org.apache.geode.cache.Region#invalidate(Object)}message to the
    * recipient
    * 
    * @param recipient the recipient of the message
@@ -149,7 +149,7 @@ public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
    * @param processorType the type of executor to use
    * @param useOriginRemote whether the receiver should use originRemote=true in its event
    * @return the InvalidateResponse processor used to await the potential
-   *         {@link com.gemstone.gemfire.cache.CacheException}
+   *         {@link org.apache.geode.cache.CacheException}
    */
   public static InvalidateResponse send(DistributedMember recipient,
       LocalRegion r, EntryEventImpl event, int processorType,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationException.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationException.java
index dfaa6c0..6f6bc09 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationException.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.internal.Assert;
 
 /**
  * Indicates that the current non-partitioned region operation failed fatally.
  * 
- * @see com.gemstone.gemfire.internal.cache.RemoteOperationMessage
+ * @see org.apache.geode.internal.cache.RemoteOperationMessage
  * @since GemFire 6.5
  */
 public class RemoteOperationException extends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessage.java
index c6ec0ab..afbf4b6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,34 +24,34 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.LowMemoryException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.LowMemoryException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.partitioned.PutMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * The base PartitionedRegion message type upon which other messages should be
@@ -170,7 +170,7 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
 
   /**
    * @param processorId1 the {@link 
-   * com.gemstone.gemfire.distributed.internal.ReplyProcessor21} id associated 
+   * org.apache.geode.distributed.internal.ReplyProcessor21} id associated 
    * with the message, null if no acknowlegement is required.
    */
   public final void registerProcessor(int processorId1)
@@ -371,7 +371,7 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
 
   /**
    * Fill out this instance of the message using the <code>DataInput</code>
-   * Required to be a {@link com.gemstone.gemfire.DataSerializable}Note: must
+   * Required to be a {@link org.apache.geode.DataSerializable}Note: must
    * be symmetric with {@link #toData(DataOutput)}in what it reads
    */
   @Override
@@ -389,7 +389,7 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
   
   /**
    * Send the contents of this instance to the DataOutput Required to be a
-   * {@link com.gemstone.gemfire.DataSerializable}Note: must be symmetric with
+   * {@link org.apache.geode.DataSerializable}Note: must be symmetric with
    * {@link #fromData(DataInput)}in what it writes
    */
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessageWithDirectReply.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessageWithDirectReply.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessageWithDirectReply.java
index 191cafb..15073b5 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessageWithDirectReply.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteOperationMessageWithDirectReply.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.DirectReplyMessage;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.DirectReplyMessage;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 /**
  * Used for partitioned region messages which support direct ack responses.
@@ -31,7 +31,7 @@ import com.gemstone.gemfire.internal.cache.PartitionedRegion;
  * or responses which are small.
  * 
  * Messages that extend this class *must* reply using the ReplySender returned
- * by {@link DistributionMessage#getReplySender(com.gemstone.gemfire.distributed.internal.DM)}
+ * by {@link DistributionMessage#getReplySender(org.apache.geode.distributed.internal.DM)}
  * 
  * Additionally, if the ReplyProcessor used for this message extends PartitionResponse, it should
  * pass false for the register parameter of the PartitionResponse.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutAllMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutAllMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutAllMessage.java
index c0c56c9..d0b92c7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutAllMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutAllMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,38 +28,38 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.EntryVersionsList;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllEntryData;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.EntryVersionsList;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllEntryData;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * A Replicate Region putAll message.  Meant to be sent only to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutMessage.java
index 34d3585..46b6f63 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemotePutMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,46 +27,46 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.NewValueImporter;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.OldValueImporter;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
-
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
-import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALUE_IS_OBJECT;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.EntryEventImpl.NewValueImporter;
+import org.apache.geode.internal.cache.EntryEventImpl.OldValueImporter;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.internal.util.Breadcrumbs;
+
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_OLD_VALUE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_BYTES;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_SERIALIZED_OBJECT;
+import static org.apache.geode.internal.cache.DistributedCacheOperation.VALUE_IS_OBJECT;
 
 /**
  * A Replicate Region update message.  Meant to be sent only to
@@ -372,7 +372,7 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
 
   /**
    * Sends a ReplicateRegion
-   * {@link com.gemstone.gemfire.cache.Region#put(Object, Object)} message to
+   * {@link org.apache.geode.cache.Region#put(Object, Object)} message to
    * the recipient
    * @param recipient the member to which the put message is sent
    * @param r  the PartitionedRegion for which the put was performed
@@ -398,7 +398,7 @@ public final class RemotePutMessage extends RemoteOperationMessageWithDirectRepl
 
   /**
    * Sends a ReplicateRegion
-   * {@link com.gemstone.gemfire.cache.Region#put(Object, Object)} message to
+   * {@link org.apache.geode.cache.Region#put(Object, Object)} message to
    * the recipient
    * @param recipient the member to which the put message is sent
    * @param r  the PartitionedRegion for which the put was performed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRegionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRegionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRegionOperation.java
index 2729156..c58b207 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRegionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRegionOperation.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,18 +24,18 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is used be a replicate region to perform region-level ops like

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRemoveAllMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRemoveAllMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRemoveAllMessage.java
index da60a98..8a04733 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRemoveAllMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RemoteRemoveAllMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,38 +28,38 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.EntryVersionsList;
-import com.gemstone.gemfire.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.EntryVersionsList;
+import org.apache.geode.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * A Replicate Region removeAll message.  Meant to be sent only to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/RoleEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RoleEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RoleEventImpl.java
index b5b03eb..b268df9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RoleEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RoleEventImpl.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.*;
 import java.util.*;
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RoleEvent;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RoleEvent;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.membership.InternalRole;
 
 /**
  * Implementation of a RoleEvent.  Super class is DataSerializable but

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/SearchLoadAndWriteProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/SearchLoadAndWriteProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/SearchLoadAndWriteProcessor.java
index 4f49ccf..ee46255 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/SearchLoadAndWriteProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/SearchLoadAndWriteProcessor.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /* enumerate each imported class because conflict with dl.u.c.TimeoutException */
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/SendQueueOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/SendQueueOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/SendQueueOperation.java
index 5ea926f..93d7744 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/SendQueueOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/SendQueueOperation.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.*;
 import java.io.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.*;
-import com.gemstone.gemfire.distributed.internal.*;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.*;
+import org.apache.geode.distributed.internal.*;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/SerializationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/SerializationHelper.java b/geode-core/src/main/java/org/apache/geode/internal/cache/SerializationHelper.java
index dd8214a..ebb3990 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/SerializationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/SerializationHelper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 public interface SerializationHelper {
 
     public byte[] convertObject2Bytes(Object obj);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/ServerPingMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ServerPingMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ServerPingMessage.java
index c6c9b1f..a836878 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ServerPingMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ServerPingMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,15 +22,15 @@ import java.io.IOException;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.Version;
 
 /**
  * Ping to check if a server is alive. It waits for a specified 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/StateFlushOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/StateFlushOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/StateFlushOperation.java
index da35c86..7560f8a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/StateFlushOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/StateFlushOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,26 +28,26 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This operation ensures that a particular member has seen all state

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/StoreAllCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/StoreAllCachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/StoreAllCachedDeserializable.java
index 4fe3a1e..fb2d964 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/StoreAllCachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/StoreAllCachedDeserializable.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
 
 /**
  * This cache deserializable always keeps its byte[] in serialized form

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXBucketRegionState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXBucketRegionState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXBucketRegionState.java
index dab7c70..7f82d66 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXBucketRegionState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXBucketRegionState.java
@@ -17,7 +17,7 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  *


[62/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGatewayHubService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGatewayHubService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGatewayHubService.java
new file mode 100644
index 0000000..51abb3f
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGatewayHubService.java
@@ -0,0 +1,149 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+
+/**
+ * Class MemberGatewayHubService
+ * 
+ * This class contains implementations of getting Gateway Receivers and Senders
+ * details of Cluster Member.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberGatewayHub")
+@Scope("singleton")
+public class MemberGatewayHubService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberGatewayHub").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils
+        .makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      // get gateway receiver
+      Cluster.GatewayReceiver gatewayReceiver = clusterMember.getGatewayReceiver();
+
+      Boolean isGateway = false;
+
+      if (gatewayReceiver != null) {
+        responseJSON.put("isGatewayReceiver", true);
+        responseJSON.put("listeningPort", gatewayReceiver.getListeningPort());
+        responseJSON.put("linkTroughput", gatewayReceiver.getLinkThroughput());
+        responseJSON.put("avgBatchLatency", gatewayReceiver.getAvgBatchProcessingTime());
+      } else {
+        responseJSON.put("isGatewayReceiver", false);
+      }
+
+      // get gateway senders
+      Cluster.GatewaySender[] gatewaySenders = clusterMember.getMemberGatewaySenders();
+
+      if (gatewaySenders.length > 0) {
+        isGateway = true;
+      }
+      responseJSON.put("isGatewaySender", isGateway);
+      // Senders
+      ArrayNode gatewaySendersJsonList = mapper.createArrayNode();
+
+      for (Cluster.GatewaySender gatewaySender : gatewaySenders) {
+        ObjectNode gatewaySenderJSON = mapper.createObjectNode();
+        gatewaySenderJSON.put("id", gatewaySender.getId());
+        gatewaySenderJSON.put("queueSize", gatewaySender.getQueueSize());
+        gatewaySenderJSON.put("status", gatewaySender.getStatus());
+        gatewaySenderJSON.put("primary", gatewaySender.getPrimary());
+        gatewaySenderJSON.put("senderType", gatewaySender.getSenderType());
+        gatewaySenderJSON.put("batchSize", gatewaySender.getBatchSize());
+        gatewaySenderJSON.put("PersistenceEnabled", gatewaySender.getPersistenceEnabled());
+        gatewaySenderJSON.put("remoteDSId", gatewaySender.getRemoteDSId());
+        gatewaySenderJSON.put("eventsExceedingAlertThreshold", gatewaySender.getEventsExceedingAlertThreshold());
+
+        gatewaySendersJsonList.add(gatewaySenderJSON);
+      }
+      // senders response
+      responseJSON.put("gatewaySenders", gatewaySendersJsonList);
+
+      // async event queues
+      Cluster.AsyncEventQueue[] asyncEventQueues = clusterMember.getMemberAsyncEventQueueList();
+      ArrayNode asyncEventQueueJsonList = mapper.createArrayNode();
+
+      for (Cluster.AsyncEventQueue asyncEventQueue : asyncEventQueues) {
+        ObjectNode asyncEventQueueJSON = mapper.createObjectNode();
+        asyncEventQueueJSON.put("id", asyncEventQueue.getId());
+        asyncEventQueueJSON.put("primary", asyncEventQueue.getPrimary());
+        asyncEventQueueJSON.put("senderType", asyncEventQueue.isParallel());
+        asyncEventQueueJSON.put("batchSize", asyncEventQueue.getBatchSize());
+        asyncEventQueueJSON.put("batchTimeInterval", asyncEventQueue.getBatchTimeInterval());
+        asyncEventQueueJSON.put("batchConflationEnabled", asyncEventQueue.isBatchConflationEnabled());
+        asyncEventQueueJSON.put("asyncEventListener", asyncEventQueue.getAsyncEventListener());
+        asyncEventQueueJSON.put("queueSize", asyncEventQueue.getEventQueueSize());
+
+        asyncEventQueueJsonList.add(asyncEventQueueJSON);
+      }
+      responseJSON.put("asyncEventQueues", asyncEventQueueJsonList);
+
+      Map<String,Cluster.Region> clusterRegions = cluster.getClusterRegions();
+
+      List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
+      clusterRegionsList.addAll(clusterRegions.values());
+
+      ArrayNode regionsList = mapper.createArrayNode();
+
+      for (Cluster.Region region : clusterRegionsList) {
+        if (region.getWanEnabled()) {
+          ObjectNode regionJSON = mapper.createObjectNode();
+          regionJSON.put("name", region.getName());
+          regionsList.add(regionJSON);
+        }
+      }
+      responseJSON.put("regionsInvolved", regionsList);
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberHeapUsageService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberHeapUsageService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberHeapUsageService.java
new file mode 100644
index 0000000..825413b
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberHeapUsageService.java
@@ -0,0 +1,73 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberHeapUsageService
+ * 
+ * This class contains implementations of getting Memeber's current Heap Usage
+ * and its trend over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberHeapUsage")
+@Scope("singleton")
+public class MemberHeapUsageService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // members list
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberHeapUsage").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      responseJSON.put("heapUsageTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_HEAP_USAGE_SAMPLE)));
+      responseJSON.put("currentHeapUsage", clusterMember.getCurrentHeapSize());
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberKeyStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberKeyStatisticsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberKeyStatisticsService.java
new file mode 100644
index 0000000..c7006c8
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberKeyStatisticsService.java
@@ -0,0 +1,76 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberKeyStatisticsService
+ * 
+ * This class contains implementations of getting Member's CPU, Memory and Read
+ * Write details
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberKeyStatistics")
+@Scope("singleton")
+public class MemberKeyStatisticsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberKeyStatistics").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      responseJSON.put("cpuUsageTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_CPU_USAGE_SAMPLE)));
+      responseJSON.put("memoryUsageTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_HEAP_USAGE_SAMPLE)));
+      responseJSON.put("readPerSecTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_GETS_PER_SECOND)));
+      responseJSON.put("writePerSecTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_PUTS_PER_SECOND)));
+    }
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberRegionsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberRegionsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberRegionsService.java
new file mode 100644
index 0000000..9181386
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberRegionsService.java
@@ -0,0 +1,127 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+
+/**
+ * Class MemberRegionsService
+ * 
+ * This class contains implementations of getting Memeber's Regions details.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("MemberRegions")
+@Scope("singleton")
+public class MemberRegionsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String NAME = "name";
+  private final String ENTRY_SIZE = "entrySize";
+  private final String DISC_STORE_NAME = "diskStoreName";
+  private final String DISC_SYNCHRONOUS = "diskSynchronous";
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberRegions").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      responseJSON.put("memberId", clusterMember.getId());
+      responseJSON.put(this.NAME, clusterMember.getName());
+      responseJSON.put("host", clusterMember.getHost());
+
+      // member's regions
+      Cluster.Region[] memberRegions = clusterMember.getMemberRegionsList();
+      ArrayNode regionsListJson = mapper.createArrayNode();
+      for (Cluster.Region memberRegion : memberRegions) {
+        ObjectNode regionJSON = mapper.createObjectNode();
+        regionJSON.put(this.NAME, memberRegion.getName());
+
+        if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
+          // Convert region path to dot separated region path
+          regionJSON.put("fullPath", StringUtils.getTableNameFromRegionName(memberRegion.getFullPath()));
+        } else {
+          regionJSON.put("fullPath", memberRegion.getFullPath());
+        }
+
+        regionJSON.put("type", memberRegion.getRegionType());
+        regionJSON.put("entryCount", memberRegion.getSystemRegionEntryCount());
+        Long entrySize = memberRegion.getEntrySize();
+
+        DecimalFormat form = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN_2);
+        String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
+
+        if (entrySize < 0) {
+          regionJSON.put(this.ENTRY_SIZE, this.VALUE_NA);
+        } else {
+          regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
+        }
+        regionJSON.put("scope", memberRegion.getScope());
+        String diskStoreName = memberRegion.getDiskStoreName();
+        if (StringUtils.isNotNullNotEmptyNotWhiteSpace(diskStoreName)) {
+          regionJSON.put(this.DISC_STORE_NAME, diskStoreName);
+          regionJSON.put(this.DISC_SYNCHRONOUS,
+              memberRegion.isDiskSynchronous());
+        } else {
+          regionJSON.put(this.DISC_SYNCHRONOUS, this.VALUE_NA);
+          regionJSON.put(this.DISC_STORE_NAME, "");
+        }
+        regionJSON.put("gatewayEnabled", memberRegion.getWanEnabled());
+
+        regionsListJson.add(regionJSON);
+      }
+      responseJSON.put("memberRegions", regionsListJson);
+
+      // response
+      responseJSON.put("status", "Normal");
+
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MembersListService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MembersListService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MembersListService.java
new file mode 100644
index 0000000..9bf8432
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MembersListService.java
@@ -0,0 +1,75 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MembersListService
+ * 
+ * This class contains implementations of getting list of Cluster Members.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MembersList")
+@Scope("singleton")
+public class MembersListService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // members list
+    ArrayNode memberListJson = mapper.createArrayNode();
+    Cluster.Member[] memberSet = cluster.getMembers();
+
+    for (Cluster.Member member : memberSet) {
+      ObjectNode memberJSON = mapper.createObjectNode();
+      memberJSON.put("memberId", member.getId());
+      memberJSON.put("name", member.getName());
+      memberJSON.put("host", member.getHost());
+
+      memberListJson.add(memberJSON);
+    }
+
+    // Response JSON
+    responseJSON.put("clusterMembers", memberListJson);
+    responseJSON.put("clusterName", cluster.getServerName());
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseService.java
new file mode 100644
index 0000000..6b8aa4d
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseService.java
@@ -0,0 +1,40 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import javax.servlet.http.HttpServletRequest;
+
+import com.fasterxml.jackson.databind.node.ObjectNode;
+
+/**
+ * Abstract class PulseService
+ * 
+ * This is a base class for all services in pulse.
+ * 
+ * @since GemFire version 7.5
+ */
+public interface PulseService {
+
+  String VALUE_NA = "NA";
+  String VALUE_ON = "ON";
+  String VALUE_OFF = "OFF";
+
+  ObjectNode execute(HttpServletRequest httpServletRequest) throws Exception;
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseServiceFactory.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseServiceFactory.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseServiceFactory.java
new file mode 100644
index 0000000..2aca834
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseServiceFactory.java
@@ -0,0 +1,55 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import org.springframework.beans.BeansException;
+import org.springframework.context.ApplicationContext;
+import org.springframework.context.ApplicationContextAware;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+
+/**
+ * Class PulseServiceFactory
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Scope("singleton")
+public class PulseServiceFactory implements ApplicationContextAware {
+
+  static final long serialVersionUID = 02L;
+  ApplicationContext applicationContext = null;
+
+  public PulseService getPulseServiceInstance(final String servicename) {
+
+    if (applicationContext != null
+        && applicationContext.containsBean(servicename)) {
+      return (PulseService) applicationContext.getBean(servicename);
+    }
+    return null;
+  }
+
+  @Override
+  public void setApplicationContext(final ApplicationContext applicationContext)
+      throws BeansException {
+
+    this.applicationContext = applicationContext;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseVersionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseVersionService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseVersionService.java
new file mode 100644
index 0000000..81728bb
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/PulseVersionService.java
@@ -0,0 +1,65 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class PulseVersionService
+ * 
+ * This class contains implementations of getting Pulse Applications Version's
+ * details (like version details, build details, source details, etc) from
+ * properties file
+ * 
+ * @since GemFire version 7.0.Beta
+ */
+
+@Component
+@Service("PulseVersion")
+@Scope("singleton")
+public class PulseVersionService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // Response
+    responseJSON.put("pulseVersion", PulseController.pulseVersion.getPulseVersion());
+    responseJSON.put("buildId", PulseController.pulseVersion.getPulseBuildId());
+    responseJSON.put("buildDate", PulseController.pulseVersion.getPulseBuildDate());
+    responseJSON.put("sourceDate", PulseController.pulseVersion.getPulseSourceDate());
+    responseJSON.put("sourceRevision", PulseController.pulseVersion.getPulseSourceRevision());
+    responseJSON.put("sourceRepository", PulseController.pulseVersion.getPulseSourceRepository());
+
+    // Send json response
+    return responseJSON;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/QueryStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/QueryStatisticsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/QueryStatisticsService.java
new file mode 100644
index 0000000..c456caf
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/QueryStatisticsService.java
@@ -0,0 +1,115 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import javax.servlet.http.HttpServletRequest;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+
+/**
+ * Class QueryStatisticsService
+ * 
+ * This class returns top N queries based on pagination and filtering criteria
+ * if any
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("QueryStatistics")
+@Scope("singleton")
+public class QueryStatisticsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  @Override
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    Cluster.Statement[] stmts = cluster.getStatements();
+
+    ArrayNode queryListJson = mapper.createArrayNode();
+    for (int i = 0; i < stmts.length; ++i) {
+      ObjectNode queryJSON = mapper.createObjectNode();
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QUERYDEFINITION, stmts[i].getQueryDefinition());
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
+          mapper.valueToTree(stmts[i].getNumTimesCompiled() < 0 ? this.VALUE_NA : stmts[i].getNumTimesCompiled()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION,
+          mapper.valueToTree(stmts[i].getNumExecution() < 0 ? this.VALUE_NA : stmts[i].getNumExecution()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
+          mapper.valueToTree(stmts[i].getNumExecutionsInProgress() < 0 ? this.VALUE_NA : stmts[i].getNumExecutionsInProgress()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
+          mapper.valueToTree(stmts[i].getNumTimesGlobalIndexLookup() < 0 ? this.VALUE_NA : stmts[i].getNumTimesGlobalIndexLookup()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED,
+          mapper.valueToTree(stmts[i].getNumRowsModified() < 0 ? this.VALUE_NA : stmts[i].getNumRowsModified()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_PARSETIME,
+          mapper.valueToTree(stmts[i].getParseTime() < 0 ? this.VALUE_NA : stmts[i].getParseTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_BINDTIME,
+          mapper.valueToTree(stmts[i].getBindTime() < 0 ? this.VALUE_NA : stmts[i].getBindTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME,
+          mapper.valueToTree(stmts[i].getOptimizeTime() < 0 ? this.VALUE_NA : stmts[i].getOptimizeTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME,
+          mapper.valueToTree(stmts[i].getRoutingInfoTime() < 0 ? this.VALUE_NA : stmts[i].getRoutingInfoTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME,
+          mapper.valueToTree(stmts[i].getGenerateTime() < 1 ? this.VALUE_NA : stmts[i].getGenerateTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME,
+          mapper.valueToTree(stmts[i].getTotalCompilationTime() < 0 ? this.VALUE_NA : stmts[i].getTotalCompilationTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME,
+          mapper.valueToTree(stmts[i].getExecutionTime() < 0 ? this.VALUE_NA : stmts[i].getExecutionTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME,
+          mapper.valueToTree(stmts[i].getProjectionTime() < 0 ? this.VALUE_NA : stmts[i].getProjectionTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
+          mapper.valueToTree(stmts[i].getTotalExecutionTime() < 0 ? this.VALUE_NA : stmts[i].getTotalExecutionTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME,
+          mapper.valueToTree(stmts[i].getRowsModificationTime() < 0 ? this.VALUE_NA : stmts[i].getRowsModificationTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
+          mapper.valueToTree(stmts[i].getqNNumRowsSeen() < 0 ? this.VALUE_NA : stmts[i].getqNNumRowsSeen()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME,
+          mapper.valueToTree(stmts[i].getqNMsgSendTime() < 0 ? this.VALUE_NA : stmts[i].getqNMsgSendTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME,
+          mapper.valueToTree(stmts[i].getqNMsgSerTime() < 0 ? this.VALUE_NA : stmts[i].getqNMsgSerTime()));
+      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME,
+          mapper.valueToTree(stmts[i].getqNRespDeSerTime() < 0 ? this.VALUE_NA : stmts[i].getqNRespDeSerTime()));
+      queryListJson.add(queryJSON);
+    }
+    responseJSON.put("queriesList", queryListJson);
+
+    // return jmx status
+    responseJSON.put("connectedFlag", cluster.isConnectedFlag());
+    responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
+
+    // Send json response
+    return responseJSON;
+
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/SystemAlertsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/SystemAlertsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/SystemAlertsService.java
new file mode 100644
index 0000000..2310cad
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/SystemAlertsService.java
@@ -0,0 +1,127 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class SystemAlertsService
+ * 
+ * This class contains implementations of getting system's alerts details (like
+ * errors, warnings and severe errors).
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("SystemAlerts")
+@Scope("singleton")
+public class SystemAlertsService implements PulseService {
+
+  private static final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    int pageNumber = 1; // Default
+    String strPageNumber = requestDataJSON.get("SystemAlerts").get("pageNumber").textValue();
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(strPageNumber)) {
+      try {
+        pageNumber = Integer.valueOf(strPageNumber);
+      } catch (NumberFormatException e) {
+      }
+    }
+
+    // cluster's Members
+    responseJSON.put("systemAlerts", getAlertsJson(cluster, pageNumber));
+    responseJSON.put("pageNumber", cluster.getNotificationPageNumber());
+    responseJSON.put("connectedFlag", cluster.isConnectedFlag());
+    responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
+
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * function used for getting all members details in format of JSON Object
+   * array defined under a cluster
+   * 
+   * @param cluster
+   * @return JSONObject Array list
+   */
+  public static ObjectNode getAlertsJson(Cluster cluster, int pageNumber) {
+    // getting list of all types of alerts
+    Cluster.Alert[] alertsList = cluster.getAlertsList();
+
+    // create alerts json
+    ObjectNode alertsJsonObject = mapper.createObjectNode();
+
+    if ((alertsList != null) && (alertsList.length > 0)) {
+      ArrayNode errorJsonArray = mapper.createArrayNode();
+      ArrayNode severeJsonArray = mapper.createArrayNode();
+      ArrayNode warningJsonArray = mapper.createArrayNode();
+      ArrayNode infoJsonArray = mapper.createArrayNode();
+
+      cluster.setNotificationPageNumber(pageNumber);
+      for (Cluster.Alert alert : alertsList) {
+        ObjectNode objAlertJson = mapper.createObjectNode();
+        objAlertJson.put("description", alert.getDescription());
+        objAlertJson.put("memberName", alert.getMemberName());
+        objAlertJson.put("severity", alert.getSeverity());
+        objAlertJson.put("isAcknowledged", alert.isAcknowledged());
+        objAlertJson.put("timestamp", alert.getTimestamp().toString());
+        objAlertJson.put("iso8601Ts", alert.getIso8601Ts());
+        objAlertJson.put("id", alert.getId());
+
+        if (alert.getSeverity() == Cluster.Alert.SEVERE) {
+          severeJsonArray.add(objAlertJson);
+        } else if (alert.getSeverity() == Cluster.Alert.ERROR) {
+          errorJsonArray.add(objAlertJson);
+        } else if (alert.getSeverity() == Cluster.Alert.WARNING) {
+          warningJsonArray.add(objAlertJson);
+        } else {
+          infoJsonArray.add(objAlertJson);
+        }
+      }
+      alertsJsonObject.put("info", infoJsonArray);
+      alertsJsonObject.put("warnings", warningJsonArray);
+      alertsJsonObject.put("errors", errorJsonArray);
+      alertsJsonObject.put("severe", severeJsonArray);
+    }
+    return alertsJsonObject;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/ConnectionUtil.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/ConnectionUtil.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/ConnectionUtil.java
new file mode 100644
index 0000000..8775723
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/ConnectionUtil.java
@@ -0,0 +1,46 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.util;
+
+import java.io.IOException;
+
+import javax.net.SocketFactory;
+import javax.net.ssl.SSLSocketFactory;
+
+
+/**
+ * 
+ *
+ */
+public class ConnectionUtil {
+
+  
+  
+  public static SocketFactory getSocketFactory(boolean usessl)
+    throws IOException
+  {
+    if(usessl){
+      return (SSLSocketFactory)SSLSocketFactory.getDefault();
+    }else{
+      return SocketFactory.getDefault();
+    }    
+  }
+  
+  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/IPAddressUtil.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/IPAddressUtil.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/IPAddressUtil.java
new file mode 100644
index 0000000..72b264f
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/IPAddressUtil.java
@@ -0,0 +1,65 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.util;
+
+import java.util.regex.Matcher;
+import java.util.regex.Pattern;
+import java.util.regex.PatternSyntaxException;
+
+/* [ NOTE: 
+ * This class supposed to be removed, if required, after discussing with 
+ * VMware team ]
+ */
+/**
+ * Class IPAddressUtil This is utility class for checking whether ip address is
+ * versions i.e. IPv4 or IPv6 address
+ * 
+ * 
+ * @since GemFire version 7.0.1
+ */
+public class IPAddressUtil {
+
+  private static Pattern VALID_IPV4_PATTERN = null;
+  private static Pattern VALID_IPV6_PATTERN = null;
+  private static final String ipv4Pattern = "(([01]?\\d\\d?|2[0-4]\\d|25[0-5])\\.){3}([01]?\\d\\d?|2[0-4]\\d|25[0-5])";
+  private static final String ipv6Pattern = "([0-9a-f]{1,4}:){7}([0-9a-f]){1,4}";
+
+  static {
+    try {
+      VALID_IPV4_PATTERN = Pattern.compile(ipv4Pattern,
+          Pattern.CASE_INSENSITIVE);
+      VALID_IPV6_PATTERN = Pattern.compile(ipv6Pattern,
+          Pattern.CASE_INSENSITIVE);
+    } catch (PatternSyntaxException e) {
+
+    }
+  }
+
+  public static Boolean isIPv4LiteralAddress(String IPAddress) {
+    Matcher matcher = IPAddressUtil.VALID_IPV4_PATTERN.matcher(IPAddress);
+    return matcher.matches();
+  }
+
+  public static Boolean isIPv6LiteralAddress(String IPAddress) {
+
+    Matcher matcher = IPAddressUtil.VALID_IPV6_PATTERN.matcher(IPAddress);
+    return matcher.matches();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/StringUtils.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/StringUtils.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/StringUtils.java
new file mode 100644
index 0000000..e719d13
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/StringUtils.java
@@ -0,0 +1,85 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.util;
+
+/**
+ * Class StringUtils This is utility class for string.
+ * 
+ * 
+ * @since GemFire version 7.0.1
+ */
+public class StringUtils {
+  /**
+   * Checks the string if it is not null, not empty, and not white space only
+   * using standard Java classes.
+   * 
+   * @param string
+   *          String to be checked.
+   * @return {@code true} if provided String is not null, is not empty, and has
+   *         at least one character that is not considered white space.
+   */
+  public static boolean isNotNullNotEmptyNotWhiteSpace(final String string) {
+    return string != null && !string.isEmpty() && !string.trim().isEmpty();
+  }
+
+  /**
+   * Checking for String that is not null, not empty, and not white space only
+   * using standard Java classes.
+   * 
+   * @param value
+   *          String to be made compliant.
+   * @return string compliant string.
+   */
+  public static String makeCompliantName(String value) {
+    value = value.replace(':', '-');
+    value = value.replace(',', '-');
+    value = value.replace('=', '-');
+    value = value.replace('*', '-');
+    value = value.replace('?', '-');
+    if (value.length() < 1) {
+      value = "nothing";
+    }
+    return value;
+  }
+
+  /**
+   * Function to get table name derived from region name/full path
+   * 
+   * @param regionName
+   *          String to be made compliant.
+   * @return string compliant string.
+   */
+  public static String getTableNameFromRegionName(String regionName) {
+    String tableName = regionName.replaceFirst("/", "").replace('/', '.');
+    return tableName;
+  }
+
+  /**
+   * Function to get region name/full path derived from table name
+   * 
+   * @param tableName
+   *          String to be made compliant.
+   * @return string compliant string.
+   */
+  public static String getRegionNameFromTableName(String tableName) {
+    String regionName = "/" + tableName.replace('.', '/');
+    return regionName;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/TimeUtils.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/TimeUtils.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/TimeUtils.java
new file mode 100644
index 0000000..4ddfe54
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/util/TimeUtils.java
@@ -0,0 +1,120 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.util;
+
+/**
+ * Class TimeUtils 
+ * 
+ * This is utility class used for conversions of time.
+ * 
+ * 
+ * @since GemFire version 7.0.1
+ */
+public class TimeUtils {
+
+  /**
+   * Method to converts time given in milliseconds to string representation in
+   * days, hours, minutes and seconds
+   * 
+   * @param longMilliSecs
+   *          Time in milliseconds.
+   * @return String
+   */
+  public static String convertTimeMillisecondsToHMS(long longMilliSecs) {
+
+    long days = longMilliSecs / (1000 * 60 * 60 * 24);
+    long remainder = longMilliSecs % (1000 * 60 * 60 * 24);
+
+    long hours = remainder / (1000 * 60 * 60);
+    remainder = remainder % (1000 * 60 * 60);
+
+    long mins = remainder / (1000 * 60);
+    remainder = remainder % (1000 * 60);
+
+    long secs = remainder / 1000;
+
+    String strDaysHrsMinsSecs = "";
+
+    if (days > 0) {
+      strDaysHrsMinsSecs += days + " Days ";
+    }
+
+    if (hours > 0) {
+      strDaysHrsMinsSecs += hours + " Hours ";
+    } else {
+      strDaysHrsMinsSecs += "0 Hours ";
+    }
+
+    if (mins > 0) {
+      strDaysHrsMinsSecs += mins + " Mins ";
+    } else {
+      strDaysHrsMinsSecs += "0 Mins ";
+    }
+
+    strDaysHrsMinsSecs += secs + " Secs";
+
+    return strDaysHrsMinsSecs;
+  }
+
+  /**
+   * Method to converts time given in seconds to string representation in days,
+   * hours, minutes and seconds
+   * 
+   * @param longSecs
+   *          Time in seconds.
+   * @return String
+   */
+  public static String convertTimeSecondsToHMS(long longSecs) {
+
+    long days = longSecs / (60 * 60 * 24);
+    long remainder = longSecs % (60 * 60 * 24);
+
+    long hours = remainder / (60 * 60);
+    remainder = remainder % (60 * 60);
+
+    long mins = remainder / (60);
+    remainder = remainder % (60);
+
+    long secs = remainder;
+
+    String strDaysHrsMinsSecs = "";
+
+    if (days > 0) {
+      strDaysHrsMinsSecs += days + " Days ";
+    }
+
+    if (hours > 0) {
+      strDaysHrsMinsSecs += hours + " Hours ";
+    } else {
+      strDaysHrsMinsSecs += "0 Hours ";
+    }
+
+    if (mins > 0) {
+      strDaysHrsMinsSecs += mins + " Mins ";
+    } else {
+      strDaysHrsMinsSecs += "0 Mins ";
+    }
+
+    strDaysHrsMinsSecs += secs + " Secs";
+
+    return strDaysHrsMinsSecs;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/webapp/WEB-INF/mvc-dispatcher-servlet.xml
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/webapp/WEB-INF/mvc-dispatcher-servlet.xml b/geode-pulse/src/main/webapp/WEB-INF/mvc-dispatcher-servlet.xml
index 60edb18..6fdee43 100644
--- a/geode-pulse/src/main/webapp/WEB-INF/mvc-dispatcher-servlet.xml
+++ b/geode-pulse/src/main/webapp/WEB-INF/mvc-dispatcher-servlet.xml
@@ -28,8 +28,8 @@
         http://www.springframework.org/schema/mvc/spring-mvc-3.2.xsd">
  
     
-    <context:component-scan base-package="com.vmware.gemfire.tools.pulse.internal" />
+    <context:component-scan base-package="org.apache.geode.tools.pulse.internal" />
 
     <mvc:annotation-driven />
      
-</beans>
\ No newline at end of file
+</beans>


[06/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapObjectKey.java
index d151694..d490d82 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapObjectKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey1.java
index ea55bc9..0759341 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey1.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey2.java
index 7ccc15e..97f4b59 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapStringKey2.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapUUIDKey.java
index b9ec7a5..38e8bb4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryHeapUUIDKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeap.java
index 92eef07..988cb99 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapIntKey.java
index c495eb5..ca1e8ae 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapIntKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapLongKey.java
index f69b383..0acf71d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapLongKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapObjectKey.java
index 6ac9795..4ad4628 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapObjectKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey1.java
index e33874b..8bd64fe 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey1.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey2.java
index 2fa8ea7..7691f77 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapStringKey2.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapUUIDKey.java
index 19d9e0c..fe7bb0e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsLRURegionEntryOffHeapUUIDKey.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntry.java
index a2db8be..b00f433 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeap.java
index 863f0c7..bb9a062 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapIntKey.java
index 0e2502d..e353367 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapIntKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapLongKey.java
index 030f154..4e374ff 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapLongKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapObjectKey.java
index bd32172..aef1c25 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapObjectKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey1.java
index b5e2139..293dd3b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey1.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey2.java
index 4e8e1e1..48f1133 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapStringKey2.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapUUIDKey.java
index a0fd1a0..95e39e4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryHeapUUIDKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeap.java
index 6e3d033..d4fc5b7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapIntKey.java
index 11920c7..33cf7fc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapIntKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapLongKey.java
index c0bfc6e..3ee7fd7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapLongKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapObjectKey.java
index b167a66..38b1b2e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapObjectKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey1.java
index 7ea4ace..05fd6f3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey1.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey2.java
index e9cfe72..a6c2158 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapStringKey2.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapUUIDKey.java
index a5d91f8..f817eb7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedStatsRegionEntryOffHeapUUIDKey.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntry.java
index 19b4c56..d7cb80f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntry.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionStamp;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeap.java
index 9e7d4e1..2e4341f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapIntKey.java
index af35a81..e370a25 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapIntKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapLongKey.java
index 749d1dc..5157e75 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapLongKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapObjectKey.java
index 2edcdec..95ea7e8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapObjectKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey1.java
index 3a23fcb..bdcd3bb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey1.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey2.java
index 53c9276..42e4663 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapStringKey2.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapUUIDKey.java
index a8a2242..c891ea5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryHeapUUIDKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeap.java
index 1f838a1..1a65839 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapIntKey.java
index 0e1ca51..40b8052 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapIntKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapLongKey.java
index ca2565d..9883b5a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapLongKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapObjectKey.java
index e808dac..f9a6ada 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VersionedThinDiskLRURegionEntryOffHeapObjectKey.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-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.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.cache.EntryEvent;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU



[55/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/driver/PulseUITest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/driver/PulseUITest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/driver/PulseUITest.java
new file mode 100644
index 0000000..a0bb728
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/testbed/driver/PulseUITest.java
@@ -0,0 +1,277 @@
+/*
+ * 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 org.apache.geode.tools.pulse.testbed.driver;
+
+import static org.apache.geode.tools.pulse.tests.PulseAbstractTest.*;
+import static org.junit.Assert.*;
+
+import java.net.InetAddress;
+import java.util.List;
+
+import org.junit.After;
+import org.junit.AfterClass;
+import org.junit.BeforeClass;
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.openqa.selenium.By;
+import org.openqa.selenium.WebDriver;
+import org.openqa.selenium.WebElement;
+import org.openqa.selenium.firefox.FirefoxDriver;
+import org.openqa.selenium.support.ui.ExpectedCondition;
+import org.openqa.selenium.support.ui.WebDriverWait;
+
+import org.apache.geode.management.internal.JettyHelper;
+import org.apache.geode.test.junit.categories.UITest;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Locator;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Peer;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Region;
+import org.apache.geode.tools.pulse.testbed.GemFireDistributedSystem.Server;
+import org.apache.geode.tools.pulse.testbed.TestBed;
+
+@Ignore("TODO: test is ignored")
+@Category(UITest.class)
+public class PulseUITest {
+
+  private static WebDriver driver;
+  private static TestBed testBed;
+  private static String pulseURL;
+  private static String path;
+  private static org.eclipse.jetty.server.Server jetty = null;
+
+  private static final String userName = "admin";
+  private static final String pasword = "admin";
+  
+  private static final String DATA_VIEW_LABEL = "Data View";
+  private static final String CLUSTER_VIEW_MEMBERS_ID = "clusterTotalMembersText";
+  private static final String CLUSTER_VIEW_SERVERS_ID = "clusterServersText";
+  private static final String CLUSTER_VIEW_LOCATORS_ID = "clusterLocatorsText";
+  private static final String CLUSTER_VIEW_REGIONS_ID = "clusterTotalRegionsText";
+
+  @BeforeClass
+  public static void setUpJetty() throws Exception {
+    String host = InetAddress.getLocalHost().getHostAddress();
+    int port = 8080;
+    String context = "/pulse";
+    path = getPulseWarPath();
+    //System.setProperty("pulse.propMockDataUpdaterClass", "org.apache.geode.tools.pulse.testbed.PropMockDataUpdater");
+
+    jetty = JettyHelper.initJetty(host, port, false, false, null, null, null);
+    JettyHelper.addWebApplication(jetty, context, getPulseWarPath());
+    jetty.start();
+
+    pulseURL = "http://" + host + ":" + port + context;
+    Thread.sleep(1000); //wait till tomcat settles down
+    driver = new FirefoxDriver();
+    driver.manage().window().maximize();//required to make all elements visible
+
+    Thread.sleep(5000); //wait till pulse starts polling threads...
+    testBed = new TestBed();
+    loginToPulse(driver, userName, pasword);
+  }
+
+  @AfterClass
+  public static void stopJetty() throws Exception {
+    jetty.stop();
+  }
+
+  @After
+  public void closeSession() {
+    driver.close();
+  }
+
+  private static void loginToPulse(WebDriver driver, String userName,String password){
+    driver.get(pulseURL);    
+    WebElement userNameElement = driver.findElement(By.id("user_name"));
+    WebElement passwordElement = driver.findElement(By.id("user_password"));
+    userNameElement.sendKeys(userName);
+    passwordElement.sendKeys(password);
+    passwordElement.submit();
+    WebElement userNameOnPulsePage = (new WebDriverWait(driver, 10))
+        .until(new ExpectedCondition<WebElement>() {
+          @Override
+          public WebElement apply(WebDriver d) {
+            return d.findElement(By.id("userName"));
+          }
+        });
+    assertNotNull(userNameOnPulsePage);
+  }
+  
+  
+  private void searchByLinkAndClick(String linkText){
+    WebElement  dataViewButton= By.linkText(linkText).findElement(driver);
+    assertNotNull(dataViewButton);   
+    dataViewButton.click();
+  }
+  
+  private void searchByIdAndClick(String id){
+    WebElement  element = driver.findElement(By.id(id));
+    assertNotNull(element);
+    element.click();    
+  }
+  
+  private void searchByXPathAndClick(String xpath){    
+    WebElement  element = driver.findElement(By.xpath(xpath));
+    assertNotNull(element);
+    element.click();    
+  }
+  
+  private void waitForElementByClassName(final String className, int seconds){
+    WebElement linkTextOnPulsePage1 = (new WebDriverWait(driver, seconds))
+    .until(new ExpectedCondition<WebElement>() {
+      @Override
+      public WebElement apply(WebDriver d) {
+        return d.findElement(By.className(className));
+      }
+    });
+    assertNotNull(linkTextOnPulsePage1);
+  }
+  
+  private void waitForElementById(final String id, int seconds){
+    WebElement element = (new WebDriverWait(driver, 10))
+    .until(new ExpectedCondition<WebElement>() {
+      @Override
+      public WebElement apply(WebDriver d) {
+        return d.findElement(By.id(id));
+      }
+    });
+    assertNotNull(element);
+  }
+  
+  @Test
+  public void testClusterViewTopRibbon() {
+    List<Server> servers = testBed.getRootDs().getServers();
+    List<Locator> locators = testBed.getRootDs().getLocators();
+    List<Peer> peers = testBed.getRootDs().getPeers();
+    List<Region> regions = testBed.getRootDs().getRegions();
+    int totalMembers = servers.size() + locators.size() + peers.size();
+    int clusterMembers = Integer.parseInt(driver.findElement(
+        By.id(CLUSTER_VIEW_MEMBERS_ID)).getText());
+    int clusterServers = Integer.parseInt(driver.findElement(
+        By.id(CLUSTER_VIEW_SERVERS_ID)).getText());
+    int clusterLocators = Integer.parseInt(driver.findElement(
+        By.id(CLUSTER_VIEW_LOCATORS_ID)).getText());
+    int clusterRegions = Integer.parseInt(driver.findElement(
+        By.id(CLUSTER_VIEW_REGIONS_ID)).getText());
+    assertEquals(totalMembers, clusterMembers);
+    assertEquals(servers.size(), clusterServers);
+    assertEquals(locators.size(), clusterLocators);
+    assertEquals(regions.size(), clusterRegions);
+  }  
+
+
+  @Test
+  public void testDataViewRegionProperties() {
+    searchByLinkAndClick(DATA_VIEW_LABEL);
+    waitForElementByClassName("pointDetailsPadding",10);    
+    searchByIdAndClick("btngridIcon");
+    
+    for(int i=1;i<testBed.getRootDs().getRegions().size();i++){
+      searchByIdAndClick(""+i);
+      String regionName1 = driver.findElement(By.id("regionName")).getText();
+      @SuppressWarnings("rawtypes")
+      List regionMemberscount1 = testBed.getRootDs().getRegion(regionName1)
+          .getMembers();
+      int regionEntCount1 = testBed.getRootDs().getRegion(regionName1)
+          .getEntryCount();
+      int regionMembers1 = Integer.parseInt(driver.findElement(
+          By.id("regionMembers")).getText());
+      int regionEntryCount1 = Integer.parseInt(driver.findElement(
+          By.id("regionEntryCount")).getText());
+      assertEquals(regionMemberscount1.size(), regionMembers1);
+      assertEquals(regionEntCount1, regionEntryCount1);
+    }
+  }
+
+  
+  @Test
+  public void testMemberViewRegions() {
+    
+    searchByLinkAndClick(DATA_VIEW_LABEL);
+    waitForElementByClassName("pointDetailsPadding",10);    
+    searchByXPathAndClick("//div[@title='peer1']");    
+    waitForElementById("memberRegionsCount",10);    
+    
+    List<Server> servers = testBed.getRootDs().getServers();
+    List<Locator> locators = testBed.getRootDs().getLocators();
+    List<Peer> peers = testBed.getRootDs().getPeers();    
+
+    String prevSelectedMember = "peer1";
+    
+    for (Peer p : peers) {
+      String peer = p.getName();
+      System.out.println("Checking regions mapping for member " + peer);
+      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
+      comboBox.click();                 
+      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
+      WebElement selectedMember = comboList.findElement(By.linkText(peer));
+      selectedMember.click();
+      timeout();
+      String peername = driver.findElement(By.id("memberName")).getText();      
+      List<Region> peerRegionscount = testBed.getRootDs().getRegions(peer);
+      int peerRegions = Integer.parseInt(driver.findElement(
+          By.id("memberRegionsCount")).getText());
+      assertEquals(peerRegionscount.size(), peerRegions);
+      prevSelectedMember = peername;
+    }
+    
+    for (Server s : servers) {
+      String server = s.getName();
+      System.out.println("Checking regions mapping for server " + server);
+      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
+      comboBox.click();                 
+      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
+      WebElement selectedMember = comboList.findElement(By.linkText(server));
+      selectedMember.click();
+      timeout();
+      String peername = driver.findElement(By.id("memberName")).getText();      
+      List<Region> serverRegionscount = testBed.getRootDs().getRegions(server);
+      int serverRegions = Integer.parseInt(driver.findElement(
+          By.id("memberRegionsCount")).getText());
+      assertEquals(serverRegionscount.size(), serverRegions);
+      prevSelectedMember = peername;            
+    }
+    /*
+    for (Locator l : locators) {      
+      String locator = l.getName();
+      System.out.println("Checking regions mapping for locator " + locator);
+      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
+      comboBox.click();                 
+      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
+      WebElement selectedMember = comboList.findElement(By.linkText(locator));
+      selectedMember.click();
+      timeout();
+      String peername = driver.findElement(By.id("memberName")).getText();      
+      List<Region> locatorRegionscount = testBed.getRootDs().getRegions(locator);
+      int locatorRegions = Integer.parseInt(driver.findElement(
+          By.id("memberRegionsCount")).getText());
+      assertIndexDetailsEquals(locatorRegionscount.size(), locatorRegions);
+      prevSelectedMember = peername;
+    }*/
+  }
+
+  public void timeout() {
+    WebElement memberNameOnPulsePage = (new WebDriverWait(driver, 10))
+        .until(new ExpectedCondition<WebElement>() {
+          @Override
+          public WebElement apply(WebDriver d) {
+            return d.findElement(By.id("memberName"));
+          }
+        });
+    assertNotNull(memberNameOnPulsePage);    
+  }  
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatement.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatement.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatement.java
new file mode 100644
index 0000000..b4ad0a2
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatement.java
@@ -0,0 +1,217 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public class AggregateStatement extends JMXBaseBean implements AggregateStatementMBean {
+  private String name = null;
+
+  public AggregateStatement(String name) {
+    this.name = name;
+  }
+
+  protected String getKey(String propName) {
+    return "aggregatestatement." + name + "." + propName;
+  }
+  
+  /**
+   * Query definition
+   * 
+   * @return
+   */
+  public String getQueryDefinition(){
+    return getString("queryDefinition");
+  }
+
+  /**
+   * Number of times this statement is compiled (including re compilations)
+   * 
+   * @return
+   */
+  @Override
+  public long getNumTimesCompiled(){
+    return getLong("numTimesCompiled");
+  }
+
+  /**
+   * Number of times this statement is executed
+   * 
+   * @return
+   */
+  @Override
+  public long getNumExecution(){
+    return getLong("numExecution");
+  }
+
+  /**
+   * Statements that are actively being processed during the statistics snapshot
+   * 
+   * @return
+   */
+  public long getNumExecutionsInProgress(){
+    return getLong("numExecutionsInProgress");
+  }
+
+  /**
+   * Number of times global index lookup message exchanges occurred
+   * 
+   * @return
+   */
+  public long getNumTimesGlobalIndexLookup(){
+    return getLong("numTimesGlobalIndexLookup");
+  }
+
+  /**
+   * Number of rows modified by DML operation of insert/delete/update
+   * 
+   * @return
+   */
+  public long getNumRowsModified(){
+    return getLong("numRowsModified");
+  }
+
+  /**
+   * Time spent(in milliseconds) in parsing the query string
+   * 
+   * @return
+   */
+  public long getParseTime(){
+    return getLong("parseTime");
+  }
+
+  /**
+   * Time spent (in milliseconds) mapping this statement with database object's metadata (bind)
+   * 
+   * @return
+   */
+  public long getBindTime(){
+    return getLong("bindTime");
+  }
+
+  /**
+   * Time spent (in milliseconds) determining the best execution path for this statement
+   * (optimize)
+   * 
+   * @return
+   */
+  public long getOptimizeTime(){
+    return getLong("optimizeTime");
+  }
+
+  /**
+   * Time spent (in milliseconds) compiling details about routing information of query strings to
+   * data node(s) (processQueryInfo)
+   * 
+   * @return
+   */
+  public long getRoutingInfoTime(){
+    return getLong("routingInfoTime");
+  }
+
+  /**
+   * Time spent (in milliseconds) to generate query execution plan definition (activation class)
+   * 
+   * @return
+   */
+  public long getGenerateTime(){
+    return getLong("generateTime");
+  }
+
+  /**
+   * Total compilation time (in milliseconds) of the statement on this node (prepMinion)
+   * 
+   * @return
+   */
+  public long getTotalCompilationTime(){
+    return getLong("totalCompilationTime");
+  }
+
+  /**
+   * Time spent (in nanoseconds) in creation of all the layers of query processing (ac.execute)
+   * 
+   * @return
+   */
+  public long getExecutionTime(){
+    return getLong("executionTime");
+  }
+
+  /**
+   * Time to apply (in nanoseconds) the projection and additional filters. (projectrestrict)
+   * 
+   * @return
+   */
+  public long getProjectionTime(){
+    return getLong("projectionTime");
+  }
+
+  /**
+   * Total execution time (in nanoseconds) taken to process the statement on this node
+   * (execute/open/next/close)
+   * 
+   * @return
+   */
+  public long getTotalExecutionTime(){
+    return getLong("totalExecutionTime");
+  }
+
+  /**
+   * Time taken (in nanoseconds) to modify rows by DML operation of insert/delete/update
+   * 
+   * @return
+   */
+  public long getRowsModificationTime(){
+    return getLong("rowsModificationTime");
+  }
+
+  /**
+   * Number of rows returned from remote nodes (ResultHolder/Get convertibles)
+   * 
+   * @return
+   */
+  public long getQNNumRowsSeen(){
+    return getLong("qnNumRowsSeen");
+  }
+
+  /**
+   * TCP send time (in nanoseconds) of all the messages including serialization time and queue
+   * wait time
+   * 
+   * @return
+   */
+  public long getQNMsgSendTime(){
+    return getLong("qnMsgSendTime");
+  }
+
+  /**
+   * Serialization time (in nanoseconds) for all the messages while sending to remote node(s)
+   * 
+   * @return
+   */
+  public long getQNMsgSerTime(){
+    return getLong("qnMsgSerTime");
+  }
+  
+  /**
+   * 
+   * 
+   * @return
+   */
+  public long getQNRespDeSerTime(){
+    return getLong("qnRespDeSerTime");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatementMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatementMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatementMBean.java
new file mode 100644
index 0000000..e1c968d
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/AggregateStatementMBean.java
@@ -0,0 +1,168 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public interface AggregateStatementMBean {
+  String OBJECT_NAME = "GemFireXD:service=Statement,type=Aggregate";
+
+  /**
+   * Query definition
+   *
+   * @return
+   */
+  String getQueryDefinition();
+
+  /**
+   * Number of times this statement is compiled (including re compilations)
+   *
+   * @return
+   */
+  long getNumTimesCompiled();
+
+  /**
+   * Number of times this statement is executed
+   *
+   * @return
+   */
+  long getNumExecution();
+
+  /**
+   * Statements that are actively being processed during the statistics snapshot
+   *
+   * @return
+   */
+  long getNumExecutionsInProgress();
+
+  /**
+   * Number of times global index lookup message exchanges occurred
+   *
+   * @return
+   */
+  long getNumTimesGlobalIndexLookup();
+
+  /**
+   * Number of rows modified by DML operation of insert/delete/update
+   *
+   * @return
+   */
+  long getNumRowsModified();
+
+  /**
+   * Time spent(in milliseconds) in parsing the query string
+   *
+   * @return
+   */
+  long getParseTime();
+
+  /**
+   * Time spent (in milliseconds) mapping this statement with database object's metadata (bind)
+   *
+   * @return
+   */
+  long getBindTime();
+
+  /**
+   * Time spent (in milliseconds) determining the best execution path for this statement
+   * (optimize)
+   *
+   * @return
+   */
+  long getOptimizeTime();
+
+  /**
+   * Time spent (in milliseconds) compiling details about routing information of query strings to
+   * data node(s) (processQueryInfo)
+   *
+   * @return
+   */
+  long getRoutingInfoTime();
+
+  /**
+   * Time spent (in milliseconds) to generate query execution plan definition (activation class)
+   *
+   * @return
+   */
+  long getGenerateTime();
+
+  /**
+   * Total compilation time (in milliseconds) of the statement on this node (prepMinion)
+   *
+   * @return
+   */
+  long getTotalCompilationTime();
+
+  /**
+   * Time spent (in nanoseconds) in creation of all the layers of query processing (ac.execute)
+   *
+   * @return
+   */
+  long getExecutionTime();
+
+  /**
+   * Time to apply (in nanoseconds) the projection and additional filters. (projectrestrict)
+   *
+   * @return
+   */
+  long getProjectionTime();
+
+  /**
+   * Total execution time (in nanoseconds) taken to process the statement on this node
+   * (execute/open/next/close)
+   *
+   * @return
+   */
+  long getTotalExecutionTime();
+
+  /**
+   * Time taken (in nanoseconds) to modify rows by DML operation of insert/delete/update
+   *
+   * @return
+   */
+  long getRowsModificationTime();
+
+  /**
+   * Number of rows returned from remote nodes (ResultHolder/Get convertibles)
+   *
+   * @return
+   */
+  long getQNNumRowsSeen();
+
+  /**
+   * TCP send time (in nanoseconds) of all the messages including serialization time and queue
+   * wait time
+   *
+   * @return
+   */
+  long getQNMsgSendTime();
+
+  /**
+   * Serialization time (in nanoseconds) for all the messages while sending to remote node(s)
+   *
+   * @return
+   */
+  long getQNMsgSerTime();
+
+  /**
+   *
+   *
+   * @return
+   */
+  long getQNRespDeSerTime();
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/DataBrowserResultLoader.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/DataBrowserResultLoader.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/DataBrowserResultLoader.java
new file mode 100644
index 0000000..b7895a6
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/DataBrowserResultLoader.java
@@ -0,0 +1,84 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import java.io.BufferedReader;
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.InputStreamReader;
+import java.net.URL;
+
+public class DataBrowserResultLoader {
+  private static DataBrowserResultLoader dbResultLoader = new DataBrowserResultLoader();
+
+  public static DataBrowserResultLoader getInstance() {
+    return dbResultLoader;
+  }
+
+  public String load(String queryString) throws IOException {
+
+    URL url = null;
+    InputStream inputStream = null;
+    BufferedReader streamReader = null;
+    String inputStr = null;
+    StringBuilder sampleQueryResultResponseStrBuilder = null;
+
+    try {
+      ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+
+      if (queryString.equals(PulseAbstractTest.QUERY_TYPE_ONE)) {
+        url = classLoader.getResource("testQueryResultClusterSmall.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_TWO)) {
+        url = classLoader.getResource("testQueryResultSmall.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_THREE)) {
+        url = classLoader.getResource("testQueryResult.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_FOUR)) {
+        url = classLoader.getResource("testQueryResultWithStructSmall.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_FIVE)) {
+        url = classLoader.getResource("testQueryResultClusterWithStruct.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_SIX)) {
+        url = classLoader.getResource("testQueryResultHashMapSmall.txt");
+      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_SEVENE)) {
+        url = classLoader.getResource("testQueryResult1000.txt");
+      } else {
+        url = classLoader.getResource("testQueryResult.txt");
+      }
+
+      File sampleQueryResultFile = new File(url.getPath());
+      inputStream = new FileInputStream(sampleQueryResultFile);
+      streamReader = new BufferedReader(new InputStreamReader(inputStream,
+          "UTF-8"));
+      sampleQueryResultResponseStrBuilder = new StringBuilder();
+
+      while ((inputStr = streamReader.readLine()) != null) {
+        sampleQueryResultResponseStrBuilder.append(inputStr);
+      }
+
+      // close stream reader
+      streamReader.close();
+
+    } catch (IOException ex) {
+      ex.printStackTrace();
+    }
+
+    return sampleQueryResultResponseStrBuilder.toString();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTable.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTable.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTable.java
new file mode 100644
index 0000000..079117b
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTable.java
@@ -0,0 +1,46 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.NotificationBroadcasterSupport;
+
+public class GemFireXDAggregateTable extends NotificationBroadcasterSupport
+    implements GemFireXDAggregateTableMBean {
+  private String name = null;
+
+  public GemFireXDAggregateTable(String name) {
+    this.name = name;
+  }
+
+  private String getKey(String propName) {
+    return "table." + name + "." + propName;
+  }
+
+  @Override
+  public long getEntrySize() {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(
+        getKey("EntrySize")));
+  }
+
+  @Override
+  public int getNumberOfRows() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("NumberOfRows")));
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTableMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTableMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTableMBean.java
new file mode 100644
index 0000000..c7f2e94
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDAggregateTableMBean.java
@@ -0,0 +1,28 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public interface GemFireXDAggregateTableMBean {
+  public static final String OBJECT_NAME = "GemFireXD:service=Table,type=Aggregate,table=";
+  
+  public long getEntrySize();
+
+  public int getNumberOfRows();
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDCluster.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDCluster.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDCluster.java
new file mode 100644
index 0000000..bc8f6f5
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDCluster.java
@@ -0,0 +1,95 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.NotificationBroadcasterSupport;
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.CompositeDataSupport;
+import javax.management.openmbean.CompositeType;
+import javax.management.openmbean.OpenDataException;
+import javax.management.openmbean.OpenType;
+import javax.management.openmbean.SimpleType;
+
+public class GemFireXDCluster extends NotificationBroadcasterSupport implements
+    GemFireXDClusterMBean {
+  private String name = null;
+
+  private static String[] itemNames = { "connectionsAttempted",
+      "connectionsActive", "connectionsClosed", "connectionsFailed" };;
+  private static String[] itemDescriptions = { "connectionsAttempted",
+      "connectionsActive", "connectionsClosed", "connectionsFailed" };
+  private static OpenType[] itemTypes = { SimpleType.LONG, SimpleType.LONG,
+      SimpleType.LONG, SimpleType.LONG };
+  private static CompositeType networkServerClientConnectionStats = null;
+
+  static {
+    try {
+      networkServerClientConnectionStats = new CompositeType(
+          "NetworkServerClientConnectionStats",
+          "Network Server Client Connection Stats Information", itemNames,
+          itemDescriptions, itemTypes);
+
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+    }
+  }
+
+  public GemFireXDCluster(String name) {
+    this.name = name;
+  }
+
+  private String getKey(String propName) {
+    return "gemfirexd." + name + "." + propName;
+  }
+
+  @Override
+  public int getProcedureCallsCompleted() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("ProcedureCallsCompleted")));
+  }
+
+  @Override
+  public int getProcedureCallsInProgress() {
+    return Integer.parseInt(JMXProperties.getInstance().getProperty(
+        getKey("ProcedureCallsInProgress")));
+  }
+
+  @Override
+  public CompositeData getNetworkServerClientConnectionStats() {
+    String value = JMXProperties.getInstance().getProperty(
+        getKey("NetworkServerClientConnectionStats"), "");
+    String[] values = value.split(",");
+    Long[] itemValues = new Long[values.length];
+    for (int i = 0; i < values.length; i++) {
+      itemValues[i] = Long.parseLong(values[i]);
+    }
+
+    CompositeData nscCompData;
+    try {
+      nscCompData = new CompositeDataSupport(
+          networkServerClientConnectionStats, itemNames, itemValues);
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+      nscCompData = null;
+    }
+    return nscCompData;
+
+  }
+
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDClusterMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDClusterMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDClusterMBean.java
new file mode 100644
index 0000000..8b31dd3
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDClusterMBean.java
@@ -0,0 +1,32 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.openmbean.CompositeData;
+
+public interface GemFireXDClusterMBean {
+  public static final String OBJECT_NAME = "GemFireXD:service=Cluster";
+
+  public int getProcedureCallsCompleted();
+
+  public int getProcedureCallsInProgress();
+
+  public CompositeData getNetworkServerClientConnectionStats();
+
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMember.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMember.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMember.java
new file mode 100644
index 0000000..b2faca4
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMember.java
@@ -0,0 +1,80 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.CompositeDataSupport;
+import javax.management.openmbean.CompositeType;
+import javax.management.openmbean.OpenDataException;
+import javax.management.openmbean.OpenType;
+import javax.management.openmbean.SimpleType;
+
+public class GemFireXDMember extends JMXBaseBean implements
+    GemFireXDMemberMBean {
+  private String name = null;
+
+  private static String[] itemNames = { "connectionsAttempted",
+      "connectionsActive", "connectionsClosed", "connectionsFailed" };;
+  private static String[] itemDescriptions = { "connectionsAttempted",
+      "connectionsActive", "connectionsClosed", "connectionsFailed" };
+  private static OpenType[] itemTypes = { SimpleType.LONG, SimpleType.LONG,
+      SimpleType.LONG, SimpleType.LONG };
+  private static CompositeType networkServerClientConnectionStats = null;
+
+  static {
+    try {
+      networkServerClientConnectionStats = new CompositeType(
+          "NetworkServerClientConnectionStats",
+          "Network Server Client Connection Stats Information", itemNames,
+          itemDescriptions, itemTypes);
+
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+    }
+  }
+
+  public GemFireXDMember(String name) {
+    this.name = name;
+  }
+
+  @Override
+  protected String getKey(String propName) {
+    return "gemfirexdmember." + name + "." + propName;
+  }
+
+  @Override
+  public boolean getDataStore() {
+    return getBoolean("DataStore");
+  }
+
+  @Override
+  public CompositeData getNetworkServerClientConnectionStats() {
+    Long[] itemValues = getLongArray("NetworkServerClientConnectionStats");
+    CompositeData nscCompData;
+    try {
+      nscCompData = new CompositeDataSupport(
+          networkServerClientConnectionStats, itemNames, itemValues);
+    } catch (OpenDataException e) {
+      e.printStackTrace();
+      nscCompData = null;
+    }
+    return nscCompData;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMemberMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMemberMBean.java
new file mode 100644
index 0000000..91491ea
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/GemFireXDMemberMBean.java
@@ -0,0 +1,31 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import javax.management.openmbean.CompositeData;
+
+public interface GemFireXDMemberMBean {
+
+  public static final String OBJECT_NAME = "GemFireXD:group=DEFAULT,type=Member";
+
+  public boolean getDataStore();
+
+  public CompositeData getNetworkServerClientConnectionStats();
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXBaseBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXBaseBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXBaseBean.java
new file mode 100644
index 0000000..5bf1481
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXBaseBean.java
@@ -0,0 +1,67 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public abstract class JMXBaseBean {
+
+  protected abstract String getKey(String propName);
+
+  protected String getString(String key) {
+    return JMXProperties.getInstance().getProperty(getKey(key));
+  }
+
+  protected String[] getStringArray(String key) {
+    return JMXProperties.getInstance().getProperty(getKey(key), "").split(" ");
+  }
+
+  protected boolean getBoolean(String key) {
+    return Boolean.parseBoolean(JMXProperties.getInstance().getProperty(
+        getKey(key)));
+  }
+
+  protected int getInt(String key) {
+    return Integer.parseInt(JMXProperties.getInstance()
+        .getProperty(getKey(key)));
+  }
+
+  protected long getLong(String key) {
+    return Long.parseLong(JMXProperties.getInstance().getProperty(getKey(key)));
+  }
+
+  protected Long[] getLongArray(String key) {
+    String value = JMXProperties.getInstance().getProperty(getKey(key), "");
+    String[] values = value.split(",");
+    Long[] longValues = new Long[values.length];
+    for (int i = 0; i < values.length; i++) {
+      longValues[i] = Long.parseLong(values[i]);
+    }
+    return longValues;
+  }
+
+  protected double getDouble(String key) {
+    return Double.parseDouble(JMXProperties.getInstance().getProperty(
+        getKey(key)));
+  }
+
+  protected float getFloat(String key) {
+    return Float.parseFloat(JMXProperties.getInstance()
+        .getProperty(getKey(key)));
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXProperties.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXProperties.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXProperties.java
new file mode 100644
index 0000000..cb5d0fc
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/JMXProperties.java
@@ -0,0 +1,47 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.IOException;
+import java.util.Properties;
+
+public class JMXProperties extends Properties {
+  private static final long serialVersionUID = -6210901350494570026L;
+
+  private static JMXProperties props = new JMXProperties();
+
+  public static JMXProperties getInstance() {
+    return props;
+  }
+
+  public void load(String propFile) throws IOException {
+    if (propFile != null) {
+      FileInputStream fin;
+      fin = new FileInputStream(new File(propFile));
+      if (fin != null) {
+        clear();
+        load(fin);
+      }
+
+      fin.close();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Member.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Member.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Member.java
new file mode 100644
index 0000000..d4606c5
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/Member.java
@@ -0,0 +1,193 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public class Member extends JMXBaseBean implements MemberMBean {
+  private String name = null;
+
+  public Member(String name) {
+    this.name = name;
+  }
+
+  protected String getKey(String propName) {
+    return "member." + name + "." + propName;
+  }
+
+  @Override
+  public boolean getManager() {
+    return getBoolean("manager");
+  }
+
+  @Override
+  public int getTotalRegionCount() {
+// This count is built dynamically in Pulse backend and region count is maintained in Cluster.Member data structure
+//    return getInt("totalRegionCount");
+    return 0;
+  }
+
+  @Override
+  public boolean getLocator() {
+    return getBoolean("locator");
+  }
+
+  @Override
+  public long getTotalDiskUsage() {
+    return getLong("totalDiskUsage");
+  }
+
+  @Override
+  public boolean getServer() {
+    return getBoolean("sever");
+  }
+
+  @Override
+  public String[] getGroups() {
+    return getStringArray("Groups");
+  }
+
+  @Override
+  /*public String[] getRedundancyZone() {
+    return getStringArray("RedundancyZone");
+  }*/
+  public String getRedundancyZone() {
+    return getString("RedundancyZone");
+  }
+
+  @Override
+  public long getTotalFileDescriptorOpen() {
+    return getLong("totalFileDescriptorOpen");
+  }
+
+  @Override
+  public double getLoadAverage() {
+    return getDouble("loadAverage");
+  }
+
+  @Override
+  public double getDiskWritesRate() {
+    return getDouble("diskWritesRate");
+  }
+
+  @Override
+  public long getJVMPauses() {
+    return getLong("JVMPauses");
+  }
+
+  @Override
+  public long getCurrentHeapSize() {
+//    return getLong("currentHeapSize");
+    return getLong("UsedMemory");
+  }
+
+  @Override
+  public long getMaximumHeapSize() {
+//    return getLong("maximumHeapSize");
+    return getLong("MaxMemory");
+  }
+
+  @Override
+  public long getUsedMemory() {
+    return getLong("UsedMemory");
+  }
+
+  @Override
+  public long getMaxMemory() {
+    return getLong("MaxMemory");
+  }
+
+  @Override
+  public int getNumThreads() {
+    return getInt("numThreads");
+  }
+
+  @Override
+  public long getMemberUpTime() {
+    return getLong("memberUpTime");
+  }
+
+  @Override
+  public String getHost() {
+    return getString("host");
+  }
+
+  @Override
+  public long getTotalBytesOnDisk() {
+    return getLong("totalBytesOnDisk");
+  }
+
+  @Override
+  public double getCpuUsage() {
+    return getDouble("cpuUsage");
+  }
+
+  @Override
+  public String getMember() {
+    return getString("member");
+  }
+
+  @Override
+  public String getId() {
+    return getString("id");
+  }
+
+  @Override
+  public double getAverageReads() {
+    return getDouble("averageReads");
+  }
+
+  @Override
+  public double getAverageWrites() {
+    return getDouble("averageWrites");
+  }
+
+  @Override
+  public int getPort() {
+    return getInt("port");
+  }
+
+  @Override
+  public long getFoo() {
+    return getLong("foo");
+  }
+
+  @Override
+  public long getOffHeapFreeSize() {
+    return getLong("OffHeapFreeSize");
+  }
+
+  @Override
+  public long getOffHeapUsedSize() {
+    return getLong("OffHeapUsedSize");
+  }
+
+  @Override
+  public long getOffHeapFreeMemory() {
+    return getLong("OffHeapFreeMemory");
+  }
+
+  @Override
+  public long getOffHeapUsedMemory() {
+    return getLong("OffHeapUsedMemory");
+  }
+
+  @Override
+  public String getVersion() {
+    return getString("Version");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/MemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/MemberMBean.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/MemberMBean.java
new file mode 100644
index 0000000..ad3c2a1
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/MemberMBean.java
@@ -0,0 +1,86 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+public interface MemberMBean {
+  String OBJECT_NAME = "GemFire:type=Member";
+
+  boolean getManager();
+
+  int getTotalRegionCount();
+
+  boolean getLocator();
+
+  long getTotalDiskUsage();
+
+  boolean getServer();
+
+  String[] getGroups();
+
+  //public String[] getRedundancyZone();
+  String getRedundancyZone();
+
+  long getTotalFileDescriptorOpen();
+
+  double getLoadAverage();
+
+  double getDiskWritesRate();
+
+  long getJVMPauses();
+
+  long getCurrentHeapSize();
+
+  long getMaximumHeapSize();
+
+  long getUsedMemory();
+
+  long getMaxMemory();
+
+  int getNumThreads();
+
+  long getMemberUpTime();
+
+  String getHost();
+
+  long getTotalBytesOnDisk();
+
+  double getCpuUsage();
+
+  String getMember();
+
+  String getId();
+
+  double getAverageReads();
+
+  double getAverageWrites();
+
+  int getPort();
+
+  long getFoo();
+
+  long getOffHeapFreeSize();
+
+  long getOffHeapUsedSize();
+
+  long getOffHeapFreeMemory();
+
+  long getOffHeapUsedMemory();
+
+  String getVersion();
+}


[11/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXCommitMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXCommitMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXCommitMessage.java
index c3ff698..4802fba 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXCommitMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXCommitMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -33,49 +33,49 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.CommitDistributionException;
-import com.gemstone.gemfire.cache.CommitIncompleteException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.RegionDistributionException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.TransactionListener;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.locks.TXLockId;
-import com.gemstone.gemfire.internal.cache.locks.TXLockIdImpl;
-import com.gemstone.gemfire.internal.cache.locks.TXLockService;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.CommitDistributionException;
+import org.apache.geode.cache.CommitIncompleteException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.RegionDistributionException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.TransactionListener;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReliableReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.locks.TXLockId;
+import org.apache.geode.internal.cache.locks.TXLockIdImpl;
+import org.apache.geode.internal.cache.locks.TXLockService;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /** TXCommitMessage is the message that contains all the information
  * that needs to be distributed, on commit, to other cache members.
@@ -2165,7 +2165,7 @@ public class TXCommitMessage extends PooledDistributionMessage implements Member
    * to bug 32999 and the recovery when the TXLock Lessor (the sending
    * VM) crashes/departs before or while sending the TXCommitMessage.
    * @see TXState#commit()
-   * @see com.gemstone.gemfire.internal.cache.locks.TXLockBatch#getBatchId()
+   * @see org.apache.geode.internal.cache.locks.TXLockBatch#getBatchId()
    */
   private void updateLockMembers() {
     if (this.lockNeedsUpdate && this.lockId != null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntry.java
index 317f4e6..d6c8854 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntry.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Hashtable;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CacheStatistics;
-import com.gemstone.gemfire.cache.EntryDestroyedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.StatisticsDisabledException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CacheStatistics;
+import org.apache.geode.cache.EntryDestroyedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.StatisticsDisabledException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /** ******************* Class Entry ***************************************** */
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryState.java
index 9ae0ac3..b2af6ea 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryState.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.OffHeapHelper;
-import com.gemstone.gemfire.internal.offheap.Releasable;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.pdx.PdxSerializationException;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.OffHeapHelper;
+import org.apache.geode.internal.offheap.Releasable;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.pdx.PdxSerializationException;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -44,7 +44,7 @@ import java.util.ArrayList;
 import java.util.List;
 import java.util.Set;
 
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.TX_ENTRY_STATE;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.TX_ENTRY_STATE;
 
 /**
  * TXEntryState is the entity that tracks transactional changes, except for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryStateFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryStateFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryStateFactory.java
index 3cb5d37..c441af2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryStateFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryStateFactory.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.RegionEntry;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryUserAttrState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryUserAttrState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryUserAttrState.java
index d53fce0..aaaca24 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryUserAttrState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEntryUserAttrState.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * TXEntryUserAttrState is the entity that tracks transactional changes

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEvent.java
index b2bd140..e02bcf8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXEvent.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.cache.*;
+package org.apache.geode.internal.cache;
+import org.apache.geode.cache.*;
 import java.util.*;
-import com.gemstone.gemfire.internal.offheap.Releasable;
+import org.apache.geode.internal.offheap.Releasable;
 
 /** <p>The internal implementation of the {@link TransactionEvent} interface
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXFarSideCMTracker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXFarSideCMTracker.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXFarSideCMTracker.java
index 90e337d..3959110 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXFarSideCMTracker.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXFarSideCMTracker.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 import java.util.Arrays;
 import java.util.Collections;
 import java.util.HashMap;
@@ -27,14 +27,14 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.locks.TXLockId;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.locks.TXLockId;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /** 
  * TXFarSideCMTracker tracks received and processed TXCommitMessages,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXId.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXId.java
index c5e6822..eadff91 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXId.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXId.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.internal.ExternalizableDSFID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.internal.DSFIDFactory;
+package org.apache.geode.internal.cache;
+import org.apache.geode.internal.ExternalizableDSFID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.internal.DSFIDFactory;
 import java.io.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /** The implementation of the {@link TransactionId} interface stored
  * in the transaction state and used, amoung other things, to uniquely
@@ -33,7 +33,7 @@ import com.gemstone.gemfire.distributed.internal.membership.*;
  * @since GemFire 4.0
  * 
  * @see TXManagerImpl#begin
- * @see com.gemstone.gemfire.cache.CacheTransactionManager#getTransactionId
+ * @see org.apache.geode.cache.CacheTransactionManager#getTransactionId
  */
 public final class TXId
   extends ExternalizableDSFID

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXLockRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXLockRequest.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXLockRequest.java
index 5f8283e..74d6f16 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXLockRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXLockRequest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.cache.locks.*;
+package org.apache.geode.internal.cache;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.cache.locks.*;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
index ab082e0..4654a75 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.TXManagerCancelledException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.SystemTimer.SystemTimerTask;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Message;
-import com.gemstone.gemfire.internal.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.MapCallback;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.DataSerializer;
+import org.apache.geode.GemFireException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.TXManagerCancelledException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.SystemTimer.SystemTimerTask;
+import org.apache.geode.internal.cache.tier.sockets.Message;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.MapCallback;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
@@ -146,7 +146,7 @@ public class TXManagerImpl implements CacheTransactionManager,
   private int transactionTimeToLive;
   
   /** Constructor that implements the {@link CacheTransactionManager}
-   * interface. Only only one instance per {@link com.gemstone.gemfire.cache.Cache}
+   * interface. Only only one instance per {@link org.apache.geode.cache.Cache}
    *
    * @param cachePerfStats 
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXMessage.java
index 4918508..d8d2ed9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,24 +22,24 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionLockRequestImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionLockRequestImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionLockRequestImpl.java
index 6327ed7..d49f4b2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionLockRequestImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionLockRequestImpl.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,11 +25,11 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /** TXRegionLockRequest represents all the locks that need to be made
  * for a single region.
@@ -39,7 +39,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * 
  */
 public class TXRegionLockRequestImpl
-  implements com.gemstone.gemfire.internal.cache.locks.TXRegionLockRequest
+  implements org.apache.geode.internal.cache.locks.TXRegionLockRequest
 {
   private static final long serialVersionUID = 5840033961584078082L;
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionState.java
index 479beb2..4026013 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRegionState.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+package org.apache.geode.internal.cache;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 import java.util.*;
 import java.util.Map.Entry;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteCommitMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteCommitMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteCommitMessage.java
index f0eb8d1..c6d6f66 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteCommitMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteCommitMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,23 +24,23 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.RemoteOperationMessage.RemoteOperationResponse;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.RemoteOperationMessage.RemoteOperationResponse;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * 
@@ -248,7 +248,7 @@ public class TXRemoteCommitMessage extends TXMessage {
 
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage}
+   * org.apache.geode.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage}
    * 
    * @since GemFire 6.6
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteRollbackMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteRollbackMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteRollbackMessage.java
index 96677f6..fdfd3e2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteRollbackMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRemoteRollbackMessage.java
@@ -14,23 +14,23 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collections;
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReliableReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXReservationMgr.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXReservationMgr.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXReservationMgr.java
index 2690419..80ffcc9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXReservationMgr.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXReservationMgr.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.cache.locks.*;
+package org.apache.geode.internal.cache;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.cache.locks.*;
 //import java.io.*;
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXRmtEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRmtEvent.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRmtEvent.java
index 3de52fd..5696b19 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXRmtEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXRmtEvent.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.Iterator;
 import java.util.List;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionEvent;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionEvent;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * <p>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXState.java
index 3223f12..fa63bcd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXState.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -33,38 +33,38 @@ import javax.transaction.Status;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.SynchronizationCommitConflictException;
-import com.gemstone.gemfire.cache.TransactionDataRebalancedException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.TransactionWriter;
-import com.gemstone.gemfire.cache.TransactionWriterException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.TXManagerCancelledException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.control.MemoryThresholds;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.SynchronizationCommitConflictException;
+import org.apache.geode.cache.TransactionDataRebalancedException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.TransactionWriter;
+import org.apache.geode.cache.TransactionWriterException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.cache.client.internal.ServerRegionDataAccess;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.TXManagerCancelledException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.control.MemoryThresholds;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /** TXState is the entity that tracks the transaction state on a per
  * thread basis, noting changes to Region entries on a per operation
@@ -199,7 +199,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getTransactionId()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getTransactionId()
    */
   public TransactionId getTransactionId() {
     return this.proxy.getTxId();
@@ -231,7 +231,7 @@ public class TXState implements TXStateInterface {
   
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#readRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#readRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState readRegion(LocalRegion r) {
     return this.regions.get(r);
@@ -243,7 +243,7 @@ public class TXState implements TXStateInterface {
     }
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#writeRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#writeRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState writeRegion(LocalRegion r) {
     TXRegionState result = readRegion(r);
@@ -262,13 +262,13 @@ public class TXState implements TXStateInterface {
     return result;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getBeginTime()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getBeginTime()
    */
   public long getBeginTime() {
     return this.beginTime;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getChanges()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getChanges()
    */
   public int getChanges() {
     int changes = 0;
@@ -280,21 +280,21 @@ public class TXState implements TXStateInterface {
     return changes;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgress()
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgress()
    */
   public boolean isInProgress() {
     return !this.closed;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#nextModSerialNum()
+   * @see org.apache.geode.internal.cache.TXStateInterface#nextModSerialNum()
    */
   public int nextModSerialNum() {
     this.modSerialNum += 1;
     return this.modSerialNum;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#needsLargeModCount()
+   * @see org.apache.geode.internal.cache.TXStateInterface#needsLargeModCount()
    */
   public boolean needsLargeModCount() {
     return this.modSerialNum > Byte.MAX_VALUE;
@@ -341,7 +341,7 @@ public class TXState implements TXStateInterface {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#commit()
+   * @see org.apache.geode.internal.cache.TXStateInterface#commit()
    */
   public void commit() throws CommitConflictException {    
     if (this.closed) {
@@ -520,7 +520,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#rollback()
+   * @see org.apache.geode.internal.cache.TXStateInterface#rollback()
    */
   public void rollback() {
     if (this.closed) {
@@ -835,7 +835,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEvents()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEvents()
    */
   public List getEvents() {
     ArrayList events = new ArrayList();
@@ -909,7 +909,7 @@ public class TXState implements TXStateInterface {
   //           JTA Synchronization implementation                 //
   //////////////////////////////////////////////////////////////////
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#beforeCompletion()
+   * @see org.apache.geode.internal.cache.TXStateInterface#beforeCompletion()
    */
   public void beforeCompletion() throws SynchronizationCommitConflictException {
     if (this.closed) {
@@ -967,7 +967,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#afterCompletion(int)
+   * @see org.apache.geode.internal.cache.TXStateInterface#afterCompletion(int)
    */
   public void afterCompletion(int status) {
     // System.err.println("start afterCompletion");
@@ -1091,14 +1091,14 @@ public class TXState implements TXStateInterface {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getCache()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getCache()
    */
   public Cache getCache() {
     return this.proxy.getTxMgr().getCache();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getRegions()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getRegions()
    */
   public Collection<LocalRegion> getRegions() {
     return this.regions.keySet();
@@ -1218,7 +1218,7 @@ public class TXState implements TXStateInterface {
   
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#containsValueForKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#containsValueForKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsValueForKey(KeyInfo keyInfo, LocalRegion region) {
     TXEntryState tx = txReadEntry(keyInfo, region, true, true/*create txEntry is absent*/);
@@ -1236,7 +1236,7 @@ public class TXState implements TXStateInterface {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#destroyExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#destroyExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, java.lang.Object)
    */
   public void destroyExistingEntry(final EntryEventImpl event, final boolean cacheWrite, Object expectedOldValue) {
     if(bridgeContext==null) {
@@ -1255,7 +1255,7 @@ public class TXState implements TXStateInterface {
     }
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#invalidateExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#invalidateExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(final EntryEventImpl event, boolean invokeCallbacks, boolean forceNewEntry) {
     if(bridgeContext==null) {
@@ -1311,7 +1311,7 @@ public class TXState implements TXStateInterface {
     return tx;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntry(final KeyInfo keyInfo, final LocalRegion region, boolean allowTombstones) {
     TXEntryState tx = txReadEntry(keyInfo, region, true, true/*create txEntry is absent*/);
@@ -1401,7 +1401,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getDeserializedValue(KeyInfo keyInfo,
                                      LocalRegion localRegion,
@@ -1426,7 +1426,7 @@ public class TXState implements TXStateInterface {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getSerializedValue(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#getSerializedValue(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
    */
   @Retained
   public Object getSerializedValue(LocalRegion localRegion,
@@ -1454,7 +1454,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#entryCount(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#entryCount(org.apache.geode.internal.cache.LocalRegion)
    */
   public int entryCount(LocalRegion localRegion) {
     int result = localRegion.getRegionSize();
@@ -1472,7 +1472,7 @@ public class TXState implements TXStateInterface {
     }
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#containsKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#containsKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsKey(KeyInfo keyInfo, LocalRegion localRegion) {
     TXEntryState tx = txReadEntry(keyInfo, localRegion, true,true/*create txEntry is absent*/);
@@ -1483,7 +1483,7 @@ public class TXState implements TXStateInterface {
     }
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getValueInVM(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getValueInVM(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   @Retained
   public Object getValueInVM(KeyInfo keyInfo, LocalRegion localRegion,
@@ -1496,7 +1496,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#putEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#putEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntry(EntryEventImpl event, boolean ifNew, boolean ifOld,
       Object expectedOldValue, boolean requireOldValue, long lastModified,
@@ -1519,13 +1519,13 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#isStatsDeferred()
+   * @see org.apache.geode.internal.cache.InternalDataView#isStatsDeferred()
    */
   public boolean isDeferredStats() {
     return true;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#findObject(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#findObject(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
    */
   public Object findObject(KeyInfo key,
                            LocalRegion r,
@@ -1554,7 +1554,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEntryForIterator(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEntryForIterator(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, boolean)
    */
   public Object getEntryForIterator(KeyInfo curr, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -1582,7 +1582,7 @@ public class TXState implements TXStateInterface {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getKeyForIterator(KeyInfo curr, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -1594,7 +1594,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getAdditionalKeysForIterator(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getAdditionalKeysForIterator(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getAdditionalKeysForIterator(LocalRegion currRgn) {
     if (currRgn instanceof PartitionedRegion) {
@@ -1622,7 +1622,7 @@ public class TXState implements TXStateInterface {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgressAndSameAs(com.gemstone.gemfire.internal.cache.TXStateInterface)
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgressAndSameAs(org.apache.geode.internal.cache.TXStateInterface)
    */
   public boolean isInProgressAndSameAs(TXStateInterface otherState) {
     return isInProgress() && otherState == this;
@@ -1630,7 +1630,7 @@ public class TXState implements TXStateInterface {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntryOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntryOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntryOnRemote(EntryEventImpl event, boolean ifNew,
       boolean ifOld, Object expectedOldValue, boolean requireOldValue,
@@ -1682,7 +1682,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getBucketKeys(com.gemstone.gemfire.internal.cache.LocalRegion, int)
+   * @see org.apache.geode.internal.cache.InternalDataView#getBucketKeys(org.apache.geode.internal.cache.LocalRegion, int)
    */
   public Set getBucketKeys(LocalRegion localRegion, int bucketId, boolean allowTombstones) {
     PartitionedRegion pr = (PartitionedRegion)localRegion;
@@ -1690,7 +1690,7 @@ public class TXState implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntryOnRemote(KeyInfo key, LocalRegion localRegion, boolean allowTombstones)
       throws DataLocationException {
@@ -1707,14 +1707,14 @@ public class TXState implements TXStateInterface {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getSemaphore()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getSemaphore()
    */
   public ReentrantLock getLock() {
     return proxy.getLock();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getRegionKeysForIteration(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getRegionKeysForIteration(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getRegionKeysForIteration(LocalRegion currRegion) {
     return currRegion.getRegionKeysForIteration();
@@ -1748,7 +1748,7 @@ public class TXState implements TXStateInterface {
   /*
    * For TX this needs to be a PR passed in as region
    *
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#postPutAll(com.gemstone.gemfire.internal.cache.DistributedPutAllOperation, java.util.Map, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#postPutAll(org.apache.geode.internal.cache.DistributedPutAllOperation, java.util.Map, org.apache.geode.internal.cache.LocalRegion)
    */
   public void postPutAll(final DistributedPutAllOperation putallOp, final VersionedObjectList successfulPuts,LocalRegion reg) {
 	  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateInterface.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateInterface.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateInterface.java
index 865ebd5..d1ce3a8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateInterface.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateInterface.java
@@ -17,7 +17,7 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.List;
@@ -25,14 +25,14 @@ import java.util.concurrent.locks.ReentrantLock;
 
 import javax.transaction.Synchronization;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.client.internal.ServerRegionDataAccess;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
 
 /**
  * An entity that tracks transactions must implement this interface. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxy.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxy.java
index 8f8d1cd..9edf1db 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxy.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxy.java
@@ -17,12 +17,12 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.cache.client.internal.ServerRegionDataAccess;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
 
 /**
  * This interface extends {@link TXStateInterface} providing for a proxy for the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxyImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxyImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxyImpl.java
index c4ebadd..412ce09 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxyImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateProxyImpl.java
@@ -17,7 +17,7 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.HashMap;
@@ -29,26 +29,26 @@ import java.util.concurrent.locks.ReentrantLock;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.cache.TransactionDataRebalancedException;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionDataAccess;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub;
-import com.gemstone.gemfire.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.GemFireException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.cache.TransactionDataRebalancedException;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.cache.client.internal.ServerRegionDataAccess;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.ClientTXStateStub;
+import org.apache.geode.internal.cache.tx.TransactionalOperation.ServerRegionOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  *
@@ -93,7 +93,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getSemaphore()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getSemaphore()
    */
   public ReentrantLock getLock() {
     return this.lock;
@@ -220,10 +220,10 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#checkJTA(java.lang.String)
+   * @see org.apache.geode.internal.cache.TXStateInterface#checkJTA(java.lang.String)
    */
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxyInterface#checkJTA(java.lang.String)
+   * @see org.apache.geode.internal.cache.TXStateProxyInterface#checkJTA(java.lang.String)
    */
   public void checkJTA(String errmsg) throws IllegalStateException {
     if (isJTA()) {
@@ -240,7 +240,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#commit()
+   * @see org.apache.geode.internal.cache.TXStateInterface#commit()
    */
   public void commit() throws CommitConflictException {
     boolean preserveTx = false;
@@ -277,7 +277,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#containsValueForKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#containsValueForKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsValueForKey(KeyInfo keyInfo, LocalRegion region) {
     try {
@@ -303,7 +303,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#destroyExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#destroyExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, java.lang.Object)
    */
   public void destroyExistingEntry(EntryEventImpl event, boolean cacheWrite,
       Object expectedOldValue) throws EntryNotFoundException {
@@ -317,21 +317,21 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getBeginTime()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getBeginTime()
    */
   public long getBeginTime() {
     return getRealDeal(null, null).getBeginTime();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getCache()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getCache()
    */
   public Cache getCache() {
     return txMgr.getCache();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getChanges()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getChanges()
    */
   public int getChanges() {
     assertBootstrapped();
@@ -339,7 +339,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getDeserializedValue(KeyInfo keyInfo,
                                      LocalRegion localRegion,
@@ -360,7 +360,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntry(KeyInfo keyInfo, LocalRegion region, boolean allowTombstones) {
     try {
@@ -374,7 +374,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEvent()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEvent()
    */
   public TXEvent getEvent() {
     assertBootstrapped();
@@ -382,7 +382,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEvents()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEvents()
    */
   public List getEvents() {
     assertBootstrapped();
@@ -390,7 +390,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getRegions()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getRegions()
    */
   public Collection<LocalRegion> getRegions() {
     assertBootstrapped();
@@ -398,14 +398,14 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getTransactionId()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getTransactionId()
    */
   public TransactionId getTransactionId() {
     return txId;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#invalidateExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#invalidateExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(EntryEventImpl event,
       boolean invokeCallbacks, boolean forceNewEntry) {
@@ -419,7 +419,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgress()
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgress()
    */
   public boolean isInProgress() {
     return inProgress;
@@ -431,7 +431,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#needsLargeModCount()
+   * @see org.apache.geode.internal.cache.TXStateInterface#needsLargeModCount()
    */
   public boolean needsLargeModCount() {
     assertBootstrapped();
@@ -439,7 +439,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#nextModSerialNum()
+   * @see org.apache.geode.internal.cache.TXStateInterface#nextModSerialNum()
    */
   public int nextModSerialNum() {
     assertBootstrapped();
@@ -447,7 +447,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#readRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#readRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState readRegion(LocalRegion r) {
     assertBootstrapped();
@@ -455,7 +455,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#rmRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#rmRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public void rmRegion(LocalRegion r) {
     assertBootstrapped();
@@ -463,7 +463,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#rollback()
+   * @see org.apache.geode.internal.cache.TXStateInterface#rollback()
    */
   public void rollback() {
     try {
@@ -477,7 +477,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txPutEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txPutEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, boolean)
    */
   public boolean txPutEntry(EntryEventImpl event, boolean ifNew,
       boolean requireOldValue, boolean checkResources, Object expectedOldValue) {
@@ -492,7 +492,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txReadEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txReadEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public TXEntryState txReadEntry(KeyInfo keyInfo, LocalRegion localRegion,
       boolean rememberRead,boolean createTxEntryIfAbsent) {
@@ -508,7 +508,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txReadRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txReadRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState txReadRegion(LocalRegion localRegion) {
     assertBootstrapped();
@@ -516,14 +516,14 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txWriteRegion(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txWriteRegion(org.apache.geode.internal.cache.LocalRegion, java.lang.Object)
    */
   public TXRegionState txWriteRegion(LocalRegion localRegion, KeyInfo entryKey) {
     return getRealDeal(entryKey, localRegion).txWriteRegion(localRegion, entryKey);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#writeRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#writeRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState writeRegion(LocalRegion r) {
     assertBootstrapped();
@@ -558,7 +558,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#containsKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#containsKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsKey(KeyInfo keyInfo, LocalRegion localRegion) {
     try {
@@ -572,7 +572,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#entryCount(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#entryCount(org.apache.geode.internal.cache.LocalRegion)
    */
   @edu.umd.cs.findbugs.annotations.SuppressWarnings(value="UL_UNRELEASED_LOCK", justification="This method unlocks and then conditionally undoes the unlock in the finally-block. Review again at later time.") 
   public int entryCount(LocalRegion localRegion) {
@@ -603,7 +603,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#findObject(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#findObject(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
    */
   public Object findObject(KeyInfo key, LocalRegion r, boolean isCreate,
                            boolean generateCallbacks, Object value, boolean disableCopyOnRead,
@@ -621,7 +621,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getAdditionalKeysForIterator(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getAdditionalKeysForIterator(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getAdditionalKeysForIterator(LocalRegion currRgn) {
     if (this.realDeal == null) {
@@ -631,7 +631,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryForIterator(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryForIterator(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, boolean)
    */
   public Object getEntryForIterator(KeyInfo key, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -654,7 +654,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getKeyForIterator(KeyInfo keyInfo, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -676,7 +676,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getValueInVM(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getValueInVM(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getValueInVM(KeyInfo keyInfo, LocalRegion localRegion,
       boolean rememberRead) {
@@ -685,7 +685,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#isDeferredStats()
+   * @see org.apache.geode.internal.cache.InternalDataView#isDeferredStats()
    */
   public boolean isDeferredStats() {
     assertBootstrapped();
@@ -693,7 +693,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntry(EntryEventImpl event, boolean ifNew, boolean ifOld,
       Object expectedOldValue, boolean requireOldValue, long lastModified,
@@ -710,14 +710,14 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgressAndSameAs(com.gemstone.gemfire.internal.cache.TXStateInterface)
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgressAndSameAs(org.apache.geode.internal.cache.TXStateInterface)
    */
   public boolean isInProgressAndSameAs(TXStateInterface otherState) {
     return isInProgress() && otherState == this; 
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxy#setLocalTXState(com.gemstone.gemfire.internal.cache.TXState)
+   * @see org.apache.geode.internal.cache.TXStateProxy#setLocalTXState(org.apache.geode.internal.cache.TXState)
    */
   public void setLocalTXState(TXStateInterface state) {
     this.realDeal = state;
@@ -725,7 +725,7 @@ public class TXStateProxyImpl implements TXStateProxy {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getSerializedValue(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#getSerializedValue(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
    */
   public Object getSerializedValue(LocalRegion localRegion,
                                    KeyInfo key,
@@ -738,7 +738,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntryOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntryOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntryOnRemote(EntryEventImpl event, boolean ifNew,
       boolean ifOld, Object expectedOldValue, boolean requireOldValue,
@@ -755,7 +755,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#destroyOnRemote(java.lang.Integer, com.gemstone.gemfire.internal.cache.EntryEventImpl, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#destroyOnRemote(java.lang.Integer, org.apache.geode.internal.cache.EntryEventImpl, java.lang.Object)
    */
   public void destroyOnRemote(EntryEventImpl event, boolean cacheWrite,
       Object expectedOldValue) throws DataLocationException {
@@ -766,7 +766,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#invalidateOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#invalidateOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateOnRemote(EntryEventImpl event, boolean invokeCallbacks,
       boolean forceNewEntry) throws DataLocationException {
@@ -793,7 +793,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getBucketKeys(com.gemstone.gemfire.internal.cache.LocalRegion, int)
+   * @see org.apache.geode.internal.cache.InternalDataView#getBucketKeys(org.apache.geode.internal.cache.LocalRegion, int)
    */
   public Set getBucketKeys(LocalRegion localRegion, int bucketId, boolean allowTombstones) {
     //if this the first operation in a transaction, reset txState
@@ -815,7 +815,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntryOnRemote(KeyInfo keyInfo, LocalRegion localRegion, boolean allowTombstones)
       throws DataLocationException {
@@ -830,14 +830,14 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxy#getTarget()
+   * @see org.apache.geode.internal.cache.TXStateProxy#getTarget()
    */
   public DistributedMember getTarget() {
     return this.target;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxy#setTarget(com.gemstone.gemfire.distributed.DistributedMember)
+   * @see org.apache.geode.internal.cache.TXStateProxy#setTarget(org.apache.geode.distributed.DistributedMember)
    */
   public void setTarget(DistributedMember target) {
     assert this.target == null;
@@ -845,7 +845,7 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getRegionKeysForIteration(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getRegionKeysForIteration(org.apache.geode.internal.cache.LocalRegion)
    */
   public Collection<?> getRegionKeysForIteration(LocalRegion currRegion) {
     if (currRegion.isUsedForPartitionedRegionBucket()) {
@@ -856,14 +856,14 @@ public class TXStateProxyImpl implements TXStateProxy {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxy#isCommitRequestedByOwner()
+   * @see org.apache.geode.internal.cache.TXStateProxy#isCommitRequestedByOwner()
    */
   public boolean isCommitOnBehalfOfRemoteStub() {
     return this.commitRequestedByOwner;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateProxy#setCommitRequestedByOwner()
+   * @see org.apache.geode.internal.cache.TXStateProxy#setCommitRequestedByOwner()
    */
   public boolean setCommitOnBehalfOfRemoteStub(boolean requestedByOwner) {
     return this.commitRequestedByOwner = requestedByOwner;


[51/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
GEODE-37 changed import statement from com.gemstone.gemfire to
org.apache.geode


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

Branch: refs/heads/feature/GEODE-37_1
Commit: 939fcf2f310c1a222d972e2f7b8840c80c6a4a78
Parents: 0b4019e
Author: Hitesh Khamesra <hk...@pivotal.io>
Authored: Fri Sep 9 13:47:27 2016 -0700
Committer: Hitesh Khamesra <hk...@pivotal.io>
Committed: Fri Sep 9 13:47:27 2016 -0700

----------------------------------------------------------------------
 README.md                                       |    4 +-
 .../release/conf/cache-peer.xml                 |    2 +-
 .../release/conf/cache-server.xml               |    2 +-
 .../geode-cs-tomcat-7/context-fragment.xml      |    4 +-
 .../geode-cs-tomcat-8/context-fragment.xml      |    4 +-
 .../tcserver/geode-cs/context-fragment.xml      |    2 +-
 .../tcserver/geode-cs/server-fragment.xml       |    2 +-
 .../geode-p2p-tomcat-7/context-fragment.xml     |    4 +-
 .../geode-p2p-tomcat-8/context-fragment.xml     |    4 +-
 .../tcserver/geode-p2p/context-fragment.xml     |    2 +-
 .../tcserver/geode-p2p/server-fragment.xml      |    2 +-
 .../geode/modules/hibernate/EnumType.java       |    4 +-
 .../geode/modules/hibernate/GemFireCache.java   |   18 +-
 .../modules/hibernate/GemFireCacheListener.java |    8 +-
 .../modules/hibernate/GemFireCacheProvider.java |   26 +-
 .../hibernate/GemFireQueryCacheFactory.java     |    2 +-
 .../modules/hibernate/GemFireRegionFactory.java |   24 +-
 .../modules/hibernate/internal/Access.java      |   10 +-
 .../ClientServerRegionFactoryDelegate.java      |   30 +-
 .../hibernate/internal/CollectionAccess.java    |   12 +-
 .../hibernate/internal/EntityRegionWriter.java  |   10 +-
 .../hibernate/internal/EntityVersion.java       |    2 +-
 .../hibernate/internal/EntityVersionImpl.java   |    2 +-
 .../hibernate/internal/EntityWrapper.java       |    6 +-
 .../hibernate/internal/GemFireBaseRegion.java   |   16 +-
 .../internal/GemFireCollectionRegion.java       |    6 +-
 .../hibernate/internal/GemFireEntityRegion.java |   12 +-
 .../internal/GemFireQueryResultsRegion.java     |    6 +-
 .../modules/hibernate/internal/KeyWrapper.java  |    6 +-
 .../internal/NonStrictReadWriteAccess.java      |    2 +-
 .../hibernate/internal/ReadOnlyAccess.java      |    2 +-
 .../hibernate/internal/ReadWriteAccess.java     |    2 +-
 .../internal/RegionFactoryDelegate.java         |   24 +-
 .../hibernate/internal/TransactionalAccess.java |    2 +-
 .../java/org/apache/geode/modules/Event.java    |    2 +-
 .../geode/modules/HibernateJUnitTest.java       |   22 +-
 .../java/org/apache/geode/modules/Owner.java    |    2 +-
 .../java/org/apache/geode/modules/Person.java   |    2 +-
 .../org/apache/geode/modules/SecondVMTest.java  |   18 +-
 .../org/apache/geode/modules/Event.hbm.xml      |    2 +-
 .../org/apache/geode/modules/Person.hbm.xml     |    2 +-
 .../internal/common/AbstractSessionCache.java   |   10 +-
 .../session/internal/common/CacheProperty.java  |    2 +-
 .../common/ClientServerSessionCache.java        |   30 +-
 .../internal/common/PeerToPeerSessionCache.java |   28 +-
 .../session/internal/common/SessionCache.java   |    6 +-
 .../common/SessionExpirationCacheListener.java  |   10 +-
 .../session/internal/filter/Constants.java      |    4 +-
 .../internal/filter/DummySessionManager.java    |    4 +-
 .../internal/filter/GemfireHttpSession.java     |   18 +-
 .../filter/GemfireSessionException.java         |    2 +-
 .../internal/filter/GemfireSessionManager.java  |   46 +-
 .../internal/filter/ListenerEventType.java      |    2 +-
 .../session/internal/filter/SessionManager.java |    2 +-
 .../AbstractDeltaSessionAttributes.java         |    8 +-
 .../attributes/AbstractSessionAttributes.java   |    8 +-
 .../internal/filter/attributes/DeltaEvent.java  |   10 +-
 .../DeltaQueuedSessionAttributes.java           |    6 +-
 .../attributes/DeltaSessionAttributes.java      |    6 +-
 .../attributes/ImmediateSessionAttributes.java  |    6 +-
 .../attributes/QueuedSessionAttributes.java     |    6 +-
 .../filter/attributes/SessionAttributes.java    |    6 +-
 .../filter/util/NamedThreadFactory.java         |    2 +-
 .../filter/util/ThreadLocalSession.java         |    2 +-
 .../internal/filter/util/TypeAwareMap.java      |    4 +-
 .../session/internal/jmx/SessionStatistics.java |    2 +-
 .../internal/jmx/SessionStatisticsMXBean.java   |    2 +-
 extensions/geode-modules-session/build.gradle   |    2 +-
 .../session/filter/SessionCachingFilter.java    |   12 +-
 .../modules/session/filter/SessionListener.java |    4 +-
 .../modules/session/installer/Installer.java    |   16 +-
 .../session/installer/JarClassLoader.java       |    2 +-
 .../session/installer/args/Argument.java        |    2 +-
 .../session/installer/args/ArgumentHandler.java |    2 +-
 .../installer/args/ArgumentProcessor.java       |    2 +-
 .../session/installer/args/ArgumentValues.java  |    2 +-
 .../installer/args/URLArgumentHandler.java      |    2 +-
 .../installer/args/UnknownArgumentHandler.java  |    2 +-
 .../session/installer/args/UsageException.java  |    2 +-
 .../session/installer/InstallerJUnitTest.java   |    6 +-
 .../internal/filter/AbstractListener.java       |    2 +-
 .../session/internal/filter/BasicServlet.java   |    2 +-
 .../session/internal/filter/Callback.java       |    2 +-
 .../internal/filter/CallbackServlet.java        |    2 +-
 .../session/internal/filter/CommonTests.java    |    4 +-
 .../HttpSessionAttributeListenerImpl.java       |    2 +-
 .../filter/HttpSessionBindingListenerImpl.java  |    2 +-
 .../filter/HttpSessionListenerImpl.java         |    4 +-
 .../filter/HttpSessionListenerImpl2.java        |    4 +-
 .../internal/filter/MyServletTester.java        |    2 +-
 .../internal/filter/RendezvousManager.java      |    2 +-
 .../ServletRequestAttributeListenerImpl.java    |    2 +-
 .../filter/ServletRequestListenerImpl.java      |    2 +-
 .../SessionReplicationIntegrationJUnitTest.java |   16 +-
 .../filter/SessionReplicationJUnitTest.java     |    8 +-
 .../SessionReplicationLocalCacheJUnitTest.java  |    8 +-
 .../session/junit/ChildFirstClassLoader.java    |    4 +-
 .../modules/session/junit/NamedRunner.java      |    2 +-
 .../session/junit/PerTestClassLoaderRunner.java |    2 +-
 .../InstallerJUnitTest.web.xml.expected         |    4 +-
 .../catalina/Tomcat7DeltaSessionManager.java    |    2 +-
 .../session/Tomcat7SessionsJUnitTest.java       |    6 +-
 .../modules/session/catalina/DeltaSession8.java |   28 +-
 .../catalina/Tomcat8DeltaSessionManager.java    |    2 +-
 .../geode/modules/session/EmbeddedTomcat8.java  |    4 +-
 .../session/TestSessionsTomcat8Base.java        |   14 +-
 .../Tomcat8SessionsClientServerDUnitTest.java   |   32 +-
 .../session/Tomcat8SessionsDUnitTest.java       |   16 +-
 .../gatewaydelta/AbstractGatewayDeltaEvent.java |   10 +-
 .../modules/gatewaydelta/GatewayDelta.java      |    2 +-
 .../gatewaydelta/GatewayDeltaCreateEvent.java   |   16 +-
 .../gatewaydelta/GatewayDeltaDestroyEvent.java  |   14 +-
 .../modules/gatewaydelta/GatewayDeltaEvent.java |    4 +-
 ...tewayDeltaEventApplicationCacheListener.java |   16 +-
 .../GatewayDeltaForwarderCacheListener.java     |   32 +-
 .../session/bootstrap/AbstractCache.java        |   22 +-
 .../session/bootstrap/ClientServerCache.java    |    6 +-
 .../session/bootstrap/LifecycleTypeAdapter.java |    2 +-
 .../session/bootstrap/PeerToPeerCache.java      |   10 +-
 .../AbstractCacheLifecycleListener.java         |    6 +-
 .../session/catalina/AbstractSessionCache.java  |   12 +-
 .../ClientServerCacheLifecycleListener.java     |    4 +-
 .../catalina/ClientServerSessionCache.java      |   46 +-
 .../session/catalina/CommitSessionValve.java    |    4 +-
 .../modules/session/catalina/DeltaSession.java  |   32 +-
 .../session/catalina/DeltaSessionFacade.java    |    2 +-
 .../session/catalina/DeltaSessionInterface.java |    6 +-
 .../session/catalina/DeltaSessionManager.java   |   24 +-
 .../session/catalina/JvmRouteBinderValve.java   |    4 +-
 .../PeerToPeerCacheLifecycleListener.java       |    4 +-
 .../catalina/PeerToPeerSessionCache.java        |   36 +-
 .../modules/session/catalina/SessionCache.java  |    8 +-
 .../session/catalina/SessionManager.java        |    2 +-
 .../catalina/Tomcat6DeltaSessionManager.java    |    2 +-
 .../callback/LocalSessionCacheLoader.java       |   12 +-
 .../callback/LocalSessionCacheWriter.java       |   16 +-
 .../SessionExpirationCacheListener.java         |   14 +-
 .../internal/DeltaSessionAttributeEvent.java    |    8 +-
 .../DeltaSessionAttributeEventBatch.java        |   14 +-
 .../DeltaSessionDestroyAttributeEvent.java      |   12 +-
 .../internal/DeltaSessionStatistics.java        |   16 +-
 .../DeltaSessionUpdateAttributeEvent.java       |   12 +-
 .../org/apache/geode/modules/util/Banner.java   |    4 +-
 .../modules/util/BootstrappingFunction.java     |   26 +-
 .../util/ClassLoaderObjectInputStream.java      |    2 +-
 .../geode/modules/util/ContextMapper.java       |    4 +-
 .../modules/util/CreateRegionFunction.java      |   44 +-
 .../geode/modules/util/DebugCacheListener.java  |    8 +-
 .../geode/modules/util/ModuleStatistics.java    |   18 +-
 .../geode/modules/util/RegionConfiguration.java |   12 +-
 .../util/RegionConfigurationCacheListener.java  |   18 +-
 .../apache/geode/modules/util/RegionHelper.java |   42 +-
 .../geode/modules/util/RegionSizeFunction.java  |   10 +-
 .../apache/geode/modules/util/RegionStatus.java |    2 +-
 .../modules/util/ResourceManagerValidator.java  |    6 +-
 .../geode/modules/util/SessionCustomExpiry.java |   12 +-
 .../TouchPartitionedRegionEntriesFunction.java  |   20 +-
 .../TouchReplicatedRegionEntriesFunction.java   |   16 +-
 .../apache/geode/modules/session/Callback.java  |    2 +-
 .../geode/modules/session/CommandServlet.java   |    2 +-
 .../geode/modules/session/EmbeddedTomcat.java   |    4 +-
 .../geode/modules/session/QueryCommand.java     |    2 +-
 .../geode/modules/session/TestSessionsBase.java |   12 +-
 .../session/Tomcat6SessionsJUnitTest.java       |    6 +-
 .../org/apache/geode/modules/Event.hbm.xml      |    2 +-
 .../org/apache/geode/modules/Person.hbm.xml     |    2 +-
 geode-assembly/build.gradle                     |   16 +-
 geode-assembly/src/main/dist/bin/gfsh           |    4 +-
 geode-assembly/src/main/dist/bin/gfsh.bat       |    2 +-
 .../org/apache/geode/BundledJarsJUnitTest.java  |    8 +-
 .../LocatorLauncherAssemblyIntegrationTest.java |   28 +-
 .../management/internal/AgentUtilJUnitTest.java |    6 +-
 .../LauncherLifecycleCommandsDUnitTest.java     |   74 +-
 ...auncherLifecycleCommandsIntegrationTest.java |    8 +-
 .../LauncherLifecycleCommandsJUnitTest.java     |   28 +-
 .../SharedConfigurationEndToEndDUnitTest.java   |   74 +-
 .../rest/internal/web/RestFunctionTemplate.java |    4 +-
 .../internal/web/RestInterfaceJUnitTest.java    |   26 +-
 .../internal/web/RestSecurityDUnitTest.java     |   10 +-
 .../web/controllers/AddFreeItemToOrders.java    |   30 +-
 .../rest/internal/web/controllers/Customer.java |    4 +-
 .../internal/web/controllers/DateTimeUtils.java |    2 +-
 .../rest/internal/web/controllers/Gender.java   |    2 +-
 .../internal/web/controllers/GetAllEntries.java |    6 +-
 .../web/controllers/GetDeliveredOrders.java     |   24 +-
 .../internal/web/controllers/GetRegions.java    |   14 +-
 .../web/controllers/GetValueForKey.java         |   14 +-
 .../rest/internal/web/controllers/Item.java     |   10 +-
 .../rest/internal/web/controllers/Order.java    |    8 +-
 .../rest/internal/web/controllers/Person.java   |   10 +-
 .../web/controllers/PutKeyFunction.java         |   10 +-
 ...stAPIOnRegionFunctionExecutionDUnitTest.java |   50 +-
 .../web/controllers/RestAPITestBase.java        |   34 +-
 .../RestAPIsAndInterOpsDUnitTest.java           |   82 +-
 ...tAPIsOnGroupsFunctionExecutionDUnitTest.java |   16 +-
 ...APIsOnMembersFunctionExecutionDUnitTest.java |   24 +-
 .../RestAPIsQueryAndFEJUnitTest.java            |  144 +-
 .../controllers/RestAPIsWithSSLDUnitTest.java   |   58 +-
 .../internal/web/controllers/RestTestUtils.java |    6 +-
 .../apache/geode/annotations/Experimental.java  |    2 +-
 .../annotations/ExperimentalJUnitTest.java      |    8 +-
 .../ClassInExperimentalPackage.java             |    4 +-
 .../experimentalpackage/package-info.java       |    6 +-
 .../ClassInNonExperimentalPackage.java          |    4 +-
 .../nonexperimentalpackage/package-info.java    |    4 +-
 geode-core/build.gradle                         |   12 +-
 .../internal/ra/GFConnectionFactoryImpl.java    |    4 +-
 .../geode/internal/ra/GFConnectionImpl.java     |    6 +-
 .../internal/ra/spi/JCALocalTransaction.java    |   16 +-
 .../internal/ra/spi/JCAManagedConnection.java   |   12 +-
 .../ra/spi/JCAManagedConnectionFactory.java     |    4 +-
 .../ra/spi/JCAManagedConnectionMetaData.java    |    2 +-
 geode-core/src/jca/ra.xml                       |   10 +-
 geode-core/src/main/java/external-overview.html |    4 +-
 .../java/org/apache/geode/CancelCriterion.java  |    4 +-
 .../java/org/apache/geode/CancelException.java  |    4 +-
 .../org/apache/geode/CanonicalInstantiator.java |    2 +-
 .../java/org/apache/geode/CopyException.java    |    2 +-
 .../main/java/org/apache/geode/CopyHelper.java  |   22 +-
 .../java/org/apache/geode/DataSerializable.java |    4 +-
 .../java/org/apache/geode/DataSerializer.java   |   50 +-
 .../src/main/java/org/apache/geode/Delta.java   |    2 +-
 .../geode/DeltaSerializationException.java      |    2 +-
 .../apache/geode/ForcedDisconnectException.java |    2 +-
 .../org/apache/geode/GemFireCacheException.java |    4 +-
 .../apache/geode/GemFireCheckedException.java   |    4 +-
 .../apache/geode/GemFireConfigException.java    |    2 +-
 .../java/org/apache/geode/GemFireException.java |    6 +-
 .../org/apache/geode/GemFireIOException.java    |    2 +-
 .../org/apache/geode/GemFireRethrowable.java    |    2 +-
 .../geode/IncompatibleSystemException.java      |    2 +-
 .../java/org/apache/geode/Instantiator.java     |   10 +-
 .../org/apache/geode/InternalGemFireError.java  |    2 +-
 .../apache/geode/InternalGemFireException.java  |    2 +-
 .../org/apache/geode/InvalidDeltaException.java |    2 +-
 .../org/apache/geode/InvalidValueException.java |    2 +-
 .../apache/geode/InvalidVersionException.java   |    2 +-
 .../java/org/apache/geode/LicenseException.java |    2 +-
 .../main/java/org/apache/geode/LogWriter.java   |    6 +-
 .../org/apache/geode/NoSystemException.java     |    2 +-
 .../geode/OutOfOffHeapMemoryException.java      |    2 +-
 .../apache/geode/SerializationException.java    |    4 +-
 .../org/apache/geode/StatisticDescriptor.java   |    6 +-
 .../main/java/org/apache/geode/Statistics.java  |    4 +-
 .../org/apache/geode/StatisticsFactory.java     |    8 +-
 .../java/org/apache/geode/StatisticsType.java   |    4 +-
 .../org/apache/geode/StatisticsTypeFactory.java |    6 +-
 .../apache/geode/SystemConnectException.java    |    2 +-
 .../java/org/apache/geode/SystemFailure.java    |   14 +-
 .../apache/geode/SystemIsRunningException.java  |    2 +-
 .../geode/ThreadInterruptedException.java       |    2 +-
 .../java/org/apache/geode/ToDataException.java  |    2 +-
 .../apache/geode/UncreatedSystemException.java  |    2 +-
 .../org/apache/geode/UnmodifiableException.java |    2 +-
 .../apache/geode/UnstartedSystemException.java  |    2 +-
 .../org/apache/geode/admin/AdminConfig.java     |    6 +-
 .../geode/admin/AdminDistributedSystem.java     |   20 +-
 .../admin/AdminDistributedSystemFactory.java    |   26 +-
 .../org/apache/geode/admin/AdminException.java  |    6 +-
 .../apache/geode/admin/AdminXmlException.java   |    4 +-
 .../main/java/org/apache/geode/admin/Alert.java |    8 +-
 .../java/org/apache/geode/admin/AlertLevel.java |   10 +-
 .../org/apache/geode/admin/AlertListener.java   |    4 +-
 .../org/apache/geode/admin/BackupStatus.java    |    8 +-
 .../geode/admin/CacheDoesNotExistException.java |    4 +-
 .../apache/geode/admin/CacheHealthConfig.java   |   12 +-
 .../org/apache/geode/admin/CacheServer.java     |    2 +-
 .../apache/geode/admin/CacheServerConfig.java   |    2 +-
 .../java/org/apache/geode/admin/CacheVm.java    |    8 +-
 .../org/apache/geode/admin/CacheVmConfig.java   |    4 +-
 .../geode/admin/ConfigurationParameter.java     |    4 +-
 .../geode/admin/DistributedSystemConfig.java    |   18 +-
 .../admin/DistributedSystemHealthConfig.java    |    4 +-
 .../apache/geode/admin/DistributionLocator.java |    4 +-
 .../geode/admin/DistributionLocatorConfig.java  |    6 +-
 .../org/apache/geode/admin/GemFireHealth.java   |    8 +-
 .../apache/geode/admin/GemFireHealthConfig.java |    4 +-
 .../apache/geode/admin/GemFireMemberStatus.java |   38 +-
 .../org/apache/geode/admin/ManagedEntity.java   |    4 +-
 .../apache/geode/admin/ManagedEntityConfig.java |    4 +-
 .../apache/geode/admin/MemberHealthConfig.java  |    4 +-
 .../admin/OperationCancelledException.java      |    6 +-
 .../geode/admin/RegionNotFoundException.java    |   10 +-
 .../geode/admin/RegionSubRegionSnapshot.java    |   14 +-
 .../geode/admin/RuntimeAdminException.java      |    6 +-
 .../java/org/apache/geode/admin/Statistic.java  |    4 +-
 .../apache/geode/admin/StatisticResource.java   |    8 +-
 .../org/apache/geode/admin/SystemMember.java    |   30 +-
 .../geode/admin/SystemMemberBridgeServer.java   |    6 +-
 .../apache/geode/admin/SystemMemberCache.java   |   20 +-
 .../geode/admin/SystemMemberCacheEvent.java     |    6 +-
 .../geode/admin/SystemMemberCacheListener.java  |    6 +-
 .../geode/admin/SystemMemberCacheServer.java    |   10 +-
 .../apache/geode/admin/SystemMemberRegion.java  |   12 +-
 .../geode/admin/SystemMemberRegionEvent.java    |    4 +-
 .../apache/geode/admin/SystemMemberType.java    |    4 +-
 .../geode/admin/SystemMembershipEvent.java      |    6 +-
 .../geode/admin/SystemMembershipListener.java   |    6 +-
 .../UnmodifiableConfigurationException.java     |    4 +-
 .../admin/internal/AbstractHealthEvaluator.java |   14 +-
 .../internal/AdminDistributedSystemImpl.java    |   96 +-
 .../admin/internal/BackupDataStoreHelper.java   |   12 +-
 .../admin/internal/BackupDataStoreResult.java   |    6 +-
 .../geode/admin/internal/BackupStatusImpl.java  |    8 +-
 .../admin/internal/CacheHealthConfigImpl.java   |    4 +-
 .../admin/internal/CacheHealthEvaluator.java    |   26 +-
 .../admin/internal/CacheServerConfigImpl.java   |   10 +-
 .../geode/admin/internal/CacheServerImpl.java   |   14 +-
 .../internal/ConfigurationParameterImpl.java    |   10 +-
 .../ConfigurationParameterListener.java         |    6 +-
 .../DisabledManagedEntityController.java        |    8 +-
 .../internal/DistributedSystemConfigImpl.java   |   22 +-
 .../DistributedSystemHealthConfigImpl.java      |    4 +-
 .../DistributedSystemHealthEvaluator.java       |   18 +-
 .../DistributedSystemHealthMonitor.java         |   58 +-
 .../internal/DistributionLocatorConfigImpl.java |   12 +-
 .../admin/internal/DistributionLocatorImpl.java |   26 +-
 .../EnabledManagedEntityController.java         |   26 +-
 .../admin/internal/FinishBackupRequest.java     |   34 +-
 .../admin/internal/FinishBackupResponse.java    |   10 +-
 .../admin/internal/FlushToDiskRequest.java      |   22 +-
 .../admin/internal/FlushToDiskResponse.java     |    6 +-
 .../admin/internal/GemFireHealthConfigImpl.java |    6 +-
 .../admin/internal/GemFireHealthEvaluator.java  |   14 +-
 .../geode/admin/internal/GemFireHealthImpl.java |   12 +-
 .../geode/admin/internal/InetAddressUtil.java   |   12 +-
 .../admin/internal/InternalManagedEntity.java   |    8 +-
 .../geode/admin/internal/LogCollator.java       |   10 +-
 .../admin/internal/ManagedEntityConfigImpl.java |   18 +-
 .../admin/internal/ManagedEntityConfigXml.java  |   16 +-
 .../ManagedEntityConfigXmlGenerator.java        |    8 +-
 .../internal/ManagedEntityConfigXmlParser.java  |   10 +-
 .../admin/internal/ManagedEntityController.java |    8 +-
 .../ManagedEntityControllerFactory.java         |   14 +-
 .../admin/internal/ManagedSystemMemberImpl.java |   12 +-
 .../admin/internal/MemberHealthConfigImpl.java  |    6 +-
 .../admin/internal/MemberHealthEvaluator.java   |   24 +-
 .../admin/internal/PrepareBackupRequest.java    |   34 +-
 .../admin/internal/PrepareBackupResponse.java   |   10 +-
 .../geode/admin/internal/StatisticImpl.java     |    6 +-
 .../admin/internal/StatisticResourceImpl.java   |   30 +-
 .../internal/SystemMemberBridgeServerImpl.java  |   16 +-
 .../internal/SystemMemberCacheEventImpl.java    |    8 +-
 .../SystemMemberCacheEventProcessor.java        |   24 +-
 .../admin/internal/SystemMemberCacheImpl.java   |   18 +-
 .../geode/admin/internal/SystemMemberImpl.java  |   56 +-
 .../internal/SystemMemberRegionEventImpl.java   |    8 +-
 .../admin/internal/SystemMemberRegionImpl.java  |   12 +-
 .../internal/SystemMembershipEventImpl.java     |    6 +-
 .../apache/geode/admin/internal/package.html    |   16 +-
 .../java/org/apache/geode/admin/jmx/Agent.java  |   10 +-
 .../org/apache/geode/admin/jmx/AgentConfig.java |   10 +-
 .../apache/geode/admin/jmx/AgentFactory.java    |   12 +-
 .../internal/AdminDistributedSystemJmxImpl.java |   66 +-
 .../admin/jmx/internal/AgentConfigImpl.java     |   50 +-
 .../geode/admin/jmx/internal/AgentImpl.java     |   68 +-
 .../geode/admin/jmx/internal/AgentLauncher.java |   30 +-
 .../admin/jmx/internal/CacheServerJmxImpl.java  |   42 +-
 .../admin/jmx/internal/ConfigAttributeInfo.java |    8 +-
 .../internal/ConfigurationParameterJmxImpl.java |   12 +-
 .../DistributedSystemHealthConfigJmxImpl.java   |    8 +-
 .../internal/DistributionLocatorJmxImpl.java    |   18 +-
 .../admin/jmx/internal/DynamicManagedBean.java  |    2 +-
 .../internal/GemFireHealthConfigJmxImpl.java    |   10 +-
 .../jmx/internal/GemFireHealthJmxImpl.java      |   20 +-
 .../admin/jmx/internal/GenerateMBeanHTML.java   |    8 +-
 .../geode/admin/jmx/internal/MBeanUtil.java     |   22 +-
 .../admin/jmx/internal/MX4JModelMBean.java      |    4 +-
 .../jmx/internal/MX4JServerSocketFactory.java   |   12 +-
 .../geode/admin/jmx/internal/MailManager.java   |   10 +-
 .../admin/jmx/internal/ManagedResource.java     |    2 +-
 .../admin/jmx/internal/ManagedResourceType.java |   26 +-
 .../jmx/internal/MemberInfoWithStatsMBean.java  |   24 +-
 .../admin/jmx/internal/RMIRegistryService.java  |    2 +-
 .../jmx/internal/RMIRegistryServiceMBean.java   |    2 +-
 .../jmx/internal/RefreshNotificationType.java   |    2 +-
 .../jmx/internal/StatAlertNotification.java     |   14 +-
 .../jmx/internal/StatAlertsAggregator.java      |    8 +-
 .../jmx/internal/StatisticAttributeInfo.java    |    8 +-
 .../jmx/internal/StatisticResourceJmxImpl.java  |   34 +-
 .../SystemMemberBridgeServerJmxImpl.java        |   14 +-
 .../jmx/internal/SystemMemberCacheJmxImpl.java  |   36 +-
 .../admin/jmx/internal/SystemMemberJmx.java     |   22 +-
 .../admin/jmx/internal/SystemMemberJmxImpl.java |   46 +-
 .../jmx/internal/SystemMemberRegionJmxImpl.java |   18 +-
 .../geode/admin/jmx/internal/package.html       |   20 +-
 .../java/org/apache/geode/admin/package.html    |   24 +-
 .../apache/geode/cache/AttributesFactory.java   |   32 +-
 .../apache/geode/cache/AttributesMutator.java   |    2 +-
 .../main/java/org/apache/geode/cache/Cache.java |   42 +-
 .../org/apache/geode/cache/CacheCallback.java   |    2 +-
 .../geode/cache/CacheClosedException.java       |    6 +-
 .../java/org/apache/geode/cache/CacheEvent.java |    6 +-
 .../org/apache/geode/cache/CacheException.java  |    4 +-
 .../geode/cache/CacheExistsException.java       |    2 +-
 .../org/apache/geode/cache/CacheFactory.java    |   28 +-
 .../org/apache/geode/cache/CacheListener.java   |    4 +-
 .../org/apache/geode/cache/CacheLoader.java     |    4 +-
 .../geode/cache/CacheLoaderException.java       |    4 +-
 .../geode/cache/CacheRuntimeException.java      |    4 +-
 .../org/apache/geode/cache/CacheStatistics.java |    2 +-
 .../geode/cache/CacheTransactionManager.java    |    6 +-
 .../org/apache/geode/cache/CacheWriter.java     |    2 +-
 .../geode/cache/CacheWriterException.java       |   12 +-
 .../apache/geode/cache/CacheXmlException.java   |    2 +-
 .../org/apache/geode/cache/ClientSession.java   |   10 +-
 .../geode/cache/CommitConflictException.java    |    2 +-
 .../cache/CommitDistributionException.java      |    2 +-
 .../geode/cache/CommitIncompleteException.java  |    2 +-
 .../org/apache/geode/cache/CustomExpiry.java    |    2 +-
 .../java/org/apache/geode/cache/DataPolicy.java |    4 +-
 .../java/org/apache/geode/cache/Declarable.java |    2 +-
 .../apache/geode/cache/DiskAccessException.java |    2 +-
 .../java/org/apache/geode/cache/DiskStore.java  |    2 +-
 .../apache/geode/cache/DiskStoreFactory.java    |    4 +-
 .../apache/geode/cache/DiskWriteAttributes.java |    2 +-
 .../geode/cache/DiskWriteAttributesFactory.java |    8 +-
 .../DuplicatePrimaryPartitionException.java     |    4 +-
 .../geode/cache/DynamicRegionFactory.java       |   48 +-
 .../geode/cache/DynamicRegionListener.java      |    2 +-
 .../geode/cache/EntryDestroyedException.java    |    2 +-
 .../java/org/apache/geode/cache/EntryEvent.java |    2 +-
 .../geode/cache/EntryExistsException.java       |    4 +-
 .../geode/cache/EntryNotFoundException.java     |    8 +-
 .../geode/cache/EntryNotFoundInRegion.java      |    8 +-
 .../org/apache/geode/cache/EntryOperation.java  |    2 +-
 .../org/apache/geode/cache/EvictionAction.java  |   10 +-
 .../apache/geode/cache/EvictionAlgorithm.java   |    8 +-
 .../apache/geode/cache/EvictionAttributes.java  |   20 +-
 .../geode/cache/EvictionAttributesMutator.java  |    8 +-
 .../apache/geode/cache/ExpirationAction.java    |    2 +-
 .../geode/cache/ExpirationAttributes.java       |    8 +-
 .../cache/FailedSynchronizationException.java   |    2 +-
 .../geode/cache/FixedPartitionAttributes.java   |   12 +-
 .../geode/cache/FixedPartitionResolver.java     |    4 +-
 .../cache/GatewayConfigurationException.java    |    2 +-
 .../apache/geode/cache/GatewayException.java    |    2 +-
 .../org/apache/geode/cache/GemFireCache.java    |   20 +-
 .../cache/IncompatibleVersionException.java     |    2 +-
 .../org/apache/geode/cache/InterestPolicy.java  |    2 +-
 .../geode/cache/InterestRegistrationEvent.java  |    4 +-
 .../cache/InterestRegistrationListener.java     |   12 +-
 .../geode/cache/InterestResultPolicy.java       |    8 +-
 .../org/apache/geode/cache/LoaderHelper.java    |    4 +-
 .../java/org/apache/geode/cache/LossAction.java |    6 +-
 .../apache/geode/cache/LowMemoryException.java  |    6 +-
 .../geode/cache/MembershipAttributes.java       |   14 +-
 .../java/org/apache/geode/cache/MirrorType.java |    2 +-
 .../cache/NoQueueServersAvailableException.java |    4 +-
 ...NoSubscriptionServersAvailableException.java |    4 +-
 .../java/org/apache/geode/cache/Operation.java  |    6 +-
 .../geode/cache/OperationAbortedException.java  |    2 +-
 .../apache/geode/cache/PartitionAttributes.java |   18 +-
 .../geode/cache/PartitionAttributesFactory.java |   20 +-
 .../apache/geode/cache/PartitionResolver.java   |    2 +-
 .../PartitionedRegionDistributionException.java |    2 +-
 .../PartitionedRegionStorageException.java      |    4 +-
 .../java/org/apache/geode/cache/Region.java     |   70 +-
 .../geode/cache/RegionAccessException.java      |    6 +-
 .../apache/geode/cache/RegionAttributes.java    |    8 +-
 .../geode/cache/RegionDestroyedException.java   |    2 +-
 .../cache/RegionDistributionException.java      |   10 +-
 .../org/apache/geode/cache/RegionEvent.java     |    2 +-
 .../geode/cache/RegionExistsException.java      |    2 +-
 .../org/apache/geode/cache/RegionFactory.java   |   14 +-
 .../geode/cache/RegionMembershipListener.java   |    6 +-
 .../cache/RegionReinitializedException.java     |    2 +-
 .../apache/geode/cache/RegionRoleException.java |    2 +-
 .../apache/geode/cache/RegionRoleListener.java  |    4 +-
 .../org/apache/geode/cache/RegionService.java   |   14 +-
 .../org/apache/geode/cache/RegionShortcut.java  |    2 +-
 .../geode/cache/RemoteTransactionException.java |    2 +-
 .../org/apache/geode/cache/RequiredRoles.java   |   18 +-
 .../apache/geode/cache/ResourceException.java   |    2 +-
 .../apache/geode/cache/ResumptionAction.java    |    6 +-
 .../java/org/apache/geode/cache/RoleEvent.java  |    2 +-
 .../org/apache/geode/cache/RoleException.java   |    2 +-
 .../main/java/org/apache/geode/cache/Scope.java |    4 +-
 .../geode/cache/SerializedCacheValue.java       |    2 +-
 .../cache/StatisticsDisabledException.java      |    2 +-
 .../geode/cache/SubscriptionAttributes.java     |    4 +-
 .../SynchronizationCommitConflictException.java |    2 +-
 .../apache/geode/cache/TimeoutException.java    |   18 +-
 ...TransactionDataNodeHasDepartedException.java |    2 +-
 .../TransactionDataNotColocatedException.java   |    2 +-
 .../TransactionDataRebalancedException.java     |    4 +-
 .../apache/geode/cache/TransactionEvent.java    |    2 +-
 .../geode/cache/TransactionException.java       |    2 +-
 .../org/apache/geode/cache/TransactionId.java   |    2 +-
 .../cache/TransactionInDoubtException.java      |    2 +-
 .../apache/geode/cache/TransactionListener.java |    2 +-
 .../apache/geode/cache/TransactionWriter.java   |    2 +-
 .../geode/cache/TransactionWriterException.java |    2 +-
 ...upportedOperationInTransactionException.java |    2 +-
 .../cache/UnsupportedVersionException.java      |    2 +-
 .../apache/geode/cache/VersionException.java    |    4 +-
 .../geode/cache/asyncqueue/AsyncEvent.java      |    6 +-
 .../cache/asyncqueue/AsyncEventListener.java    |    4 +-
 .../geode/cache/asyncqueue/AsyncEventQueue.java |    8 +-
 .../asyncqueue/AsyncEventQueueFactory.java      |   10 +-
 .../internal/AsyncEventQueueFactoryImpl.java    |   42 +-
 .../internal/AsyncEventQueueImpl.java           |   22 +-
 .../internal/AsyncEventQueueStats.java          |   14 +-
 .../internal/ParallelAsyncEventQueueImpl.java   |   56 +-
 .../internal/SerialAsyncEventQueueImpl.java     |   60 +-
 .../client/AllConnectionsInUseException.java    |    2 +-
 .../apache/geode/cache/client/ClientCache.java  |    8 +-
 .../geode/cache/client/ClientCacheFactory.java  |   44 +-
 .../cache/client/ClientNotReadyException.java   |    6 +-
 .../geode/cache/client/ClientRegionFactory.java |   22 +-
 .../cache/client/ClientRegionShortcut.java      |    4 +-
 .../client/NoAvailableLocatorsException.java    |    2 +-
 .../client/NoAvailableServersException.java     |    2 +-
 .../org/apache/geode/cache/client/Pool.java     |    8 +-
 .../apache/geode/cache/client/PoolFactory.java  |   14 +-
 .../apache/geode/cache/client/PoolManager.java  |    8 +-
 .../client/ServerConnectivityException.java     |    4 +-
 .../cache/client/ServerOperationException.java  |    4 +-
 .../ServerRefusedConnectionException.java       |    6 +-
 .../client/SubscriptionNotEnabledException.java |    4 +-
 .../geode/cache/client/internal/AbstractOp.java |   36 +-
 .../cache/client/internal/AddPDXEnumOp.java     |   10 +-
 .../cache/client/internal/AddPDXTypeOp.java     |   10 +-
 .../client/internal/AuthenticateUserOp.java     |   44 +-
 .../internal/AutoConnectionSourceImpl.java      |   40 +-
 .../client/internal/CacheServerLoadMessage.java |   20 +-
 .../geode/cache/client/internal/ClearOp.java    |   10 +-
 .../client/internal/ClientMetadataService.java  |   18 +-
 .../client/internal/ClientPartitionAdvisor.java |   22 +-
 .../internal/ClientRegionFactoryImpl.java       |   38 +-
 .../cache/client/internal/ClientUpdater.java    |    2 +-
 .../client/internal/CloseConnectionOp.java      |    8 +-
 .../geode/cache/client/internal/CommitOp.java   |   10 +-
 .../geode/cache/client/internal/Connection.java |    6 +-
 .../client/internal/ConnectionFactory.java      |    6 +-
 .../client/internal/ConnectionFactoryImpl.java  |   38 +-
 .../cache/client/internal/ConnectionImpl.java   |   36 +-
 .../cache/client/internal/ConnectionSource.java |    6 +-
 .../cache/client/internal/ConnectionStats.java  |   22 +-
 .../cache/client/internal/ContainsKeyOp.java    |    8 +-
 .../DataSerializerRecoveryListener.java         |   18 +-
 .../geode/cache/client/internal/DestroyOp.java  |   36 +-
 .../cache/client/internal/DestroyRegionOp.java  |   10 +-
 .../geode/cache/client/internal/Endpoint.java   |    8 +-
 .../cache/client/internal/EndpointManager.java  |    6 +-
 .../client/internal/EndpointManagerImpl.java    |   34 +-
 .../cache/client/internal/ExecutablePool.java   |    8 +-
 .../client/internal/ExecuteFunctionHelper.java  |    2 +-
 .../client/internal/ExecuteFunctionNoAckOp.java |   30 +-
 .../client/internal/ExecuteFunctionOp.java      |   50 +-
 .../internal/ExecuteRegionFunctionNoAckOp.java  |   30 +-
 .../internal/ExecuteRegionFunctionOp.java       |   50 +-
 .../ExecuteRegionFunctionSingleHopOp.java       |   52 +-
 .../internal/ExplicitConnectionSourceImpl.java  |   14 +-
 .../geode/cache/client/internal/GetAllOp.java   |   28 +-
 .../client/internal/GetClientPRMetaDataOp.java  |   18 +-
 .../GetClientPartitionAttributesOp.java         |   18 +-
 .../geode/cache/client/internal/GetEntryOp.java |   10 +-
 .../cache/client/internal/GetEventValueOp.java  |   16 +-
 .../client/internal/GetFunctionAttributeOp.java |    6 +-
 .../geode/cache/client/internal/GetOp.java      |   38 +-
 .../cache/client/internal/GetPDXEnumByIdOp.java |   10 +-
 .../cache/client/internal/GetPDXEnumsOp.java    |   14 +-
 .../client/internal/GetPDXIdForEnumOp.java      |   16 +-
 .../client/internal/GetPDXIdForTypeOp.java      |   16 +-
 .../cache/client/internal/GetPDXTypeByIdOp.java |   10 +-
 .../cache/client/internal/GetPDXTypesOp.java    |   14 +-
 .../internal/InstantiatorRecoveryListener.java  |   16 +-
 .../cache/client/internal/InternalPool.java     |    8 +-
 .../cache/client/internal/InvalidateOp.java     |   16 +-
 .../geode/cache/client/internal/KeySetOp.java   |   18 +-
 .../cache/client/internal/LiveServerPinger.java |   10 +-
 .../internal/LocatorDiscoveryCallback.java      |    2 +-
 .../LocatorDiscoveryCallbackAdapter.java        |    2 +-
 .../cache/client/internal/MakePrimaryOp.java    |    8 +-
 .../apache/geode/cache/client/internal/Op.java  |    2 +-
 .../cache/client/internal/OpExecutorImpl.java   |   62 +-
 .../internal/PdxRegistryRecoveryListener.java   |    8 +-
 .../geode/cache/client/internal/PingOp.java     |   12 +-
 .../geode/cache/client/internal/PoolImpl.java   |   60 +-
 .../cache/client/internal/PrimaryAckOp.java     |    8 +-
 .../geode/cache/client/internal/ProxyCache.java |   34 +-
 .../client/internal/ProxyCacheCloseOp.java      |   20 +-
 .../cache/client/internal/ProxyRegion.java      |   46 +-
 .../geode/cache/client/internal/PutAllOp.java   |   38 +-
 .../geode/cache/client/internal/PutOp.java      |   38 +-
 .../geode/cache/client/internal/QueryOp.java    |   38 +-
 .../client/internal/QueueConnectionImpl.java    |   12 +-
 .../cache/client/internal/QueueManager.java     |    6 +-
 .../cache/client/internal/QueueManagerImpl.java |   70 +-
 .../geode/cache/client/internal/QueueState.java |    4 +-
 .../cache/client/internal/QueueStateImpl.java   |   26 +-
 .../cache/client/internal/ReadyForEventsOp.java |    8 +-
 .../internal/RegisterDataSerializersOp.java     |   22 +-
 .../internal/RegisterInstantiatorsOp.java       |   24 +-
 .../client/internal/RegisterInterestListOp.java |   12 +-
 .../client/internal/RegisterInterestOp.java     |   32 +-
 .../internal/RegisterInterestTracker.java       |   20 +-
 .../cache/client/internal/RemoveAllOp.java      |   36 +-
 .../geode/cache/client/internal/RollbackOp.java |    6 +-
 .../cache/client/internal/ServerBlackList.java  |   10 +-
 .../cache/client/internal/ServerProxy.java      |    6 +-
 .../client/internal/ServerRegionDataAccess.java |   18 +-
 .../client/internal/ServerRegionProxy.java      |   82 +-
 .../internal/SingleHopClientExecutor.java       |   40 +-
 .../internal/SingleHopOperationCallable.java    |   10 +-
 .../geode/cache/client/internal/SizeOp.java     |    8 +-
 .../cache/client/internal/TXFailoverOp.java     |    6 +-
 .../client/internal/TXSynchronizationOp.java    |   24 +-
 .../internal/UnregisterInterestListOp.java      |    8 +-
 .../client/internal/UnregisterInterestOp.java   |   10 +-
 .../cache/client/internal/UserAttributes.java   |    6 +-
 .../locator/ClientConnectionRequest.java        |    4 +-
 .../locator/ClientConnectionResponse.java       |    8 +-
 .../locator/ClientReplacementRequest.java       |    8 +-
 .../internal/locator/GetAllServersRequest.java  |    4 +-
 .../internal/locator/GetAllServersResponse.java |    8 +-
 .../internal/locator/LocatorListRequest.java    |    4 +-
 .../internal/locator/LocatorListResponse.java   |    6 +-
 .../internal/locator/LocatorStatusRequest.java  |    8 +-
 .../internal/locator/LocatorStatusResponse.java |   16 +-
 .../locator/QueueConnectionRequest.java         |    8 +-
 .../locator/QueueConnectionResponse.java        |    6 +-
 .../internal/locator/SerializationHelper.java   |    8 +-
 .../internal/locator/ServerLocationRequest.java |    8 +-
 .../locator/ServerLocationResponse.java         |    6 +-
 .../locator/wan/LocatorMembershipListener.java  |    6 +-
 .../pooling/ConnectionDestroyedException.java   |    4 +-
 .../internal/pooling/ConnectionManager.java     |   10 +-
 .../internal/pooling/ConnectionManagerImpl.java |   46 +-
 .../internal/pooling/PooledConnection.java      |   18 +-
 .../org/apache/geode/cache/client/package.html  |   20 +-
 .../geode/cache/control/RebalanceFactory.java   |    2 +-
 .../geode/cache/control/RebalanceOperation.java |    4 +-
 .../geode/cache/control/RebalanceResults.java   |    4 +-
 .../geode/cache/control/ResourceManager.java    |   20 +-
 .../org/apache/geode/cache/control/package.html |    2 +-
 .../execute/EmptyRegionFunctionException.java   |    4 +-
 .../apache/geode/cache/execute/Execution.java   |    8 +-
 .../apache/geode/cache/execute/Function.java    |   12 +-
 .../geode/cache/execute/FunctionAdapter.java    |    2 +-
 .../geode/cache/execute/FunctionContext.java    |    2 +-
 .../geode/cache/execute/FunctionException.java  |    6 +-
 .../FunctionInvocationTargetException.java      |    4 +-
 .../geode/cache/execute/FunctionService.java    |   24 +-
 .../cache/execute/RegionFunctionContext.java    |    8 +-
 .../geode/cache/execute/ResultCollector.java    |    4 +-
 .../geode/cache/execute/ResultSender.java       |   10 +-
 .../internal/FunctionServiceManager.java        |   44 +-
 .../org/apache/geode/cache/execute/package.html |   10 +-
 .../operations/CloseCQOperationContext.java     |    4 +-
 .../operations/DestroyOperationContext.java     |    4 +-
 .../operations/ExecuteCQOperationContext.java   |    2 +-
 .../ExecuteFunctionOperationContext.java        |    2 +-
 .../GetDurableCQsOperationContext.java          |    4 +-
 .../cache/operations/GetOperationContext.java   |    4 +-
 .../operations/InterestOperationContext.java    |    2 +-
 .../geode/cache/operations/InterestType.java    |    2 +-
 .../operations/InvalidateOperationContext.java  |    4 +-
 .../cache/operations/KeyOperationContext.java   |   14 +-
 .../operations/KeySetOperationContext.java      |    8 +-
 .../operations/KeyValueOperationContext.java    |    8 +-
 .../cache/operations/OperationContext.java      |    2 +-
 .../operations/PutAllOperationContext.java      |    8 +-
 .../cache/operations/PutOperationContext.java   |    6 +-
 .../cache/operations/QueryOperationContext.java |    4 +-
 .../operations/RegionClearOperationContext.java |    4 +-
 .../RegionCreateOperationContext.java           |    4 +-
 .../RegionDestroyOperationContext.java          |    4 +-
 .../operations/RegionOperationContext.java      |   10 +-
 .../RegisterInterestOperationContext.java       |    6 +-
 .../operations/RemoveAllOperationContext.java   |    6 +-
 .../operations/StopCQOperationContext.java      |    4 +-
 .../UnregisterInterestOperationContext.java     |    4 +-
 .../internal/GetOperationContextImpl.java       |   12 +-
 .../operations/internal/UpdateOnlyMap.java      |    6 +-
 .../apache/geode/cache/operations/package.html  |   60 +-
 .../java/org/apache/geode/cache/package.html    |  206 +-
 .../cache/partition/PartitionListener.java      |    6 +-
 .../partition/PartitionListenerAdapter.java     |    6 +-
 .../cache/partition/PartitionMemberInfo.java    |    6 +-
 .../PartitionNotAvailableException.java         |    4 +-
 .../cache/partition/PartitionRebalanceInfo.java |    4 +-
 .../cache/partition/PartitionRegionHelper.java  |   52 +-
 .../cache/partition/PartitionRegionInfo.java    |   14 +-
 .../ConflictingPersistentDataException.java     |    6 +-
 .../persistence/PartitionOfflineException.java  |    4 +-
 .../geode/cache/persistence/PersistentID.java   |    8 +-
 .../PersistentReplicatesOfflineException.java   |    4 +-
 .../persistence/RevokeFailedException.java      |    4 +-
 .../RevokedPersistentDataException.java         |    6 +-
 .../apache/geode/cache/query/Aggregator.java    |    2 +-
 .../cache/query/AmbiguousNameException.java     |    2 +-
 .../apache/geode/cache/query/CqAttributes.java  |    2 +-
 .../geode/cache/query/CqAttributesFactory.java  |    6 +-
 .../geode/cache/query/CqAttributesMutator.java  |    2 +-
 .../geode/cache/query/CqClosedException.java    |    4 +-
 .../org/apache/geode/cache/query/CqEvent.java   |    4 +-
 .../apache/geode/cache/query/CqException.java   |    2 +-
 .../geode/cache/query/CqExistsException.java    |    2 +-
 .../apache/geode/cache/query/CqListener.java    |    6 +-
 .../org/apache/geode/cache/query/CqQuery.java   |    2 +-
 .../org/apache/geode/cache/query/CqResults.java |    8 +-
 .../geode/cache/query/CqServiceStatistics.java  |    2 +-
 .../org/apache/geode/cache/query/CqState.java   |    2 +-
 .../apache/geode/cache/query/CqStatistics.java  |    2 +-
 .../geode/cache/query/CqStatusListener.java     |    2 +-
 .../cache/query/FunctionDomainException.java    |    2 +-
 .../org/apache/geode/cache/query/Index.java     |    4 +-
 .../cache/query/IndexCreationException.java     |    2 +-
 .../geode/cache/query/IndexExistsException.java |    2 +-
 .../cache/query/IndexInvalidException.java      |    4 +-
 .../cache/query/IndexMaintenanceException.java  |    4 +-
 .../cache/query/IndexNameConflictException.java |    2 +-
 .../geode/cache/query/IndexStatistics.java      |    2 +-
 .../org/apache/geode/cache/query/IndexType.java |    2 +-
 .../query/MultiIndexCreationException.java      |    4 +-
 .../cache/query/NameNotFoundException.java      |    2 +-
 .../cache/query/NameResolutionException.java    |    2 +-
 .../query/ParameterCountInvalidException.java   |    2 +-
 .../org/apache/geode/cache/query/Query.java     |   12 +-
 .../geode/cache/query/QueryException.java       |    4 +-
 .../query/QueryExecutionLowMemoryException.java |    6 +-
 .../query/QueryExecutionTimeoutException.java   |    4 +-
 .../cache/query/QueryInvalidException.java      |    4 +-
 .../query/QueryInvocationTargetException.java   |    2 +-
 .../apache/geode/cache/query/QueryService.java  |    6 +-
 .../geode/cache/query/QueryStatistics.java      |    2 +-
 .../cache/query/RegionNotFoundException.java    |    2 +-
 .../apache/geode/cache/query/SelectResults.java |    8 +-
 .../org/apache/geode/cache/query/Struct.java    |    4 +-
 .../cache/query/TypeMismatchException.java      |    2 +-
 .../query/internal/AbstractCompiledValue.java   |   14 +-
 .../internal/AbstractGroupOrRangeJunction.java  |   16 +-
 .../cache/query/internal/AllGroupJunction.java  |   20 +-
 .../query/internal/AttributeDescriptor.java     |   30 +-
 .../apache/geode/cache/query/internal/Bag.java  |   26 +-
 .../internal/CompiledAggregateFunction.java     |   48 +-
 .../query/internal/CompiledBindArgument.java    |   16 +-
 .../query/internal/CompiledComparison.java      |   44 +-
 .../query/internal/CompiledConstruction.java    |    6 +-
 .../cache/query/internal/CompiledFunction.java  |    8 +-
 .../query/internal/CompiledGroupBySelect.java   |   34 +-
 .../geode/cache/query/internal/CompiledID.java  |    8 +-
 .../geode/cache/query/internal/CompiledIn.java  |   46 +-
 .../query/internal/CompiledIndexOperation.java  |    8 +-
 .../query/internal/CompiledIteratorDef.java     |   16 +-
 .../cache/query/internal/CompiledJunction.java  |   36 +-
 .../cache/query/internal/CompiledLike.java      |   32 +-
 .../cache/query/internal/CompiledLiteral.java   |    8 +-
 .../cache/query/internal/CompiledNegation.java  |    6 +-
 .../cache/query/internal/CompiledOperation.java |   34 +-
 .../cache/query/internal/CompiledPath.java      |   10 +-
 .../cache/query/internal/CompiledRegion.java    |   16 +-
 .../cache/query/internal/CompiledSelect.java    |   58 +-
 .../query/internal/CompiledSortCriterion.java   |   30 +-
 .../query/internal/CompiledUnaryMinus.java      |   16 +-
 .../cache/query/internal/CompiledUndefined.java |   18 +-
 .../cache/query/internal/CompiledValue.java     |   10 +-
 .../query/internal/CompositeGroupJunction.java  |   22 +-
 .../geode/cache/query/internal/CqEntry.java     |    8 +-
 .../cache/query/internal/CqQueryVsdStats.java   |   20 +-
 .../geode/cache/query/internal/CqStateImpl.java |    4 +-
 .../internal/CumulativeNonDistinctResults.java  |   32 +-
 .../cache/query/internal/DefaultQuery.java      |   38 +-
 .../query/internal/DefaultQueryService.java     |   52 +-
 .../geode/cache/query/internal/DerivedInfo.java |   28 +-
 .../cache/query/internal/ExecutionContext.java  |   32 +-
 .../geode/cache/query/internal/Filter.java      |    6 +-
 .../geode/cache/query/internal/Functions.java   |    8 +-
 .../cache/query/internal/GroupJunction.java     |   10 +-
 .../cache/query/internal/HashingStrategy.java   |    2 +-
 .../geode/cache/query/internal/IndexInfo.java   |   18 +-
 .../internal/IndexTrackingQueryObserver.java    |   10 +-
 .../geode/cache/query/internal/Indexable.java   |    8 +-
 .../cache/query/internal/LinkedResultSet.java   |   20 +-
 .../cache/query/internal/LinkedStructSet.java   |   24 +-
 .../cache/query/internal/MapIndexable.java      |    2 +-
 .../cache/query/internal/MethodDispatch.java    |    8 +-
 .../cache/query/internal/NWayMergeResults.java  |   26 +-
 .../geode/cache/query/internal/Negatable.java   |    2 +-
 .../geode/cache/query/internal/NullToken.java   |   10 +-
 .../cache/query/internal/ObjectIntHashMap.java  |    2 +-
 .../cache/query/internal/OrderByComparator.java |   18 +-
 .../internal/OrderByComparatorUnmapped.java     |   12 +-
 .../geode/cache/query/internal/Ordered.java     |    2 +-
 .../cache/query/internal/OrganizedOperands.java |    2 +-
 .../cache/query/internal/PRQueryTraceInfo.java  |   14 +-
 .../geode/cache/query/internal/PathUtils.java   |   22 +-
 .../geode/cache/query/internal/PlanInfo.java    |    2 +-
 .../cache/query/internal/ProxyQueryService.java |   48 +-
 .../geode/cache/query/internal/QCompiler.java   |   54 +-
 .../geode/cache/query/internal/QRegion.java     |   16 +-
 .../geode/cache/query/internal/QScope.java      |    2 +-
 .../QueryExecutionCanceledException.java        |    6 +-
 .../query/internal/QueryExecutionContext.java   |   10 +-
 .../cache/query/internal/QueryExecutor.java     |   10 +-
 .../cache/query/internal/QueryMonitor.java      |   16 +-
 .../cache/query/internal/QueryObserver.java     |    4 +-
 .../query/internal/QueryObserverAdapter.java    |    6 +-
 .../query/internal/QueryObserverHolder.java     |    2 +-
 .../geode/cache/query/internal/QueryUtils.java  |   54 +-
 .../cache/query/internal/RangeJunction.java     |   32 +-
 .../geode/cache/query/internal/ResultsBag.java  |   16 +-
 .../ResultsCollectionCopyOnReadWrapper.java     |   14 +-
 ...ResultsCollectionPdxDeserializerWrapper.java |   18 +-
 .../internal/ResultsCollectionWrapper.java      |   20 +-
 .../geode/cache/query/internal/ResultsSet.java  |   20 +-
 .../cache/query/internal/RuntimeIterator.java   |   12 +-
 .../query/internal/SelectResultsComparator.java |    4 +-
 .../cache/query/internal/SortedResultSet.java   |   16 +-
 .../cache/query/internal/SortedResultsBag.java  |   10 +-
 .../cache/query/internal/SortedStructBag.java   |   18 +-
 .../cache/query/internal/SortedStructSet.java   |   16 +-
 .../geode/cache/query/internal/StructBag.java   |   18 +-
 .../cache/query/internal/StructFields.java      |    4 +-
 .../geode/cache/query/internal/StructImpl.java  |   20 +-
 .../geode/cache/query/internal/StructSet.java   |   16 +-
 .../geode/cache/query/internal/Support.java     |    8 +-
 .../geode/cache/query/internal/Undefined.java   |   10 +-
 .../internal/aggregate/AbstractAggregator.java  |    4 +-
 .../cache/query/internal/aggregate/Avg.java     |    4 +-
 .../query/internal/aggregate/AvgBucketNode.java |    4 +-
 .../query/internal/aggregate/AvgDistinct.java   |    4 +-
 .../aggregate/AvgDistinctPRQueryNode.java       |    2 +-
 .../internal/aggregate/AvgPRQueryNode.java      |    2 +-
 .../cache/query/internal/aggregate/Count.java   |    6 +-
 .../query/internal/aggregate/CountDistinct.java |    2 +-
 .../aggregate/CountDistinctPRQueryNode.java     |    2 +-
 .../internal/aggregate/CountPRQueryNode.java    |    4 +-
 .../internal/aggregate/DistinctAggregator.java  |    4 +-
 .../cache/query/internal/aggregate/MaxMin.java  |    6 +-
 .../cache/query/internal/aggregate/Sum.java     |    4 +-
 .../query/internal/aggregate/SumDistinct.java   |    2 +-
 .../aggregate/SumDistinctPRQueryNode.java       |    2 +-
 .../geode/cache/query/internal/cq/ClientCQ.java |   12 +-
 .../query/internal/cq/CqAttributesImpl.java     |   18 +-
 .../cache/query/internal/cq/CqService.java      |   38 +-
 .../query/internal/cq/CqServiceProvider.java    |    8 +-
 .../query/internal/cq/InternalCqQuery.java      |   16 +-
 .../query/internal/cq/MissingCqService.java     |   38 +-
 .../internal/cq/MissingCqServiceStatistics.java |    4 +-
 .../geode/cache/query/internal/cq/ServerCQ.java |   12 +-
 .../query/internal/cq/spi/CqServiceFactory.java |    8 +-
 .../query/internal/index/AbstractIndex.java     |  102 +-
 .../query/internal/index/AbstractMapIndex.java  |   40 +-
 .../internal/index/CompactMapRangeIndex.java    |   16 +-
 .../query/internal/index/CompactRangeIndex.java |   92 +-
 .../query/internal/index/DummyQRegion.java      |   34 +-
 .../index/FunctionalIndexCreationHelper.java    |   58 +-
 .../cache/query/internal/index/HashIndex.java   |  102 +-
 .../query/internal/index/HashIndexSet.java      |   12 +-
 .../query/internal/index/IMQException.java      |    4 +-
 .../internal/index/IndexConcurrentHashSet.java  |    4 +-
 .../query/internal/index/IndexCreationData.java |    8 +-
 .../internal/index/IndexCreationHelper.java     |   12 +-
 .../cache/query/internal/index/IndexData.java   |    2 +-
 .../query/internal/index/IndexElemArray.java    |    2 +-
 .../query/internal/index/IndexManager.java      |   32 +-
 .../query/internal/index/IndexProtocol.java     |   32 +-
 .../cache/query/internal/index/IndexStats.java  |   12 +-
 .../cache/query/internal/index/IndexStore.java  |    6 +-
 .../cache/query/internal/index/IndexUtils.java  |   24 +-
 .../index/IndexedExpressionEvaluator.java       |    8 +-
 .../query/internal/index/MapIndexStore.java     |   28 +-
 .../query/internal/index/MapRangeIndex.java     |   12 +-
 .../query/internal/index/MemoryIndexStore.java  |   38 +-
 .../query/internal/index/PartitionedIndex.java  |   42 +-
 .../query/internal/index/PrimaryKeyIndex.java   |   54 +-
 .../index/PrimaryKeyIndexCreationHelper.java    |   22 +-
 .../cache/query/internal/index/RangeIndex.java  |   58 +-
 .../cache/query/internal/index/package.html     |    2 +-
 .../query/internal/parse/ASTAggregateFunc.java  |    8 +-
 .../cache/query/internal/parse/ASTAnd.java      |    4 +-
 .../query/internal/parse/ASTCombination.java    |    4 +-
 .../query/internal/parse/ASTCompareOp.java      |    4 +-
 .../query/internal/parse/ASTConstruction.java   |    6 +-
 .../query/internal/parse/ASTConversionExpr.java |    4 +-
 .../cache/query/internal/parse/ASTDummy.java    |    4 +-
 .../cache/query/internal/parse/ASTGroupBy.java  |    4 +-
 .../cache/query/internal/parse/ASTHint.java     |    4 +-
 .../query/internal/parse/ASTHintIdentifier.java |    4 +-
 .../query/internal/parse/ASTIdentifier.java     |    4 +-
 .../cache/query/internal/parse/ASTImport.java   |    4 +-
 .../geode/cache/query/internal/parse/ASTIn.java |    4 +-
 .../query/internal/parse/ASTIteratorDef.java    |    6 +-
 .../cache/query/internal/parse/ASTLike.java     |    4 +-
 .../cache/query/internal/parse/ASTLimit.java    |    4 +-
 .../cache/query/internal/parse/ASTLiteral.java  |    8 +-
 .../internal/parse/ASTMethodInvocation.java     |    6 +-
 .../geode/cache/query/internal/parse/ASTOr.java |    4 +-
 .../cache/query/internal/parse/ASTOrderBy.java  |    4 +-
 .../query/internal/parse/ASTParameter.java      |    4 +-
 .../cache/query/internal/parse/ASTPostfix.java  |    4 +-
 .../query/internal/parse/ASTProjection.java     |    4 +-
 .../query/internal/parse/ASTRegionPath.java     |    4 +-
 .../cache/query/internal/parse/ASTSelect.java   |    6 +-
 .../query/internal/parse/ASTSortCriterion.java  |    4 +-
 .../cache/query/internal/parse/ASTTrace.java    |    4 +-
 .../cache/query/internal/parse/ASTType.java     |    8 +-
 .../cache/query/internal/parse/ASTTypeCast.java |    4 +-
 .../cache/query/internal/parse/ASTUnary.java    |    6 +-
 .../query/internal/parse/ASTUndefinedExpr.java  |    4 +-
 .../query/internal/parse/ASTUnsupported.java    |    6 +-
 .../cache/query/internal/parse/GemFireAST.java  |    6 +-
 .../cache/query/internal/parse/OQLLexer.java    |    4 +-
 .../internal/parse/OQLLexerTokenTypes.java      |    4 +-
 .../cache/query/internal/parse/OQLParser.java   |  314 +--
 .../cache/query/internal/parse/UtilParser.java  |    4 +-
 .../geode/cache/query/internal/parse/oql.g      |  184 +-
 .../internal/types/CollectionTypeImpl.java      |   20 +-
 .../types/ExtendedNumericComparator.java        |    6 +-
 .../cache/query/internal/types/MapTypeImpl.java |    6 +-
 .../query/internal/types/NumericComparator.java |    2 +-
 .../query/internal/types/ObjectTypeImpl.java    |   14 +-
 .../query/internal/types/StructTypeImpl.java    |   12 +-
 .../internal/types/TemporalComparator.java      |    2 +-
 .../cache/query/internal/types/TypeUtils.java   |   28 +-
 .../query/internal/utils/LimitIterator.java     |    2 +-
 .../cache/query/internal/utils/PDXUtils.java    |   12 +-
 .../org/apache/geode/cache/query/package.html   |   20 +-
 .../geode/cache/query/types/CollectionType.java |    2 +-
 .../apache/geode/cache/query/types/MapType.java |    2 +-
 .../geode/cache/query/types/ObjectType.java     |    4 +-
 .../geode/cache/query/types/StructType.java     |    4 +-
 .../apache/geode/cache/server/CacheServer.java  |   22 +-
 .../cache/server/ClientSubscriptionConfig.java  |    2 +-
 .../apache/geode/cache/server/ServerLoad.java   |    4 +-
 .../geode/cache/server/ServerLoadProbe.java     |    4 +-
 .../cache/server/ServerLoadProbeAdapter.java    |    2 +-
 .../geode/cache/server/ServerMetrics.java       |    2 +-
 .../server/internal/ConnectionCountProbe.java   |   12 +-
 .../cache/server/internal/LoadMonitor.java      |   32 +-
 .../server/internal/ServerMetricsImpl.java      |    4 +-
 .../org/apache/geode/cache/server/package.html  |   12 +-
 .../cache/snapshot/CacheSnapshotService.java    |   12 +-
 .../cache/snapshot/RegionSnapshotService.java   |   12 +-
 .../geode/cache/snapshot/SnapshotFilter.java    |    2 +-
 .../geode/cache/snapshot/SnapshotIterator.java  |    2 +-
 .../geode/cache/snapshot/SnapshotOptions.java   |    2 +-
 .../geode/cache/snapshot/SnapshotReader.java    |   10 +-
 .../apache/geode/cache/snapshot/package.html    |   16 +-
 .../geode/cache/util/CacheListenerAdapter.java  |   10 +-
 .../geode/cache/util/CacheWriterAdapter.java    |   10 +-
 .../geode/cache/util/CqListenerAdapter.java     |    8 +-
 .../org/apache/geode/cache/util/Gateway.java    |    2 +-
 .../geode/cache/util/GatewayConflictHelper.java |    2 +-
 .../cache/util/GatewayConflictResolver.java     |    2 +-
 .../apache/geode/cache/util/GatewayEvent.java   |    8 +-
 .../apache/geode/cache/util/ObjectSizer.java    |    8 +-
 .../geode/cache/util/ObjectSizerImpl.java       |    2 +-
 .../util/RegionMembershipListenerAdapter.java   |   10 +-
 .../cache/util/RegionRoleListenerAdapter.java   |    6 +-
 .../geode/cache/util/TimestampedEntryEvent.java |    4 +-
 .../cache/util/TransactionListenerAdapter.java  |    6 +-
 .../org/apache/geode/cache/util/package.html    |    2 +-
 .../apache/geode/cache/wan/EventSequenceID.java |    4 +-
 .../geode/cache/wan/GatewayEventFilter.java     |    4 +-
 .../wan/GatewayEventSubstitutionFilter.java     |    6 +-
 .../geode/cache/wan/GatewayQueueEvent.java      |    8 +-
 .../apache/geode/cache/wan/GatewayReceiver.java |    6 +-
 .../geode/cache/wan/GatewayReceiverFactory.java |    2 +-
 .../apache/geode/cache/wan/GatewaySender.java   |    4 +-
 .../geode/cache/wan/GatewaySenderFactory.java   |    4 +-
 .../geode/cache/wan/GatewayTransportFilter.java |    4 +-
 .../geode/compression/CompressionException.java |    4 +-
 .../apache/geode/compression/Compressor.java    |    2 +-
 .../geode/compression/SnappyCompressor.java     |    2 +-
 .../geode/distributed/AbstractLauncher.java     |   42 +-
 .../geode/distributed/ClientSocketFactory.java  |    2 +-
 .../distributed/ConfigurationProperties.java    |   14 +-
 .../distributed/DistributedLockService.java     |   12 +-
 .../geode/distributed/DistributedMember.java    |    2 +-
 .../geode/distributed/DistributedSystem.java    |   58 +-
 .../DistributedSystemDisconnectedException.java |    4 +-
 .../distributed/DurableClientAttributes.java    |    4 +-
 .../distributed/FutureCancelledException.java   |    4 +-
 .../distributed/GatewayCancelledException.java  |    4 +-
 .../distributed/LeaseExpiredException.java      |    4 +-
 .../org/apache/geode/distributed/Locator.java   |   32 +-
 .../geode/distributed/LocatorLauncher.java      |   96 +-
 .../geode/distributed/LockNotHeldException.java |    2 +-
 .../LockServiceDestroyedException.java          |    2 +-
 .../distributed/OplogCancelledException.java    |    4 +-
 .../distributed/PoolCancelledException.java     |    4 +-
 .../java/org/apache/geode/distributed/Role.java |    2 +-
 .../geode/distributed/ServerLauncher.java       |  100 +-
 .../ServerLauncherCacheProvider.java            |    4 +-
 .../TXManagerCancelledException.java            |    4 +-
 .../internal/AbstractDistributionConfig.java    |   26 +-
 .../distributed/internal/AdminMessageType.java  |    2 +-
 .../internal/AtomicLongWithTerminalState.java   |    2 +-
 .../geode/distributed/internal/CacheTime.java   |    2 +-
 .../internal/CollectingReplyProcessor.java      |    6 +-
 .../distributed/internal/ConfigAttribute.java   |    2 +-
 .../internal/ConfigAttributeChecker.java        |    2 +-
 .../internal/ConfigAttributeDesc.java           |    2 +-
 .../internal/ConfigAttributeGetter.java         |    2 +-
 .../internal/ConfigAttributeSetter.java         |    2 +-
 .../distributed/internal/ConflationKey.java     |    2 +-
 .../apache/geode/distributed/internal/DM.java   |   16 +-
 .../geode/distributed/internal/DMStats.java     |    2 +-
 .../geode/distributed/internal/DSClock.java     |   20 +-
 .../DefaultServerLauncherCacheProvider.java     |   12 +-
 .../internal/DirectReplyProcessor.java          |    6 +-
 .../internal/DistributionAdvisee.java           |   10 +-
 .../internal/DistributionAdvisor.java           |   38 +-
 .../internal/DistributionChannel.java           |   16 +-
 .../internal/DistributionConfig.java            |   58 +-
 .../internal/DistributionConfigImpl.java        |   34 +-
 .../internal/DistributionConfigSnapshot.java    |    4 +-
 .../internal/DistributionException.java         |    4 +-
 .../internal/DistributionManager.java           |   92 +-
 .../internal/DistributionMessage.java           |   38 +-
 .../internal/DistributionMessageObserver.java   |    2 +-
 .../distributed/internal/DistributionStats.java |   22 +-
 .../distributed/internal/FlowControlParams.java |    2 +-
 .../FunctionExecutionPooledExecutor.java        |    6 +-
 .../distributed/internal/HealthMonitor.java     |    4 +-
 .../distributed/internal/HealthMonitorImpl.java |   20 +-
 .../internal/HighPriorityAckedMessage.java      |   18 +-
 .../HighPriorityDistributionMessage.java        |    2 +-
 .../distributed/internal/IgnoredByManager.java  |    2 +-
 .../internal/InternalDistributedSystem.java     |  116 +-
 .../distributed/internal/InternalLocator.java   |   86 +-
 .../internal/LocatorLoadSnapshot.java           |    8 +-
 .../distributed/internal/LocatorStats.java      |    8 +-
 .../internal/LonerDistributionManager.java      |   42 +-
 .../geode/distributed/internal/MQueue.java      |    2 +-
 .../internal/MembershipListener.java            |    4 +-
 .../distributed/internal/MessageFactory.java    |    6 +-
 .../distributed/internal/MessageWithReply.java  |    6 +-
 .../internal/OverflowQueueWithDMStats.java      |    2 +-
 .../distributed/internal/PoolStatHelper.java    |    2 +-
 .../internal/PooledDistributionMessage.java     |    2 +-
 .../internal/PooledExecutorWithDMStats.java     |    6 +-
 .../distributed/internal/ProcessorKeeper21.java |    4 +-
 .../distributed/internal/ProductUseLog.java     |   14 +-
 .../distributed/internal/ProfileListener.java   |    4 +-
 .../distributed/internal/QueueStatHelper.java   |    2 +-
 .../internal/ReliableReplyException.java        |    2 +-
 .../internal/ReliableReplyProcessor21.java      |    6 +-
 .../distributed/internal/ReplyException.java    |   12 +-
 .../distributed/internal/ReplyMessage.java      |   16 +-
 .../distributed/internal/ReplyProcessor21.java  |   38 +-
 .../geode/distributed/internal/ReplySender.java |    6 +-
 .../distributed/internal/ResourceEvent.java     |    2 +-
 .../internal/ResourceEventsListener.java        |    2 +-
 .../internal/RuntimeDistributionConfigImpl.java |   10 +-
 .../internal/SerialAckedMessage.java            |   12 +-
 .../internal/SerialDistributionMessage.java     |    2 +-
 .../SerialQueuedExecutorWithDMStats.java        |    2 +-
 .../distributed/internal/ServerLocation.java    |    8 +-
 .../distributed/internal/ServerLocator.java     |   62 +-
 .../internal/SharedConfiguration.java           |   74 +-
 .../distributed/internal/ShutdownMessage.java   |   10 +-
 .../geode/distributed/internal/Sizeable.java    |    2 +-
 .../distributed/internal/SizeableRunnable.java  |    2 +-
 .../distributed/internal/StartupMessage.java    |   20 +-
 .../internal/StartupMessageData.java            |    6 +-
 .../internal/StartupMessageReplyProcessor.java  |    6 +-
 .../distributed/internal/StartupOperation.java  |   12 +-
 .../internal/StartupResponseMessage.java        |   22 +-
 .../StartupResponseWithVersionMessage.java      |   14 +-
 .../internal/ThrottledMemQueueStatHelper.java   |    2 +-
 .../internal/ThrottledQueueStatHelper.java      |    2 +-
 .../ThrottlingMemLinkedQueueWithDMStats.java    |    4 +-
 .../internal/WaitForViewInstallation.java       |   10 +-
 .../internal/WanLocatorDiscoverer.java          |    4 +-
 .../deadlock/DLockDependencyMonitor.java        |    8 +-
 .../internal/deadlock/DeadlockDetector.java     |    2 +-
 .../internal/deadlock/Dependency.java           |    2 +-
 .../internal/deadlock/DependencyGraph.java      |    6 +-
 .../internal/deadlock/DependencyMonitor.java    |    2 +-
 .../deadlock/DependencyMonitorManager.java      |    4 +-
 .../deadlock/GemFireDeadlockDetector.java       |   24 +-
 .../internal/deadlock/LocalLockInfo.java        |    4 +-
 .../internal/deadlock/LocalThread.java          |    2 +-
 .../deadlock/MessageDependencyMonitor.java      |   12 +-
 .../internal/deadlock/ThreadReference.java      |    2 +-
 .../internal/deadlock/UnsafeThreadLocal.java    |    2 +-
 .../internal/direct/DirectChannel.java          |   44 +-
 .../internal/direct/DirectChannelListener.java  |    6 +-
 .../internal/direct/ShunnedMemberException.java |    4 +-
 .../internal/distribution-overview.html         |    6 +-
 .../internal/locks/Collaboration.java           |   10 +-
 .../distributed/internal/locks/DLockBatch.java  |    4 +-
 .../internal/locks/DLockBatchId.java            |    6 +-
 .../internal/locks/DLockGrantor.java            |   60 +-
 .../locks/DLockLessorDepartureHandler.java      |    4 +-
 .../internal/locks/DLockQueryProcessor.java     |   34 +-
 .../locks/DLockRecoverGrantorProcessor.java     |   32 +-
 .../internal/locks/DLockReleaseProcessor.java   |   32 +-
 .../internal/locks/DLockRemoteToken.java        |   12 +-
 .../internal/locks/DLockRequestProcessor.java   |   44 +-
 .../internal/locks/DLockService.java            |   54 +-
 .../distributed/internal/locks/DLockStats.java  |    8 +-
 .../distributed/internal/locks/DLockToken.java  |   22 +-
 .../internal/locks/DeposeGrantorProcessor.java  |   24 +-
 .../internal/locks/DistributedLockStats.java    |    4 +-
 .../internal/locks/DistributedMemberLock.java   |   16 +-
 .../internal/locks/DummyDLockStats.java         |    4 +-
 .../internal/locks/ElderInitProcessor.java      |   32 +-
 .../distributed/internal/locks/ElderState.java  |   18 +-
 .../distributed/internal/locks/GrantorInfo.java |    4 +-
 .../internal/locks/GrantorRequestProcessor.java |   40 +-
 .../locks/LockGrantorDestroyedException.java    |    2 +-
 .../internal/locks/LockGrantorId.java           |   10 +-
 .../locks/NonGrantorDestroyedProcessor.java     |   34 +-
 .../internal/locks/RemoteThread.java            |    4 +-
 .../distributed/internal/locks/package.html     |   24 +-
 .../DistributedMembershipListener.java          |    8 +-
 .../membership/InternalDistributedMember.java   |   38 +-
 .../internal/membership/InternalRole.java       |   16 +-
 .../internal/membership/MemberAttributes.java   |    4 +-
 .../internal/membership/MemberFactory.java      |   16 +-
 .../internal/membership/MemberServices.java     |   14 +-
 .../internal/membership/MembershipManager.java  |   12 +-
 .../internal/membership/MembershipTestHook.java |    2 +-
 .../internal/membership/NetMember.java          |    4 +-
 .../internal/membership/NetView.java            |   14 +-
 .../internal/membership/QuorumChecker.java      |    2 +-
 .../internal/membership/gms/GMSMember.java      |   20 +-
 .../membership/gms/GMSMemberFactory.java        |   34 +-
 .../internal/membership/gms/GMSUtil.java        |    6 +-
 .../internal/membership/gms/NetLocator.java     |    6 +-
 .../internal/membership/gms/ServiceConfig.java  |   12 +-
 .../internal/membership/gms/Services.java       |   48 +-
 .../internal/membership/gms/SuspectMember.java  |    4 +-
 .../membership/gms/auth/GMSAuthenticator.java   |   38 +-
 .../membership/gms/fd/GMSHealthMonitor.java     |   46 +-
 .../gms/interfaces/Authenticator.java           |    6 +-
 .../gms/interfaces/HealthMonitor.java           |    8 +-
 .../membership/gms/interfaces/JoinLeave.java    |   10 +-
 .../membership/gms/interfaces/Locator.java      |    4 +-
 .../membership/gms/interfaces/Manager.java      |   14 +-
 .../gms/interfaces/MessageHandler.java          |    4 +-
 .../membership/gms/interfaces/Messenger.java    |   10 +-
 .../membership/gms/interfaces/Service.java      |    8 +-
 .../gms/locator/FindCoordinatorRequest.java     |   16 +-
 .../gms/locator/FindCoordinatorResponse.java    |   18 +-
 .../membership/gms/locator/GMSLocator.java      |   46 +-
 .../membership/gms/locator/GetViewRequest.java  |    6 +-
 .../membership/gms/locator/GetViewResponse.java |   10 +-
 .../gms/locator/PeerLocatorRequest.java         |    2 +-
 .../membership/gms/membership/GMSJoinLeave.java |   58 +-
 .../membership/gms/messages/HasMemberID.java    |    4 +-
 .../gms/messages/HeartbeatMessage.java          |    8 +-
 .../gms/messages/HeartbeatRequestMessage.java   |   12 +-
 .../gms/messages/InstallViewMessage.java        |   12 +-
 .../gms/messages/JoinRequestMessage.java        |   12 +-
 .../gms/messages/JoinResponseMessage.java       |   16 +-
 .../gms/messages/LeaveRequestMessage.java       |   12 +-
 .../gms/messages/NetworkPartitionMessage.java   |    8 +-
 .../gms/messages/RemoveMemberMessage.java       |   12 +-
 .../gms/messages/SuspectMembersMessage.java     |   12 +-
 .../membership/gms/messages/SuspectRequest.java |    4 +-
 .../membership/gms/messages/ViewAckMessage.java |   12 +-
 .../gms/messenger/AddressManager.java           |    4 +-
 .../membership/gms/messenger/GMSEncrypt.java    |   12 +-
 .../membership/gms/messenger/GMSPingPonger.java |    4 +-
 .../gms/messenger/GMSQuorumChecker.java         |   12 +-
 .../membership/gms/messenger/JGAddress.java     |   10 +-
 .../gms/messenger/JGroupsMessenger.java         |   84 +-
 .../membership/gms/messenger/StatRecorder.java  |    8 +-
 .../membership/gms/messenger/Transport.java     |    2 +-
 .../gms/mgr/GMSMembershipManager.java           |  120 +-
 .../membership/gms/mgr/LocalViewMessage.java    |   10 +-
 .../geode/distributed/internal/package.html     |   12 +-
 .../internal/streaming/StreamingOperation.java  |   70 +-
 .../internal/tcpserver/InfoRequest.java         |    4 +-
 .../internal/tcpserver/InfoResponse.java        |    6 +-
 .../internal/tcpserver/ShutdownRequest.java     |    4 +-
 .../internal/tcpserver/ShutdownResponse.java    |    4 +-
 .../internal/tcpserver/TcpClient.java           |   16 +-
 .../internal/tcpserver/TcpHandler.java          |    8 +-
 .../internal/tcpserver/TcpServer.java           |   18 +-
 .../internal/tcpserver/VersionRequest.java      |    4 +-
 .../internal/tcpserver/VersionResponse.java     |    6 +-
 .../unsafe/RegisterSignalHandlerSupport.java    |    2 +-
 .../org/apache/geode/distributed/package.html   |    4 +-
 .../org/apache/geode/i18n/LogWriterI18n.java    |    6 +-
 .../java/org/apache/geode/i18n/StringId.java    |   10 +-
 .../apache/geode/internal/AbstractConfig.java   |   14 +-
 .../java/org/apache/geode/internal/Assert.java  |   12 +-
 .../apache/geode/internal/AvailablePort.java    |    6 +-
 .../java/org/apache/geode/internal/Banner.java  |   10 +-
 .../geode/internal/ByteArrayDataInput.java      |    6 +-
 .../geode/internal/ByteBufferOutputStream.java  |    2 +-
 .../apache/geode/internal/ByteBufferWriter.java |    2 +-
 .../apache/geode/internal/ClassLoadUtil.java    |    2 +-
 .../apache/geode/internal/ClassPathLoader.java  |    8 +-
 .../java/org/apache/geode/internal/Config.java  |    8 +-
 .../org/apache/geode/internal/ConfigSource.java |    2 +-
 .../geode/internal/ConnectionWatcher.java       |    2 +-
 .../geode/internal/CopyOnWriteHashSet.java      |    2 +-
 .../java/org/apache/geode/internal/DSCODE.java  |    4 +-
 .../org/apache/geode/internal/DSFIDFactory.java |  774 +++----
 .../geode/internal/DSFIDNotFoundException.java  |    2 +-
 .../geode/internal/DataSerializableFixedID.java |    8 +-
 .../geode/internal/DistributionLocator.java     |   20 +-
 .../geode/internal/ExternalizableDSFID.java     |    2 +-
 .../org/apache/geode/internal/FileUtil.java     |    4 +-
 .../apache/geode/internal/GemFireVersion.java   |    8 +-
 .../geode/internal/GfeConsoleReaderFactory.java |    8 +-
 .../geode/internal/HeapDataOutputStream.java    |   14 +-
 .../apache/geode/internal/HistogramStats.java   |   10 +-
 .../geode/internal/InternalDataSerializer.java  |   50 +-
 .../apache/geode/internal/InternalEntity.java   |    2 +-
 .../geode/internal/InternalInstantiator.java    |   44 +-
 .../InternalStatisticsDisabledException.java    |   12 +-
 .../apache/geode/internal/JarClassLoader.java   |   18 +-
 .../org/apache/geode/internal/JarDeployer.java  |    6 +-
 .../org/apache/geode/internal/ManagerInfo.java  |    6 +-
 .../apache/geode/internal/MigrationClient.java  |   22 +-
 .../apache/geode/internal/MigrationServer.java  |   28 +-
 .../org/apache/geode/internal/NanoTimer.java    |    2 +-
 .../geode/internal/NullDataOutputStream.java    |    4 +-
 .../org/apache/geode/internal/OSProcess.java    |   20 +-
 .../geode/internal/ObjIdConcurrentMap.java      |    2 +-
 .../org/apache/geode/internal/ObjIdMap.java     |    4 +-
 .../internal/ObjToByteArraySerializer.java      |    2 +-
 .../geode/internal/OneTaskOnlyExecutor.java     |    2 +-
 .../geode/internal/PdxSerializerObject.java     |   10 +-
 .../geode/internal/ProcessOutputReader.java     |    4 +-
 .../org/apache/geode/internal/PureJavaMode.java |    4 +-
 ...cheduledThreadPoolExecutorWithKeepAlive.java |    2 +-
 .../org/apache/geode/internal/Sendable.java     |    2 +-
 .../geode/internal/SerializationVersions.java   |    2 +-
 .../org/apache/geode/internal/SetUtils.java     |    2 +-
 .../apache/geode/internal/SharedLibrary.java    |   10 +-
 .../org/apache/geode/internal/SmHelper.java     |    4 +-
 .../org/apache/geode/internal/SocketCloser.java |    8 +-
 .../apache/geode/internal/SocketCreator.java    |   38 +-
 .../org/apache/geode/internal/SystemAdmin.java  |   52 +-
 .../geode/internal/SystemFailureTestHook.java   |    2 +-
 .../org/apache/geode/internal/SystemTimer.java  |   14 +-
 .../geode/internal/UniqueIdGenerator.java       |    4 +-
 .../java/org/apache/geode/internal/Version.java |    8 +-
 .../internal/VersionedDataInputStream.java      |    2 +-
 .../internal/VersionedDataOutputStream.java     |    2 +-
 .../internal/VersionedDataSerializable.java     |    4 +-
 .../geode/internal/VersionedDataStream.java     |    4 +-
 .../geode/internal/VersionedObjectInput.java    |    2 +-
 .../geode/internal/VersionedObjectOutput.java   |    2 +-
 .../geode/internal/admin/AdminBridgeServer.java |    4 +-
 .../org/apache/geode/internal/admin/Alert.java  |    6 +-
 .../geode/internal/admin/AlertListener.java     |    2 +-
 .../geode/internal/admin/ApplicationVM.java     |    6 +-
 .../geode/internal/admin/CacheCollector.java    |   12 +-
 .../apache/geode/internal/admin/CacheInfo.java  |    4 +-
 .../geode/internal/admin/CacheSnapshot.java     |    2 +-
 .../admin/ClientHealthMonitoringRegion.java     |   24 +-
 .../internal/admin/ClientMembershipMessage.java |   16 +-
 .../internal/admin/ClientStatsManager.java      |   36 +-
 .../internal/admin/CompoundEntrySnapshot.java   |    8 +-
 .../internal/admin/CompoundRegionSnapshot.java  |   20 +-
 .../apache/geode/internal/admin/DLockInfo.java  |    4 +-
 .../geode/internal/admin/EntrySnapshot.java     |    2 +-
 .../geode/internal/admin/EntryValueNode.java    |    2 +-
 .../apache/geode/internal/admin/GemFireVM.java  |   26 +-
 .../geode/internal/admin/GfManagerAgent.java    |    6 +-
 .../internal/admin/GfManagerAgentConfig.java    |    6 +-
 .../internal/admin/GfManagerAgentFactory.java   |    4 +-
 .../apache/geode/internal/admin/GfObject.java   |    2 +-
 .../geode/internal/admin/HealthListener.java    |    6 +-
 .../geode/internal/admin/JoinLeaveListener.java |    2 +-
 .../geode/internal/admin/ListenerIdMap.java     |    4 +-
 .../geode/internal/admin/RegionSnapshot.java    |    4 +-
 .../apache/geode/internal/admin/SSLConfig.java  |    8 +-
 .../geode/internal/admin/SnapshotClient.java    |    2 +-
 .../org/apache/geode/internal/admin/Stat.java   |    2 +-
 .../apache/geode/internal/admin/StatAlert.java  |    2 +-
 .../internal/admin/StatAlertDefinition.java     |    8 +-
 .../geode/internal/admin/StatAlertsManager.java |   38 +-
 .../geode/internal/admin/StatListener.java      |    2 +-
 .../geode/internal/admin/StatResource.java      |    2 +-
 .../geode/internal/admin/TransportConfig.java   |    2 +-
 .../apache/geode/internal/admin/package.html    |    2 +-
 .../admin/remote/AddHealthListenerRequest.java  |   14 +-
 .../admin/remote/AddHealthListenerResponse.java |   14 +-
 .../admin/remote/AddStatListenerRequest.java    |   12 +-
 .../admin/remote/AddStatListenerResponse.java   |   12 +-
 .../remote/AdminConsoleDisconnectMessage.java   |   20 +-
 .../admin/remote/AdminConsoleMessage.java       |   16 +-
 .../admin/remote/AdminFailureResponse.java      |   10 +-
 .../remote/AdminMultipleReplyProcessor.java     |   18 +-
 .../internal/admin/remote/AdminRegion.java      |   26 +-
 .../admin/remote/AdminReplyProcessor.java       |    8 +-
 .../internal/admin/remote/AdminRequest.java     |   22 +-
 .../internal/admin/remote/AdminResponse.java    |   12 +-
 .../internal/admin/remote/AdminWaiters.java     |   18 +-
 .../admin/remote/AlertLevelChangeMessage.java   |   18 +-
 .../admin/remote/AlertListenerMessage.java      |   16 +-
 .../admin/remote/AlertsNotificationMessage.java |   14 +-
 .../admin/remote/AppCacheSnapshotMessage.java   |   12 +-
 .../admin/remote/BridgeServerRequest.java       |   10 +-
 .../admin/remote/BridgeServerResponse.java      |   18 +-
 .../admin/remote/CacheConfigRequest.java        |   12 +-
 .../admin/remote/CacheConfigResponse.java       |   16 +-
 .../internal/admin/remote/CacheDisplay.java     |    6 +-
 .../internal/admin/remote/CacheInfoRequest.java |   10 +-
 .../admin/remote/CacheInfoResponse.java         |   16 +-
 .../admin/remote/CancelStatListenerRequest.java |   10 +-
 .../remote/CancelStatListenerResponse.java      |   14 +-
 .../internal/admin/remote/Cancellable.java      |    2 +-
 .../admin/remote/CancellationMessage.java       |   14 +-
 .../admin/remote/CancellationRegistry.java      |    6 +-
 .../remote/ChangeRefreshIntervalMessage.java    |   10 +-
 .../internal/admin/remote/CliLegacyMessage.java |   10 +-
 .../admin/remote/ClientHealthStats.java         |   10 +-
 .../internal/admin/remote/CompactRequest.java   |   22 +-
 .../internal/admin/remote/CompactResponse.java  |    8 +-
 .../admin/remote/DestroyEntryMessage.java       |   20 +-
 .../admin/remote/DestroyRegionMessage.java      |   20 +-
 .../admin/remote/DistributionLocatorId.java     |   14 +-
 .../geode/internal/admin/remote/DummyEntry.java |    8 +-
 .../admin/remote/DurableClientInfoRequest.java  |    8 +-
 .../admin/remote/DurableClientInfoResponse.java |   16 +-
 .../admin/remote/EntryValueNodeImpl.java        |   10 +-
 .../admin/remote/FetchDistLockInfoRequest.java  |   10 +-
 .../admin/remote/FetchDistLockInfoResponse.java |   16 +-
 .../remote/FetchHealthDiagnosisRequest.java     |   10 +-
 .../remote/FetchHealthDiagnosisResponse.java    |   14 +-
 .../internal/admin/remote/FetchHostRequest.java |    6 +-
 .../admin/remote/FetchHostResponse.java         |   24 +-
 .../remote/FetchResourceAttributesRequest.java  |   10 +-
 .../remote/FetchResourceAttributesResponse.java |    8 +-
 .../admin/remote/FetchStatsRequest.java         |   10 +-
 .../admin/remote/FetchStatsResponse.java        |   12 +-
 .../admin/remote/FetchSysCfgRequest.java        |    8 +-
 .../admin/remote/FetchSysCfgResponse.java       |   10 +-
 .../remote/FlushAppCacheSnapshotMessage.java    |    8 +-
 .../admin/remote/HealthListenerMessage.java     |   14 +-
 .../remote/InspectionClasspathManager.java      |    2 +-
 .../admin/remote/LicenseInfoRequest.java        |   10 +-
 .../admin/remote/LicenseInfoResponse.java       |   10 +-
 .../remote/MissingPersistentIDsRequest.java     |   26 +-
 .../remote/MissingPersistentIDsResponse.java    |   14 +-
 .../admin/remote/ObjectDetailsRequest.java      |   10 +-
 .../admin/remote/ObjectDetailsResponse.java     |   14 +-
 .../admin/remote/ObjectNamesRequest.java        |   10 +-
 .../admin/remote/ObjectNamesResponse.java       |   14 +-
 .../PrepareRevokePersistentIDRequest.java       |   22 +-
 .../remote/RefreshMemberSnapshotRequest.java    |    6 +-
 .../remote/RefreshMemberSnapshotResponse.java   |   18 +-
 .../admin/remote/RegionAdminMessage.java        |   16 +-
 .../admin/remote/RegionAdminRequest.java        |   24 +-
 .../admin/remote/RegionAttributesRequest.java   |   10 +-
 .../admin/remote/RegionAttributesResponse.java  |   14 +-
 .../internal/admin/remote/RegionRequest.java    |   12 +-
 .../internal/admin/remote/RegionResponse.java   |   18 +-
 .../admin/remote/RegionSizeRequest.java         |   10 +-
 .../admin/remote/RegionSizeResponse.java        |   14 +-
 .../admin/remote/RegionStatisticsRequest.java   |   10 +-
 .../admin/remote/RegionStatisticsResponse.java  |   14 +-
 .../remote/RegionSubRegionSizeRequest.java      |    4 +-
 .../remote/RegionSubRegionsSizeResponse.java    |   20 +-
 .../internal/admin/remote/RemoteAlert.java      |   16 +-
 .../admin/remote/RemoteApplicationVM.java       |    6 +-
 .../admin/remote/RemoteBridgeServer.java        |   36 +-
 .../internal/admin/remote/RemoteCacheInfo.java  |   26 +-
 .../admin/remote/RemoteCacheStatistics.java     |    8 +-
 .../internal/admin/remote/RemoteDLockInfo.java  |   16 +-
 .../admin/remote/RemoteEntrySnapshot.java       |   10 +-
 .../internal/admin/remote/RemoteGemFireVM.java  |   60 +-
 .../admin/remote/RemoteGfManagerAgent.java      |   46 +-
 .../internal/admin/remote/RemoteObjectName.java |   12 +-
 .../admin/remote/RemoteRegionAttributes.java    |   60 +-
 .../admin/remote/RemoteRegionSnapshot.java      |   10 +-
 .../geode/internal/admin/remote/RemoteStat.java |    8 +-
 .../admin/remote/RemoteStatResource.java        |    6 +-
 .../admin/remote/RemoteTransportConfig.java     |   16 +-
 .../remote/RemoveHealthListenerRequest.java     |   12 +-
 .../remote/RemoveHealthListenerResponse.java    |   12 +-
 .../admin/remote/ResetHealthStatusRequest.java  |   12 +-
 .../admin/remote/ResetHealthStatusResponse.java |   12 +-
 .../admin/remote/RevokePersistentIDRequest.java |   18 +-
 .../remote/RevokePersistentIDResponse.java      |    4 +-
 .../admin/remote/RootRegionRequest.java         |   10 +-
 .../admin/remote/RootRegionResponse.java        |   24 +-
 .../remote/ShutdownAllGatewayHubsRequest.java   |    8 +-
 .../admin/remote/ShutdownAllRequest.java        |   20 +-
 .../admin/remote/ShutdownAllResponse.java       |    4 +-
 .../admin/remote/SnapshotResultMessage.java     |   12 +-
 .../remote/StatAlertsManagerAssignMessage.java  |   12 +-
 .../admin/remote/StatListenerMessage.java       |   10 +-
 .../admin/remote/StoreSysCfgRequest.java        |   12 +-
 .../admin/remote/StoreSysCfgResponse.java       |   10 +-
 .../internal/admin/remote/SubRegionRequest.java |   10 +-
 .../admin/remote/SubRegionResponse.java         |   14 +-
 .../internal/admin/remote/TailLogRequest.java   |   10 +-
 .../internal/admin/remote/TailLogResponse.java  |   24 +-
 .../remote/UpdateAlertDefinitionMessage.java    |   14 +-
 .../admin/remote/VersionInfoRequest.java        |   10 +-
 .../admin/remote/VersionInfoResponse.java       |   10 +-
 .../admin/remote/VersionMismatchAlert.java      |    6 +-
 .../geode/internal/admin/remote/package.html    |    4 +-
 .../admin/statalerts/BaseDecoratorImpl.java     |   12 +-
 .../statalerts/DummyStatisticInfoImpl.java      |    8 +-
 .../admin/statalerts/FunctionDecoratorImpl.java |   10 +-
 .../admin/statalerts/FunctionHelper.java        |    4 +-
 .../statalerts/GaugeThresholdDecoratorImpl.java |   14 +-
 .../statalerts/MultiAttrDefinitionImpl.java     |   14 +-
 .../NumberThresholdDecoratorImpl.java           |   14 +-
 .../statalerts/SingleAttrDefinitionImpl.java    |   20 +-
 .../admin/statalerts/StatisticInfo.java         |   10 +-
 .../admin/statalerts/StatisticInfoImpl.java     |   12 +-
 .../cache/AbstractBucketRegionQueue.java        |   32 +-
 .../internal/cache/AbstractCacheServer.java     |   30 +-
 .../cache/AbstractDiskLRURegionEntry.java       |    4 +-
 .../internal/cache/AbstractDiskRegion.java      |   38 +-
 .../internal/cache/AbstractDiskRegionEntry.java |   10 +-
 .../internal/cache/AbstractLRURegionEntry.java  |    4 +-
 .../internal/cache/AbstractLRURegionMap.java    |   48 +-
 .../cache/AbstractOplogDiskRegionEntry.java     |   14 +-
 .../geode/internal/cache/AbstractRegion.java    |   58 +-
 .../internal/cache/AbstractRegionEntry.java     |   88 +-
 .../geode/internal/cache/AbstractRegionMap.java |   78 +-
 .../internal/cache/AbstractUpdateOperation.java |   42 +-
 .../geode/internal/cache/AcceptHelper.java      |    2 +-
 .../cache/AddCacheServerProfileMessage.java     |   14 +-
 .../apache/geode/internal/cache/BackupLock.java |    2 +-
 .../geode/internal/cache/BucketAdvisor.java     |   60 +-
 .../apache/geode/internal/cache/BucketDump.java |    8 +-
 .../internal/cache/BucketNotFoundException.java |    2 +-
 .../cache/BucketPersistenceAdvisor.java         |   36 +-
 .../geode/internal/cache/BucketRegion.java      |  108 +-
 .../internal/cache/BucketRegionEvictior.java    |    4 +-
 .../geode/internal/cache/BucketRegionQueue.java |   38 +-
 .../internal/cache/BucketServerLocation.java    |    6 +-
 .../internal/cache/BucketServerLocation66.java  |    6 +-
 .../cache/BytesAndBitsForCompactor.java         |    6 +-
 .../geode/internal/cache/CacheClientStatus.java |    4 +-
 .../geode/internal/cache/CacheConfig.java       |   12 +-
 .../cache/CacheDistributionAdvisee.java         |   10 +-
 .../cache/CacheDistributionAdvisor.java         |   44 +-
 .../internal/cache/CacheLifecycleListener.java  |    2 +-
 .../geode/internal/cache/CacheObserver.java     |    6 +-
 .../internal/cache/CacheObserverAdapter.java    |   14 +-
 .../internal/cache/CacheObserverHolder.java     |    4 +-
 .../geode/internal/cache/CachePerfStats.java    |   12 +-
 .../internal/cache/CacheServerAdvisor.java      |   14 +-
 .../geode/internal/cache/CacheServerImpl.java   |   60 +-
 .../internal/cache/CacheServerLauncher.java     |   48 +-
 .../geode/internal/cache/CacheService.java      |    6 +-
 .../internal/cache/CacheServiceProfile.java     |    4 +-
 .../internal/cache/CacheStatisticsImpl.java     |   12 +-
 .../internal/cache/CachedDeserializable.java    |   12 +-
 .../cache/CachedDeserializableFactory.java      |   20 +-
 .../internal/cache/ClientRegionEventImpl.java   |   12 +-
 .../internal/cache/ClientServerObserver.java    |    6 +-
 .../cache/ClientServerObserverAdapter.java      |    6 +-
 .../cache/ClientServerObserverHolder.java       |    4 +-
 .../cache/ClientSubscriptionConfigImpl.java     |    6 +-
 .../geode/internal/cache/CloseCacheMessage.java |   14 +-
 .../cache/ClusterConfigurationLoader.java       |   36 +-
 .../geode/internal/cache/ColocationHelper.java  |   32 +-
 .../geode/internal/cache/ColocationLogger.java  |   14 +-
 .../internal/cache/CommitReplyException.java    |    4 +-
 .../geode/internal/cache/CompactableOplog.java  |    8 +-
 .../geode/internal/cache/Conflatable.java       |    2 +-
 .../geode/internal/cache/ControllerAdvisor.java |   12 +-
 .../internal/cache/CountingDataInputStream.java |    2 +-
 .../internal/cache/CreateRegionProcessor.java   |   64 +-
 .../internal/cache/CustomEntryExpiryTask.java   |    4 +-
 .../internal/cache/DataLocationException.java   |    4 +-
 .../geode/internal/cache/DestroyOperation.java  |   26 +-
 .../cache/DestroyPartitionedRegionMessage.java  |   40 +-
 .../internal/cache/DestroyRegionOperation.java  |   50 +-
 .../geode/internal/cache/DestroyedEntry.java    |    8 +-
 .../internal/cache/DirectReplyMessage.java      |   12 +-
 .../geode/internal/cache/DirectoryHolder.java   |    4 +-
 .../internal/cache/DiskDirectoryStats.java      |   10 +-
 .../apache/geode/internal/cache/DiskEntry.java  |   56 +-
 .../org/apache/geode/internal/cache/DiskId.java |    4 +-
 .../geode/internal/cache/DiskInitFile.java      |   64 +-
 .../apache/geode/internal/cache/DiskRegion.java |   32 +-
 .../geode/internal/cache/DiskRegionStats.java   |   16 +-
 .../internal/cache/DiskStoreAttributes.java     |   26 +-
 .../geode/internal/cache/DiskStoreBackup.java   |    6 +-
 .../internal/cache/DiskStoreFactoryImpl.java    |   26 +-
 .../geode/internal/cache/DiskStoreImpl.java     |   82 +-
 .../geode/internal/cache/DiskStoreMonitor.java  |   18 +-
 .../geode/internal/cache/DiskStoreObserver.java |    2 +-
 .../geode/internal/cache/DiskStoreStats.java    |   10 +-
 .../geode/internal/cache/DiskStoreTask.java     |    2 +-
 .../internal/cache/DiskWriteAttributesImpl.java |   10 +-
 .../internal/cache/DistPeerTXStateStub.java     |   42 +-
 .../cache/DistTXAdjunctCommitMessage.java       |    8 +-
 .../internal/cache/DistTXCommitMessage.java     |   40 +-
 .../cache/DistTXCoordinatorInterface.java       |    8 +-
 .../internal/cache/DistTXPrecommitMessage.java  |   48 +-
 .../internal/cache/DistTXRollbackMessage.java   |   42 +-
 .../geode/internal/cache/DistTXState.java       |   54 +-
 .../cache/DistTXStateOnCoordinator.java         |   36 +-
 .../internal/cache/DistTXStateProxyImpl.java    |    6 +-
 .../DistTXStateProxyImplOnCoordinator.java      |   36 +-
 .../cache/DistTXStateProxyImplOnDatanode.java   |   14 +-
 .../cache/DistributedCacheOperation.java        |  100 +-
 .../cache/DistributedClearOperation.java        |   22 +-
 .../cache/DistributedPutAllOperation.java       |   60 +-
 .../geode/internal/cache/DistributedRegion.java |  100 +-
 ...stributedRegionFunctionStreamingMessage.java |   46 +-
 .../cache/DistributedRemoveAllOperation.java    |   62 +-
 .../cache/DistributedTombstoneOperation.java    |   32 +-
 .../internal/cache/DummyCachePerfStats.java     |    6 +-
 .../internal/cache/DynamicRegionAttributes.java |    6 +-
 .../cache/DynamicRegionFactoryImpl.java         |    6 +-
 .../apache/geode/internal/cache/EntriesMap.java |    8 +-
 .../apache/geode/internal/cache/EntriesSet.java |   14 +-
 .../apache/geode/internal/cache/EntryBits.java  |    2 +-
 .../geode/internal/cache/EntryEventImpl.java    |   88 +-
 .../geode/internal/cache/EntryExpiryTask.java   |   12 +-
 .../internal/cache/EntryOperationImpl.java      |    8 +-
 .../geode/internal/cache/EntrySnapshot.java     |   20 +-
 .../geode/internal/cache/EnumListenerEvent.java |    4 +-
 .../apache/geode/internal/cache/EventID.java    |   36 +-
 .../geode/internal/cache/EventIDHolder.java     |    2 +-
 .../geode/internal/cache/EventStateHelper.java  |   20 +-
 .../geode/internal/cache/EventTracker.java      |   32 +-
 .../internal/cache/EvictionAttributesImpl.java  |   46 +-
 .../internal/cache/ExpirationScheduler.java     |   16 +-
 .../apache/geode/internal/cache/ExpiryTask.java |   28 +-
 .../geode/internal/cache/ExportDiskRegion.java  |   10 +-
 .../geode/internal/cache/FilterProfile.java     |   88 +-
 .../geode/internal/cache/FilterRoutingInfo.java |   24 +-
 .../cache/FindDurableQueueProcessor.java        |   30 +-
 .../internal/cache/FindRemoteTXMessage.java     |   36 +-
 .../internal/cache/FindVersionTagOperation.java |   28 +-
 .../cache/FixedPartitionAttributesImpl.java     |   10 +-
 .../internal/cache/ForceReattemptException.java |    8 +-
 .../cache/ForceableLinkedBlockingQueue.java     |    2 +-
 .../FunctionStreamingOrderedReplyMessage.java   |   12 +-
 .../cache/FunctionStreamingReplyMessage.java    |   18 +-
 .../internal/cache/GatewayEventFilter.java      |    2 +-
 .../geode/internal/cache/GemFireCacheImpl.java  |  326 +--
 .../internal/cache/GemfireCacheHelper.java      |    2 +-
 .../geode/internal/cache/GridAdvisor.java       |   14 +-
 .../apache/geode/internal/cache/HARegion.java   |   58 +-
 .../geode/internal/cache/HasCachePerfStats.java |    2 +-
 .../geode/internal/cache/IdentityArrayList.java |    2 +-
 .../apache/geode/internal/cache/ImageState.java |   10 +-
 .../cache/InMemoryPersistentMemberView.java     |   12 +-
 .../internal/cache/IncomingGatewayStatus.java   |    2 +-
 .../internal/cache/InitialImageFlowControl.java |   24 +-
 .../internal/cache/InitialImageOperation.java   |   98 +-
 .../geode/internal/cache/InlineKeyHelper.java   |    4 +-
 .../geode/internal/cache/InterestEvent.java     |    6 +-
 .../geode/internal/cache/InterestFilter.java    |    4 +-
 .../cache/InterestRegistrationEventImpl.java    |   18 +-
 .../geode/internal/cache/InternalCache.java     |   12 +-
 .../internal/cache/InternalCacheEvent.java      |   10 +-
 .../geode/internal/cache/InternalDataView.java  |   16 +-
 .../internal/cache/InternalRegionArguments.java |   12 +-
 .../internal/cache/InvalidateOperation.java     |   22 +-
 .../InvalidatePartitionedRegionMessage.java     |   24 +-
 .../cache/InvalidateRegionOperation.java        |   10 +-
 .../cache/JtaAfterCompletionMessage.java        |   28 +-
 .../cache/JtaBeforeCompletionMessage.java       |   22 +-
 .../apache/geode/internal/cache/KeyInfo.java    |   12 +-
 .../internal/cache/LoaderHelperFactory.java     |    6 +-
 .../geode/internal/cache/LoaderHelperImpl.java  |   10 +-
 .../geode/internal/cache/LocalDataSet.java      |   72 +-
 .../geode/internal/cache/LocalRegion.java       |  338 +--
 .../internal/cache/LocalRegionDataView.java     |   54 +-
 .../cache/MemberFunctionStreamingMessage.java   |   60 +-
 .../cache/MinimumSystemRequirements.java        |   10 +-
 .../cache/NetSearchExpirationCalculator.java    |    4 +-
 .../org/apache/geode/internal/cache/Node.java   |   12 +-
 .../internal/cache/NonLocalRegionEntry.java     |   62 +-
 .../cache/NonLocalRegionEntryWithStats.java     |    8 +-
 .../internal/cache/OffHeapRegionEntry.java      |    4 +-
 .../cache/OfflineCompactionDiskRegion.java      |   12 +-
 .../org/apache/geode/internal/cache/OpType.java |    4 +-
 .../org/apache/geode/internal/cache/Oplog.java  |   78 +-
 .../apache/geode/internal/cache/OplogSet.java   |    4 +-
 .../internal/cache/OrderedTombstoneMap.java     |    8 +-
 .../geode/internal/cache/OverflowOplog.java     |   32 +-
 .../geode/internal/cache/OverflowOplogSet.java  |   12 +-
 .../internal/cache/PRContainsValueFunction.java |   12 +-
 .../internal/cache/PRHARedundancyProvider.java  |   70 +-
 .../geode/internal/cache/PRQueryProcessor.java  |   34 +-
 .../internal/cache/PRSystemPropertyGetter.java  |    2 +-
 .../internal/cache/PartitionAttributesImpl.java |   34 +-
 .../internal/cache/PartitionRegionConfig.java   |   30 +-
 .../cache/PartitionRegionConfigValidator.java   |   26 +-
 .../geode/internal/cache/PartitionedRegion.java |  190 +-
 .../PartitionedRegionBucketMgmtHelper.java      |    8 +-
 .../cache/PartitionedRegionDataStore.java       |   94 +-
 .../cache/PartitionedRegionDataView.java        |   10 +-
 .../cache/PartitionedRegionException.java       |    4 +-
 .../internal/cache/PartitionedRegionHelper.java |   72 +-
 .../cache/PartitionedRegionQueryEvaluator.java  |   40 +-
 .../internal/cache/PartitionedRegionStats.java  |   16 +-
 .../internal/cache/PartitionedRegionStatus.java |    2 +-
 .../geode/internal/cache/PeerTXStateStub.java   |   40 +-
 .../internal/cache/PersistentOplogSet.java      |   30 +-
 .../internal/cache/PlaceHolderDiskRegion.java   |   20 +-
 .../geode/internal/cache/PoolFactoryImpl.java   |   32 +-
 .../geode/internal/cache/PoolManagerImpl.java   |   40 +-
 .../apache/geode/internal/cache/PoolStats.java  |   10 +-
 .../cache/PreferBytesCachedDeserializable.java  |   14 +-
 .../internal/cache/PrimaryBucketException.java  |    4 +-
 .../cache/ProfileExchangeProcessor.java         |    6 +-
 .../geode/internal/cache/ProxyBucketRegion.java |   54 +-
 .../geode/internal/cache/ProxyRegionMap.java    |   52 +-
 .../cache/PutAllPartialResultException.java     |    8 +-
 .../geode/internal/cache/QueuedOperation.java   |   16 +-
 .../internal/cache/RegionClearedException.java  |    2 +-
 .../geode/internal/cache/RegionEntry.java       |   36 +-
 .../internal/cache/RegionEntryContext.java      |    6 +-
 .../internal/cache/RegionEntryFactory.java      |    2 +-
 .../geode/internal/cache/RegionEventImpl.java   |   38 +-
 .../geode/internal/cache/RegionEvictorTask.java |   14 +-
 .../geode/internal/cache/RegionExpiryTask.java  |   12 +-
 .../geode/internal/cache/RegionFactoryImpl.java |    8 +-
 .../internal/cache/RegionIdleExpiryTask.java    |    4 +-
 .../geode/internal/cache/RegionListener.java    |    6 +-
 .../apache/geode/internal/cache/RegionMap.java  |   30 +-
 .../geode/internal/cache/RegionMapFactory.java  |    2 +-
 .../geode/internal/cache/RegionQueue.java       |    4 +-
 .../internal/cache/RegionQueueException.java    |    4 +-
 .../geode/internal/cache/RegionStatus.java      |    8 +-
 .../internal/cache/RegionTTLExpiryTask.java     |    4 +-
 .../internal/cache/ReleaseClearLockMessage.java |   24 +-
 .../cache/ReliableDistributionData.java         |    2 +-
 .../internal/cache/ReliableMessageQueue.java    |    4 +-
 .../cache/ReliableMessageQueueFactory.java      |    2 +-
 .../cache/ReliableMessageQueueFactoryImpl.java  |    6 +-
 .../cache/RemoteContainsKeyValueMessage.java    |   46 +-
 .../internal/cache/RemoteDestroyMessage.java    |   78 +-
 .../internal/cache/RemoteFetchEntryMessage.java |   54 +-
 .../cache/RemoteFetchVersionMessage.java        |   34 +-
 .../geode/internal/cache/RemoteGetMessage.java  |   62 +-
 .../internal/cache/RemoteInvalidateMessage.java |   62 +-
 .../cache/RemoteOperationException.java         |    8 +-
 .../internal/cache/RemoteOperationMessage.java  |   64 +-
 .../RemoteOperationMessageWithDirectReply.java  |   16 +-
 .../internal/cache/RemotePutAllMessage.java     |   66 +-
 .../geode/internal/cache/RemotePutMessage.java  |   86 +-
 .../internal/cache/RemoteRegionOperation.java   |   26 +-
 .../internal/cache/RemoteRemoveAllMessage.java  |   66 +-
 .../geode/internal/cache/RoleEventImpl.java     |   18 +-
 .../cache/SearchLoadAndWriteProcessor.java      |   34 +-
 .../internal/cache/SendQueueOperation.java      |   10 +-
 .../internal/cache/SerializationHelper.java     |    2 +-
 .../geode/internal/cache/ServerPingMessage.java |   20 +-
 .../internal/cache/StateFlushOperation.java     |   42 +-
 .../cache/StoreAllCachedDeserializable.java     |   14 +-
 .../internal/cache/TXBucketRegionState.java     |    2 +-
 .../geode/internal/cache/TXCommitMessage.java   |   90 +-
 .../apache/geode/internal/cache/TXEntry.java    |   18 +-
 .../geode/internal/cache/TXEntryState.java      |   42 +-
 .../internal/cache/TXEntryStateFactory.java     |    4 +-
 .../internal/cache/TXEntryUserAttrState.java    |    6 +-
 .../apache/geode/internal/cache/TXEvent.java    |    6 +-
 .../internal/cache/TXFarSideCMTracker.java      |   18 +-
 .../org/apache/geode/internal/cache/TXId.java   |   16 +-
 .../geode/internal/cache/TXLockRequest.java     |    6 +-
 .../geode/internal/cache/TXManagerImpl.java     |   40 +-
 .../apache/geode/internal/cache/TXMessage.java  |   38 +-
 .../internal/cache/TXRegionLockRequestImpl.java |   14 +-
 .../geode/internal/cache/TXRegionState.java     |   14 +-
 .../internal/cache/TXRemoteCommitMessage.java   |   38 +-
 .../internal/cache/TXRemoteRollbackMessage.java |   22 +-
 .../geode/internal/cache/TXReservationMgr.java  |    8 +-
 .../apache/geode/internal/cache/TXRmtEvent.java |   18 +-
 .../apache/geode/internal/cache/TXState.java    |  140 +-
 .../geode/internal/cache/TXStateInterface.java  |   18 +-
 .../geode/internal/cache/TXStateProxy.java      |   10 +-
 .../geode/internal/cache/TXStateProxyImpl.java  |  140 +-
 .../geode/internal/cache/TXStateStub.java       |  118 +-
 .../cache/TXSynchronizationRunnable.java        |    6 +-
 .../cache/TestHeapThresholdObserver.java        |    2 +-
 .../cache/TimestampedEntryEventImpl.java        |   14 +-
 .../org/apache/geode/internal/cache/Token.java  |    8 +-
 .../geode/internal/cache/TombstoneService.java  |   36 +-
 .../internal/cache/TransactionMessage.java      |    6 +-
 .../geode/internal/cache/TxEntryFactory.java    |    2 +-
 .../internal/cache/UnsharedImageState.java      |   20 +-
 .../cache/UpdateAttributesProcessor.java        |   44 +-
 .../cache/UpdateEntryVersionOperation.java      |   26 +-
 .../geode/internal/cache/UpdateOperation.java   |   50 +-
 .../cache/UserSpecifiedDiskStoreAttributes.java |    6 +-
 .../cache/UserSpecifiedRegionAttributes.java    |    8 +-
 .../internal/cache/VMCachedDeserializable.java  |   22 +-
 .../geode/internal/cache/VMLRURegionMap.java    |    6 +-
 .../geode/internal/cache/VMRegionMap.java       |    2 +-
 .../cache/VMStatsDiskLRURegionEntry.java        |    2 +-
 .../cache/VMStatsDiskLRURegionEntryHeap.java    |    2 +-
 .../VMStatsDiskLRURegionEntryHeapIntKey.java    |   14 +-
 .../VMStatsDiskLRURegionEntryHeapLongKey.java   |   14 +-
 .../VMStatsDiskLRURegionEntryHeapObjectKey.java |   14 +-
 ...VMStatsDiskLRURegionEntryHeapStringKey1.java |   14 +-
 ...VMStatsDiskLRURegionEntryHeapStringKey2.java |   14 +-
 .../VMStatsDiskLRURegionEntryHeapUUIDKey.java   |   14 +-
 .../cache/VMStatsDiskLRURegionEntryOffHeap.java |    2 +-
 .../VMStatsDiskLRURegionEntryOffHeapIntKey.java |   22 +-
 ...VMStatsDiskLRURegionEntryOffHeapLongKey.java |   22 +-
 ...StatsDiskLRURegionEntryOffHeapObjectKey.java |   22 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey1.java |   22 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey2.java |   22 +-
 ...VMStatsDiskLRURegionEntryOffHeapUUIDKey.java |   22 +-
 .../internal/cache/VMStatsDiskRegionEntry.java  |    2 +-
 .../cache/VMStatsDiskRegionEntryHeap.java       |    2 +-
 .../cache/VMStatsDiskRegionEntryHeapIntKey.java |   10 +-
 .../VMStatsDiskRegionEntryHeapLongKey.java      |   10 +-
 .../VMStatsDiskRegionEntryHeapObjectKey.java    |   10 +-
 .../VMStatsDiskRegionEntryHeapStringKey1.java   |   10 +-
 .../VMStatsDiskRegionEntryHeapStringKey2.java   |   10 +-
 .../VMStatsDiskRegionEntryHeapUUIDKey.java      |   10 +-
 .../cache/VMStatsDiskRegionEntryOffHeap.java    |    2 +-
 .../VMStatsDiskRegionEntryOffHeapIntKey.java    |   18 +-
 .../VMStatsDiskRegionEntryOffHeapLongKey.java   |   18 +-
 .../VMStatsDiskRegionEntryOffHeapObjectKey.java |   18 +-
 ...VMStatsDiskRegionEntryOffHeapStringKey1.java |   18 +-
 ...VMStatsDiskRegionEntryOffHeapStringKey2.java |   18 +-
 .../VMStatsDiskRegionEntryOffHeapUUIDKey.java   |   18 +-
 .../internal/cache/VMStatsLRURegionEntry.java   |    2 +-
 .../cache/VMStatsLRURegionEntryHeap.java        |    2 +-
 .../cache/VMStatsLRURegionEntryHeapIntKey.java  |   12 +-
 .../cache/VMStatsLRURegionEntryHeapLongKey.java |   12 +-
 .../VMStatsLRURegionEntryHeapObjectKey.java     |   12 +-
 .../VMStatsLRURegionEntryHeapStringKey1.java    |   12 +-
 .../VMStatsLRURegionEntryHeapStringKey2.java    |   12 +-
 .../cache/VMStatsLRURegionEntryHeapUUIDKey.java |   12 +-
 .../cache/VMStatsLRURegionEntryOffHeap.java     |    2 +-
 .../VMStatsLRURegionEntryOffHeapIntKey.java     |   20 +-
 .../VMStatsLRURegionEntryOffHeapLongKey.java    |   20 +-
 .../VMStatsLRURegionEntryOffHeapObjectKey.java  |   20 +-
 .../VMStatsLRURegionEntryOffHeapStringKey1.java |   20 +-
 .../VMStatsLRURegionEntryOffHeapStringKey2.java |   20 +-
 .../VMStatsLRURegionEntryOffHeapUUIDKey.java    |   20 +-
 .../internal/cache/VMStatsRegionEntry.java      |    2 +-
 .../internal/cache/VMStatsRegionEntryHeap.java  |    2 +-
 .../cache/VMStatsRegionEntryHeapIntKey.java     |    6 +-
 .../cache/VMStatsRegionEntryHeapLongKey.java    |    6 +-
 .../cache/VMStatsRegionEntryHeapObjectKey.java  |    6 +-
 .../cache/VMStatsRegionEntryHeapStringKey1.java |    6 +-
 .../cache/VMStatsRegionEntryHeapStringKey2.java |    6 +-
 .../cache/VMStatsRegionEntryHeapUUIDKey.java    |    6 +-
 .../cache/VMStatsRegionEntryOffHeap.java        |    2 +-
 .../cache/VMStatsRegionEntryOffHeapIntKey.java  |   14 +-
 .../cache/VMStatsRegionEntryOffHeapLongKey.java |   14 +-
 .../VMStatsRegionEntryOffHeapObjectKey.java     |   14 +-
 .../VMStatsRegionEntryOffHeapStringKey1.java    |   14 +-
 .../VMStatsRegionEntryOffHeapStringKey2.java    |   14 +-
 .../cache/VMStatsRegionEntryOffHeapUUIDKey.java |   14 +-
 .../cache/VMThinDiskLRURegionEntry.java         |    2 +-
 .../cache/VMThinDiskLRURegionEntryHeap.java     |    2 +-
 .../VMThinDiskLRURegionEntryHeapIntKey.java     |   12 +-
 .../VMThinDiskLRURegionEntryHeapLongKey.java    |   12 +-
 .../VMThinDiskLRURegionEntryHeapObjectKey.java  |   12 +-
 .../VMThinDiskLRURegionEntryHeapStringKey1.java |   12 +-
 .../VMThinDiskLRURegionEntryHeapStringKey2.java |   12 +-
 .../VMThinDiskLRURegionEntryHeapUUIDKey.java    |   12 +-
 .../cache/VMThinDiskLRURegionEntryOffHeap.java  |    2 +-
 .../VMThinDiskLRURegionEntryOffHeapIntKey.java  |   20 +-
 .../VMThinDiskLRURegionEntryOffHeapLongKey.java |   20 +-
 ...MThinDiskLRURegionEntryOffHeapObjectKey.java |   20 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey1.java |   20 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey2.java |   20 +-
 .../VMThinDiskLRURegionEntryOffHeapUUIDKey.java |   20 +-
 .../internal/cache/VMThinDiskRegionEntry.java   |    6 +-
 .../cache/VMThinDiskRegionEntryHeap.java        |    2 +-
 .../cache/VMThinDiskRegionEntryHeapIntKey.java  |    8 +-
 .../cache/VMThinDiskRegionEntryHeapLongKey.java |    8 +-
 .../VMThinDiskRegionEntryHeapObjectKey.java     |    8 +-
 .../VMThinDiskRegionEntryHeapStringKey1.java    |    8 +-
 .../VMThinDiskRegionEntryHeapStringKey2.java    |    8 +-
 .../cache/VMThinDiskRegionEntryHeapUUIDKey.java |    8 +-
 .../cache/VMThinDiskRegionEntryOffHeap.java     |    2 +-
 .../VMThinDiskRegionEntryOffHeapIntKey.java     |   16 +-
 .../VMThinDiskRegionEntryOffHeapLongKey.java    |   16 +-
 .../VMThinDiskRegionEntryOffHeapObjectKey.java  |   16 +-
 .../VMThinDiskRegionEntryOffHeapStringKey1.java |   16 +-
 .../VMThinDiskRegionEntryOffHeapStringKey2.java |   16 +-
 .../VMThinDiskRegionEntryOffHeapUUIDKey.java    |   16 +-
 .../internal/cache/VMThinLRURegionEntry.java    |    2 +-
 .../cache/VMThinLRURegionEntryHeap.java         |    2 +-
 .../cache/VMThinLRURegionEntryHeapIntKey.java   |   10 +-
 .../cache/VMThinLRURegionEntryHeapLongKey.java  |   10 +-
 .../VMThinLRURegionEntryHeapObjectKey.java      |   10 +-
 .../VMThinLRURegionEntryHeapStringKey1.java     |   10 +-
 .../VMThinLRURegionEntryHeapStringKey2.java     |   10 +-
 .../cache/VMThinLRURegionEntryHeapUUIDKey.java  |   10 +-
 .../cache/VMThinLRURegionEntryOffHeap.java      |    2 +-
 .../VMThinLRURegionEntryOffHeapIntKey.java      |   18 +-
 .../VMThinLRURegionEntryOffHeapLongKey.java     |   18 +-
 .../VMThinLRURegionEntryOffHeapObjectKey.java   |   18 +-
 .../VMThinLRURegionEntryOffHeapStringKey1.java  |   18 +-
 .../VMThinLRURegionEntryOffHeapStringKey2.java  |   18 +-
 .../VMThinLRURegionEntryOffHeapUUIDKey.java     |   18 +-
 .../geode/internal/cache/VMThinRegionEntry.java |    2 +-
 .../internal/cache/VMThinRegionEntryHeap.java   |    2 +-
 .../cache/VMThinRegionEntryHeapIntKey.java      |    4 +-
 .../cache/VMThinRegionEntryHeapLongKey.java     |    4 +-
 .../cache/VMThinRegionEntryHeapObjectKey.java   |    4 +-
 .../cache/VMThinRegionEntryHeapStringKey1.java  |    4 +-
 .../cache/VMThinRegionEntryHeapStringKey2.java  |    4 +-
 .../cache/VMThinRegionEntryHeapUUIDKey.java     |    4 +-
 .../cache/VMThinRegionEntryOffHeap.java         |    2 +-
 .../cache/VMThinRegionEntryOffHeapIntKey.java   |   12 +-
 .../cache/VMThinRegionEntryOffHeapLongKey.java  |   12 +-
 .../VMThinRegionEntryOffHeapObjectKey.java      |   12 +-
 .../VMThinRegionEntryOffHeapStringKey1.java     |   12 +-
 .../VMThinRegionEntryOffHeapStringKey2.java     |   12 +-
 .../cache/VMThinRegionEntryOffHeapUUIDKey.java  |   12 +-
 .../internal/cache/ValidatingDiskRegion.java    |   46 +-
 .../geode/internal/cache/ValueByteWrapper.java  |    2 +-
 .../geode/internal/cache/VersionTagHolder.java  |    4 +-
 .../geode/internal/cache/VersionTimestamp.java  |    2 +-
 .../cache/VersionedStatsDiskLRURegionEntry.java |    4 +-
 .../VersionedStatsDiskLRURegionEntryHeap.java   |    2 +-
 ...sionedStatsDiskLRURegionEntryHeapIntKey.java |   24 +-
 ...ionedStatsDiskLRURegionEntryHeapLongKey.java |   24 +-
 ...nedStatsDiskLRURegionEntryHeapObjectKey.java |   24 +-
 ...edStatsDiskLRURegionEntryHeapStringKey1.java |   24 +-
 ...edStatsDiskLRURegionEntryHeapStringKey2.java |   24 +-
 ...ionedStatsDiskLRURegionEntryHeapUUIDKey.java |   24 +-
 ...VersionedStatsDiskLRURegionEntryOffHeap.java |    2 +-
 ...nedStatsDiskLRURegionEntryOffHeapIntKey.java |   32 +-
 ...edStatsDiskLRURegionEntryOffHeapLongKey.java |   32 +-
 ...StatsDiskLRURegionEntryOffHeapObjectKey.java |   32 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey1.java |   32 +-
 ...tatsDiskLRURegionEntryOffHeapStringKey2.java |   32 +-
 ...edStatsDiskLRURegionEntryOffHeapUUIDKey.java |   32 +-
 .../cache/VersionedStatsDiskRegionEntry.java    |    4 +-
 .../VersionedStatsDiskRegionEntryHeap.java      |    2 +-
 ...VersionedStatsDiskRegionEntryHeapIntKey.java |   20 +-
 ...ersionedStatsDiskRegionEntryHeapLongKey.java |   20 +-
 ...sionedStatsDiskRegionEntryHeapObjectKey.java |   20 +-
 ...ionedStatsDiskRegionEntryHeapStringKey1.java |   20 +-
 ...ionedStatsDiskRegionEntryHeapStringKey2.java |   20 +-
 ...ersionedStatsDiskRegionEntryHeapUUIDKey.java |   20 +-
 .../VersionedStatsDiskRegionEntryOffHeap.java   |    2 +-
 ...sionedStatsDiskRegionEntryOffHeapIntKey.java |   28 +-
 ...ionedStatsDiskRegionEntryOffHeapLongKey.java |   28 +-
 ...nedStatsDiskRegionEntryOffHeapObjectKey.java |   28 +-
 ...edStatsDiskRegionEntryOffHeapStringKey1.java |   28 +-
 ...edStatsDiskRegionEntryOffHeapStringKey2.java |   28 +-
 ...ionedStatsDiskRegionEntryOffHeapUUIDKey.java |   28 +-
 .../cache/VersionedStatsLRURegionEntry.java     |    4 +-
 .../cache/VersionedStatsLRURegionEntryHeap.java |    2 +-
 .../VersionedStatsLRURegionEntryHeapIntKey.java |   22 +-
 ...VersionedStatsLRURegionEntryHeapLongKey.java |   22 +-
 ...rsionedStatsLRURegionEntryHeapObjectKey.java |   22 +-
 ...sionedStatsLRURegionEntryHeapStringKey1.java |   22 +-
 ...sionedStatsLRURegionEntryHeapStringKey2.java |   22 +-
 ...VersionedStatsLRURegionEntryHeapUUIDKey.java |   22 +-
 .../VersionedStatsLRURegionEntryOffHeap.java    |    2 +-
 ...rsionedStatsLRURegionEntryOffHeapIntKey.java |   30 +-
 ...sionedStatsLRURegionEntryOffHeapLongKey.java |   30 +-
 ...onedStatsLRURegionEntryOffHeapObjectKey.java |   30 +-
 ...nedStatsLRURegionEntryOffHeapStringKey1.java |   30 +-
 ...nedStatsLRURegionEntryOffHeapStringKey2.java |   30 +-
 ...sionedStatsLRURegionEntryOffHeapUUIDKey.java |   30 +-
 .../cache/VersionedStatsRegionEntry.java        |    4 +-
 .../cache/VersionedStatsRegionEntryHeap.java    |    2 +-
 .../VersionedStatsRegionEntryHeapIntKey.java    |   16 +-
 .../VersionedStatsRegionEntryHeapLongKey.java   |   16 +-
 .../VersionedStatsRegionEntryHeapObjectKey.java |   16 +-
 ...VersionedStatsRegionEntryHeapStringKey1.java |   16 +-
 ...VersionedStatsRegionEntryHeapStringKey2.java |   16 +-
 .../VersionedStatsRegionEntryHeapUUIDKey.java   |   16 +-
 .../cache/VersionedStatsRegionEntryOffHeap.java |    2 +-
 .../VersionedStatsRegionEntryOffHeapIntKey.java |   24 +-
 ...VersionedStatsRegionEntryOffHeapLongKey.java |   24 +-
 ...rsionedStatsRegionEntryOffHeapObjectKey.java |   24 +-
 ...sionedStatsRegionEntryOffHeapStringKey1.java |   24 +-
 ...sionedStatsRegionEntryOffHeapStringKey2.java |   24 +-
 ...VersionedStatsRegionEntryOffHeapUUIDKey.java |   24 +-
 .../cache/VersionedThinDiskLRURegionEntry.java  |    4 +-
 .../VersionedThinDiskLRURegionEntryHeap.java    |    2 +-
 ...rsionedThinDiskLRURegionEntryHeapIntKey.java |   22 +-
 ...sionedThinDiskLRURegionEntryHeapLongKey.java |   22 +-
 ...onedThinDiskLRURegionEntryHeapObjectKey.java |   22 +-
 ...nedThinDiskLRURegionEntryHeapStringKey1.java |   22 +-
 ...nedThinDiskLRURegionEntryHeapStringKey2.java |   22 +-
 ...sionedThinDiskLRURegionEntryHeapUUIDKey.java |   22 +-
 .../VersionedThinDiskLRURegionEntryOffHeap.java |    2 +-
 ...onedThinDiskLRURegionEntryOffHeapIntKey.java |   30 +-
 ...nedThinDiskLRURegionEntryOffHeapLongKey.java |   30 +-
 ...dThinDiskLRURegionEntryOffHeapObjectKey.java |   30 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey1.java |   30 +-
 ...ThinDiskLRURegionEntryOffHeapStringKey2.java |   30 +-
 ...nedThinDiskLRURegionEntryOffHeapUUIDKey.java |   30 +-
 .../cache/VersionedThinDiskRegionEntry.java     |    4 +-
 .../cache/VersionedThinDiskRegionEntryHeap.java |    2 +-
 .../VersionedThinDiskRegionEntryHeapIntKey.java |   18 +-
 ...VersionedThinDiskRegionEntryHeapLongKey.java |   18 +-
 ...rsionedThinDiskRegionEntryHeapObjectKey.java |   18 +-
 ...sionedThinDiskRegionEntryHeapStringKey1.java |   18 +-
 ...sionedThinDiskRegionEntryHeapStringKey2.java |   18 +-
 ...VersionedThinDiskRegionEntryHeapUUIDKey.java |   18 +-
 .../VersionedThinDiskRegionEntryOffHeap.java    |    2 +-
 ...rsionedThinDiskRegionEntryOffHeapIntKey.java |   26 +-
 ...sionedThinDiskRegionEntryOffHeapLongKey.java |   26 +-
 ...onedThinDiskRegionEntryOffHeapObjectKey.java |   26 +-
 ...nedThinDiskRegionEntryOffHeapStringKey1.java |   26 +-
 ...nedThinDiskRegionEntryOffHeapStringKey2.java |   26 +-
 ...sionedThinDiskRegionEntryOffHeapUUIDKey.java |   26 +-
 .../cache/VersionedThinLRURegionEntry.java      |   12 +-
 .../cache/VersionedThinLRURegionEntryHeap.java  |    2 +-
 .../VersionedThinLRURegionEntryHeapIntKey.java  |   20 +-
 .../VersionedThinLRURegionEntryHeapLongKey.java |   20 +-
 ...ersionedThinLRURegionEntryHeapObjectKey.java |   20 +-
 ...rsionedThinLRURegionEntryHeapStringKey1.java |   20 +-
 ...rsionedThinLRURegionEntryHeapStringKey2.java |   20 +-
 .../VersionedThinLRURegionEntryHeapUUIDKey.java |   20 +-
 .../VersionedThinLRURegionEntryOffHeap.java     |    2 +-
 ...ersionedThinLRURegionEntryOffHeapIntKey.java |   28 +-
 ...rsionedThinLRURegionEntryOffHeapLongKey.java |   28 +-
 ...ionedThinLRURegionEntryOffHeapObjectKey.java |   28 +-
 ...onedThinLRURegionEntryOffHeapStringKey1.java |   28 +-
 ...onedThinLRURegionEntryOffHeapStringKey2.java |   28 +-
 ...rsionedThinLRURegionEntryOffHeapUUIDKey.java |   28 +-
 .../cache/VersionedThinRegionEntry.java         |    4 +-
 .../cache/VersionedThinRegionEntryHeap.java     |    2 +-
 .../VersionedThinRegionEntryHeapIntKey.java     |   14 +-
 .../VersionedThinRegionEntryHeapLongKey.java    |   14 +-
 .../VersionedThinRegionEntryHeapObjectKey.java  |   14 +-
 .../VersionedThinRegionEntryHeapStringKey1.java |   14 +-
 .../VersionedThinRegionEntryHeapStringKey2.java |   14 +-
 .../VersionedThinRegionEntryHeapUUIDKey.java    |   14 +-
 .../cache/VersionedThinRegionEntryOffHeap.java  |    2 +-
 .../VersionedThinRegionEntryOffHeapIntKey.java  |   22 +-
 .../VersionedThinRegionEntryOffHeapLongKey.java |   22 +-
 ...ersionedThinRegionEntryOffHeapObjectKey.java |   22 +-
 ...rsionedThinRegionEntryOffHeapStringKey1.java |   22 +-
 ...rsionedThinRegionEntryOffHeapStringKey2.java |   22 +-
 .../VersionedThinRegionEntryOffHeapUUIDKey.java |   22 +-
 .../internal/cache/WrappedCallbackArgument.java |    6 +-
 .../cache/WrappedRegionMembershipListener.java  |   40 +-
 .../CompressedCachedDeserializable.java         |   26 +-
 .../SnappyCompressedCachedDeserializable.java   |   10 +-
 .../internal/cache/control/FilterByPath.java    |    4 +-
 .../cache/control/HeapMemoryMonitor.java        |   42 +-
 .../cache/control/InternalResourceManager.java  |   52 +-
 .../internal/cache/control/MemoryEvent.java     |    8 +-
 .../cache/control/MemoryThresholds.java         |   12 +-
 .../cache/control/OffHeapMemoryMonitor.java     |   24 +-
 .../control/PartitionRebalanceDetailsImpl.java  |    8 +-
 .../cache/control/RebalanceOperationImpl.java   |   28 +-
 .../cache/control/RebalanceResultsImpl.java     |    6 +-
 .../internal/cache/control/RegionFilter.java    |    4 +-
 .../internal/cache/control/ResourceAdvisor.java |   48 +-
 .../internal/cache/control/ResourceEvent.java   |    6 +-
 .../cache/control/ResourceListener.java         |    4 +-
 .../cache/control/ResourceManagerStats.java     |   18 +-
 .../internal/cache/control/ResourceMonitor.java |    4 +-
 .../cache/execute/AbstractExecution.java        |   42 +-
 .../cache/execute/BucketMovedException.java     |    4 +-
 .../cache/execute/DefaultResultCollector.java   |   10 +-
 .../DistributedRegionFunctionExecutor.java      |   34 +-
 .../DistributedRegionFunctionResultSender.java  |   24 +-
 .../DistributedRegionFunctionResultWaiter.java  |   16 +-
 .../cache/execute/FunctionContextImpl.java      |   12 +-
 .../execute/FunctionExecutionNodePruner.java    |   16 +-
 .../cache/execute/FunctionRemoteContext.java    |   10 +-
 .../cache/execute/FunctionServiceStats.java     |   20 +-
 .../internal/cache/execute/FunctionStats.java   |   16 +-
 .../FunctionStreamingResultCollector.java       |   44 +-
 .../cache/execute/InternalExecution.java        |   12 +-
 .../execute/InternalFunctionException.java      |    8 +-
 ...ternalFunctionInvocationTargetException.java |    6 +-
 .../cache/execute/InternalFunctionService.java  |   22 +-
 .../execute/InternalRegionFunctionContext.java  |   14 +-
 .../cache/execute/InternalResultSender.java     |    4 +-
 .../cache/execute/LocalResultCollector.java     |    6 +-
 .../cache/execute/LocalResultCollectorImpl.java |   20 +-
 .../cache/execute/MemberFunctionExecutor.java   |   38 +-
 .../execute/MemberFunctionResultSender.java     |   24 +-
 .../execute/MemberFunctionResultWaiter.java     |   16 +-
 .../cache/execute/MemberMappedArgument.java     |    2 +-
 .../execute/MultiRegionFunctionContext.java     |    8 +-
 .../execute/MultiRegionFunctionContextImpl.java |    6 +-
 .../execute/MultiRegionFunctionExecutor.java    |   46 +-
 .../MultiRegionFunctionResultWaiter.java        |   16 +-
 .../geode/internal/cache/execute/NoResult.java  |   12 +-
 .../PartitionedRegionFunctionExecutor.java      |   36 +-
 .../PartitionedRegionFunctionResultSender.java  |   24 +-
 .../PartitionedRegionFunctionResultWaiter.java  |   22 +-
 .../execute/RegionFunctionContextImpl.java      |   12 +-
 .../cache/execute/ServerFunctionExecutor.java   |   36 +-
 .../execute/ServerRegionFunctionExecutor.java   |   34 +-
 .../ServerToClientFunctionResultSender.java     |   30 +-
 .../ServerToClientFunctionResultSender65.java   |   26 +-
 .../execute/StreamingFunctionOperation.java     |   16 +-
 .../util/FindRestEnabledServersFunction.java    |   18 +-
 .../internal/cache/extension/Extensible.java    |    4 +-
 .../internal/cache/extension/Extension.java     |    8 +-
 .../cache/extension/ExtensionPoint.java         |    2 +-
 .../cache/extension/SimpleExtensionPoint.java   |    6 +-
 .../geode/internal/cache/ha/HAContainerMap.java |   10 +-
 .../internal/cache/ha/HAContainerRegion.java    |   18 +-
 .../internal/cache/ha/HAContainerWrapper.java   |    6 +-
 .../geode/internal/cache/ha/HARegionQueue.java  |   62 +-
 .../cache/ha/HARegionQueueAttributes.java       |    4 +-
 .../internal/cache/ha/HARegionQueueStats.java   |   16 +-
 .../internal/cache/ha/QueueRemovalMessage.java  |   28 +-
 .../internal/cache/ha/ThreadIdentifier.java     |   10 +-
 .../cache/locks/TXLessorDepartureHandler.java   |   16 +-
 .../geode/internal/cache/locks/TXLockBatch.java |   22 +-
 .../geode/internal/cache/locks/TXLockId.java    |    8 +-
 .../internal/cache/locks/TXLockIdImpl.java      |   12 +-
 .../internal/cache/locks/TXLockService.java     |    6 +-
 .../internal/cache/locks/TXLockServiceImpl.java |   22 +-
 .../geode/internal/cache/locks/TXLockToken.java |    8 +-
 .../locks/TXLockUpdateParticipantsMessage.java  |   30 +-
 .../locks/TXOriginatorRecoveryProcessor.java    |   32 +-
 .../locks/TXRecoverGrantorMessageProcessor.java |   24 +-
 .../cache/locks/TXRegionLockRequest.java        |    6 +-
 .../geode/internal/cache/lru/EnableLRU.java     |   12 +-
 .../geode/internal/cache/lru/HeapEvictor.java   |   28 +-
 .../cache/lru/HeapLRUCapacityController.java    |   30 +-
 .../internal/cache/lru/HeapLRUStatistics.java   |   12 +-
 .../geode/internal/cache/lru/LRUAlgorithm.java  |   26 +-
 .../cache/lru/LRUCapacityController.java        |   16 +-
 .../geode/internal/cache/lru/LRUClockNode.java  |    2 +-
 .../geode/internal/cache/lru/LRUEntry.java      |    6 +-
 .../internal/cache/lru/LRUMapCallbacks.java     |    8 +-
 .../geode/internal/cache/lru/LRUStatistics.java |   10 +-
 .../cache/lru/MemLRUCapacityController.java     |   56 +-
 .../internal/cache/lru/NewLIFOClockHand.java    |    8 +-
 .../internal/cache/lru/NewLRUClockHand.java     |   22 +-
 .../internal/cache/lru/OffHeapEvictor.java      |   18 +-
 .../geode/internal/cache/lru/Sizeable.java      |    2 +-
 .../operations/ContainsKeyOperationContext.java |    6 +-
 .../apache/geode/internal/cache/package.html    |    6 +-
 .../AllBucketProfilesUpdateMessage.java         |   28 +-
 .../partitioned/BecomePrimaryBucketMessage.java |   34 +-
 .../internal/cache/partitioned/Bucket.java      |   14 +-
 .../cache/partitioned/BucketBackupMessage.java  |   22 +-
 .../cache/partitioned/BucketCountLoadProbe.java |   12 +-
 .../partitioned/BucketProfileUpdateMessage.java |   30 +-
 .../cache/partitioned/BucketSizeMessage.java    |   42 +-
 .../partitioned/ContainsKeyValueMessage.java    |   54 +-
 .../cache/partitioned/CreateBucketMessage.java  |   44 +-
 .../partitioned/CreateMissingBucketsTask.java   |   12 +-
 .../partitioned/DeposePrimaryBucketMessage.java |   34 +-
 .../cache/partitioned/DestroyMessage.java       |   80 +-
 .../DestroyRegionOnDataStoreMessage.java        |   30 +-
 .../partitioned/DumpAllPRConfigMessage.java     |   18 +-
 .../cache/partitioned/DumpB2NRegion.java        |   48 +-
 .../cache/partitioned/DumpBucketsMessage.java   |   18 +-
 .../partitioned/EndBucketCreationMessage.java   |   18 +-
 .../partitioned/FetchBulkEntriesMessage.java    |   60 +-
 .../cache/partitioned/FetchEntriesMessage.java  |   74 +-
 .../cache/partitioned/FetchEntryMessage.java    |   64 +-
 .../cache/partitioned/FetchKeysMessage.java     |   52 +-
 .../FetchPartitionDetailsMessage.java           |   38 +-
 .../cache/partitioned/FlushMessage.java         |   24 +-
 .../internal/cache/partitioned/GetMessage.java  |   80 +-
 .../partitioned/IdentityRequestMessage.java     |   32 +-
 .../partitioned/IdentityUpdateMessage.java      |   24 +-
 .../cache/partitioned/IndexCreationMsg.java     |   56 +-
 .../cache/partitioned/InterestEventMessage.java |   36 +-
 .../cache/partitioned/InternalPRInfo.java       |    6 +-
 .../partitioned/InternalPartitionDetails.java   |    6 +-
 .../cache/partitioned/InvalidateMessage.java    |   68 +-
 .../internal/cache/partitioned/LoadProbe.java   |    6 +-
 .../internal/cache/partitioned/LockObject.java  |    2 +-
 .../partitioned/ManageBackupBucketMessage.java  |   44 +-
 .../cache/partitioned/ManageBucketMessage.java  |   44 +-
 .../cache/partitioned/MoveBucketMessage.java    |   36 +-
 .../cache/partitioned/OfflineMemberDetails.java |    6 +-
 .../partitioned/OfflineMemberDetailsImpl.java   |    8 +-
 .../cache/partitioned/PREntriesIterator.java    |    4 +-
 .../PRFunctionStreamingResultCollector.java     |   52 +-
 .../internal/cache/partitioned/PRLoad.java      |    6 +-
 .../PRLocallyDestroyedException.java            |    4 +-
 .../cache/partitioned/PRSanityCheckMessage.java |   28 +-
 .../cache/partitioned/PRTombstoneMessage.java   |   46 +-
 .../PRUpdateEntryVersionMessage.java            |   58 +-
 .../partitioned/PartitionMemberInfoImpl.java    |    4 +-
 .../cache/partitioned/PartitionMessage.java     |   96 +-
 .../PartitionMessageWithDirectReply.java        |   18 +-
 .../partitioned/PartitionRegionInfoImpl.java    |    4 +-
 ...rtitionedRegionFunctionStreamingMessage.java |   36 +-
 .../partitioned/PartitionedRegionObserver.java  |    4 +-
 .../PartitionedRegionObserverAdapter.java       |    6 +-
 .../PartitionedRegionObserverHolder.java        |    4 +-
 .../PartitionedRegionRebalanceOp.java           |   52 +-
 .../partitioned/PrimaryRequestMessage.java      |   34 +-
 .../cache/partitioned/PutAllPRMessage.java      |   94 +-
 .../internal/cache/partitioned/PutMessage.java  |  100 +-
 .../cache/partitioned/QueryMessage.java         |   56 +-
 .../cache/partitioned/RecoveryRunnable.java     |   14 +-
 .../RedundancyAlreadyMetException.java          |    4 +-
 .../cache/partitioned/RedundancyLogger.java     |   30 +-
 .../cache/partitioned/RegionAdvisor.java        |   56 +-
 .../partitioned/RemoteFetchKeysMessage.java     |   62 +-
 .../cache/partitioned/RemoteSizeMessage.java    |   38 +-
 .../cache/partitioned/RemoveAllPRMessage.java   |   96 +-
 .../cache/partitioned/RemoveBucketMessage.java  |   36 +-
 .../cache/partitioned/RemoveIndexesMessage.java |   42 +-
 .../internal/cache/partitioned/SizeMessage.java |   44 +-
 .../cache/partitioned/SizedBasedLoadProbe.java  |   14 +-
 .../StreamingPartitionOperation.java            |   54 +-
 .../partitioned/rebalance/BucketOperator.java   |    4 +-
 .../rebalance/BucketOperatorImpl.java           |    8 +-
 .../rebalance/BucketOperatorWrapper.java        |   12 +-
 .../rebalance/CompositeDirector.java            |    2 +-
 .../rebalance/ExplicitMoveDirector.java         |   20 +-
 .../partitioned/rebalance/FPRDirector.java      |    2 +-
 .../partitioned/rebalance/MoveBuckets.java      |    4 +-
 .../partitioned/rebalance/MovePrimaries.java    |    4 +-
 .../partitioned/rebalance/MovePrimariesFPR.java |   18 +-
 .../rebalance/ParallelBucketOperator.java       |    8 +-
 .../rebalance/PartitionedRegionLoadModel.java   |   30 +-
 .../rebalance/PercentageMoveDirector.java       |   14 +-
 .../rebalance/RebalanceDirector.java            |    2 +-
 .../rebalance/RebalanceDirectorAdapter.java     |    2 +-
 .../rebalance/RemoveOverRedundancy.java         |   10 +-
 .../rebalance/SatisfyRedundancy.java            |    8 +-
 .../rebalance/SatisfyRedundancyFPR.java         |   10 +-
 .../rebalance/SimulatedBucketOperator.java      |    4 +-
 .../cache/persistence/BackupInspector.java      |    2 +-
 .../cache/persistence/BackupManager.java        |   28 +-
 .../cache/persistence/BytesAndBits.java         |    4 +-
 .../cache/persistence/CanonicalIdHolder.java    |    4 +-
 .../CreatePersistentRegionProcessor.java        |   10 +-
 .../cache/persistence/DiskExceptionHandler.java |    8 +-
 .../persistence/DiskInitFileInterpreter.java    |    8 +-
 .../cache/persistence/DiskInitFileParser.java   |   32 +-
 .../cache/persistence/DiskRecoveryStore.java    |   26 +-
 .../cache/persistence/DiskRegionView.java       |   20 +-
 .../cache/persistence/DiskStoreFilter.java      |    4 +-
 .../internal/cache/persistence/DiskStoreID.java |    8 +-
 .../persistence/MembershipFlushRequest.java     |   38 +-
 .../persistence/MembershipViewRequest.java      |   50 +-
 .../internal/cache/persistence/OplogType.java   |    2 +-
 .../cache/persistence/PRPersistentConfig.java   |    2 +-
 .../cache/persistence/PersistenceAdvisor.java   |   12 +-
 .../persistence/PersistenceAdvisorImpl.java     |   42 +-
 .../persistence/PersistenceObserverHolder.java  |    4 +-
 .../cache/persistence/PersistentMemberID.java   |    8 +-
 .../persistence/PersistentMemberManager.java    |   18 +-
 .../persistence/PersistentMemberPattern.java    |    8 +-
 .../persistence/PersistentMemberState.java      |    2 +-
 .../cache/persistence/PersistentMemberView.java |    4 +-
 .../persistence/PersistentMembershipView.java   |   10 +-
 .../persistence/PersistentStateListener.java    |    4 +-
 .../PersistentStateQueryMessage.java            |   46 +-
 .../PersistentStateQueryResults.java            |    4 +-
 .../PrepareNewPersistentMemberMessage.java      |   46 +-
 .../RemovePersistentMemberMessage.java          |   46 +-
 .../cache/persistence/RestoreScript.java        |    4 +-
 .../persistence/UninterruptibleFileChannel.java |    2 +-
 .../UninterruptibleRandomAccessFile.java        |    2 +-
 .../persistence/query/CloseableIterator.java    |    2 +-
 .../persistence/query/IdentityExtractor.java    |    2 +-
 .../cache/persistence/query/IndexMap.java       |    4 +-
 .../cache/persistence/query/ResultBag.java      |    4 +-
 .../cache/persistence/query/ResultList.java     |    4 +-
 .../cache/persistence/query/ResultMap.java      |    4 +-
 .../cache/persistence/query/ResultSet.java      |    4 +-
 .../persistence/query/SortKeyExtractor.java     |    2 +-
 .../query/TemporaryResultSetFactory.java        |    8 +-
 .../persistence/query/mock/ByteComparator.java  |    6 +-
 .../mock/CachedDeserializableComparator.java    |    4 +-
 .../persistence/query/mock/IndexMapImpl.java    |   14 +-
 .../persistence/query/mock/ItrAdapter.java      |    6 +-
 .../query/mock/NaturalComparator.java           |    2 +-
 .../cache/persistence/query/mock/Pair.java      |    2 +-
 .../persistence/query/mock/PairComparator.java  |    2 +-
 .../persistence/query/mock/ResultListImpl.java  |    8 +-
 .../query/mock/ReverseComparator.java           |    2 +-
 .../query/mock/SortedResultBagImpl.java         |   12 +-
 .../query/mock/SortedResultMapImpl.java         |   10 +-
 .../query/mock/SortedResultSetImpl.java         |   12 +-
 .../apache/geode/internal/cache/properties.html |  472 ++--
 .../region/entry/RegionEntryFactoryBuilder.java |    4 +-
 .../snapshot/CacheSnapshotServiceImpl.java      |   20 +-
 .../internal/cache/snapshot/ClientExporter.java |   36 +-
 .../cache/snapshot/ExportedRegistry.java        |   10 +-
 .../internal/cache/snapshot/FlowController.java |   26 +-
 .../internal/cache/snapshot/GFSnapshot.java     |   26 +-
 .../internal/cache/snapshot/LocalExporter.java  |   16 +-
 .../snapshot/RegionSnapshotServiceImpl.java     |   46 +-
 .../cache/snapshot/SnapshotFileMapper.java      |   20 +-
 .../cache/snapshot/SnapshotOptionsImpl.java     |    6 +-
 .../internal/cache/snapshot/SnapshotPacket.java |   30 +-
 .../cache/snapshot/WindowedExporter.java        |   36 +-
 .../geode/internal/cache/tier/Acceptor.java     |    4 +-
 .../internal/cache/tier/BatchException.java     |    4 +-
 .../internal/cache/tier/CachedRegionHelper.java |   12 +-
 .../internal/cache/tier/ClientHandShake.java    |    6 +-
 .../geode/internal/cache/tier/Command.java      |    4 +-
 .../internal/cache/tier/ConnectionProxy.java    |    4 +-
 .../geode/internal/cache/tier/InterestType.java |    2 +-
 .../cache/tier/InternalClientMembership.java    |   44 +-
 .../geode/internal/cache/tier/MessageType.java  |    2 +-
 .../cache/tier/sockets/AcceptorImpl.java        |   72 +-
 .../cache/tier/sockets/BaseCommand.java         |   56 +-
 .../cache/tier/sockets/BaseCommandQuery.java    |   46 +-
 .../cache/tier/sockets/CacheClientNotifier.java |  164 +-
 .../tier/sockets/CacheClientNotifierStats.java  |   18 +-
 .../cache/tier/sockets/CacheClientProxy.java    |  144 +-
 .../tier/sockets/CacheClientProxyStats.java     |   18 +-
 .../cache/tier/sockets/CacheClientUpdater.java  |   72 +-
 .../cache/tier/sockets/CacheServerHelper.java   |   16 +-
 .../cache/tier/sockets/CacheServerStats.java    |   20 +-
 .../cache/tier/sockets/ChunkedMessage.java      |   12 +-
 .../tier/sockets/ClientBlacklistProcessor.java  |   26 +-
 .../sockets/ClientDataSerializerMessage.java    |   14 +-
 .../cache/tier/sockets/ClientHealthMonitor.java |   32 +-
 .../tier/sockets/ClientInstantiatorMessage.java |   14 +-
 .../tier/sockets/ClientInterestMessageImpl.java |   16 +-
 .../tier/sockets/ClientMarkerMessageImpl.java   |   10 +-
 .../cache/tier/sockets/ClientMessage.java       |    8 +-
 .../tier/sockets/ClientPingMessageImpl.java     |    8 +-
 .../tier/sockets/ClientProxyMembershipID.java   |   28 +-
 .../tier/sockets/ClientTombstoneMessage.java    |   18 +-
 .../cache/tier/sockets/ClientUpdateMessage.java |    8 +-
 .../tier/sockets/ClientUpdateMessageImpl.java   |   58 +-
 .../cache/tier/sockets/ClientUserAuths.java     |    8 +-
 .../cache/tier/sockets/CommandInitializer.java  |  164 +-
 .../cache/tier/sockets/ConnectionListener.java  |    2 +-
 .../tier/sockets/ConnectionListenerAdapter.java |    2 +-
 .../cache/tier/sockets/HAEventWrapper.java      |   42 +-
 .../internal/cache/tier/sockets/HandShake.java  |   76 +-
 .../tier/sockets/InterestResultPolicyImpl.java  |    8 +-
 .../internal/cache/tier/sockets/Message.java    |   32 +-
 .../cache/tier/sockets/MessageStats.java        |    2 +-
 .../tier/sockets/MessageTooLargeException.java  |    2 +-
 .../cache/tier/sockets/ObjectPartList.java      |   18 +-
 .../cache/tier/sockets/ObjectPartList651.java   |    6 +-
 .../geode/internal/cache/tier/sockets/Part.java |   14 +-
 .../RemoveClientFromBlacklistMessage.java       |   18 +-
 .../tier/sockets/SerializedObjectPartList.java  |    6 +-
 .../cache/tier/sockets/ServerConnection.java    |   68 +-
 .../tier/sockets/ServerHandShakeProcessor.java  |   42 +-
 .../cache/tier/sockets/ServerQueueStatus.java   |    4 +-
 .../tier/sockets/ServerResponseMatrix.java      |   10 +-
 .../tier/sockets/UnregisterAllInterest.java     |    2 +-
 .../cache/tier/sockets/UserAuthAttributes.java  |    6 +-
 .../cache/tier/sockets/VersionedObjectList.java |   30 +-
 .../cache/tier/sockets/command/AddPdxEnum.java  |   18 +-
 .../cache/tier/sockets/command/AddPdxType.java  |   20 +-
 .../cache/tier/sockets/command/ClearRegion.java |   32 +-
 .../cache/tier/sockets/command/ClientReady.java |    8 +-
 .../tier/sockets/command/CloseConnection.java   |   18 +-
 .../tier/sockets/command/CommitCommand.java     |   30 +-
 .../cache/tier/sockets/command/ContainsKey.java |   32 +-
 .../tier/sockets/command/ContainsKey66.java     |   32 +-
 .../tier/sockets/command/CreateRegion.java      |   26 +-
 .../cache/tier/sockets/command/Default.java     |   12 +-
 .../cache/tier/sockets/command/Destroy.java     |   44 +-
 .../cache/tier/sockets/command/Destroy65.java   |   56 +-
 .../cache/tier/sockets/command/Destroy70.java   |   16 +-
 .../tier/sockets/command/DestroyRegion.java     |   36 +-
 .../tier/sockets/command/ExecuteFunction.java   |   62 +-
 .../tier/sockets/command/ExecuteFunction65.java |   64 +-
 .../tier/sockets/command/ExecuteFunction66.java |   76 +-
 .../tier/sockets/command/ExecuteFunction70.java |   32 +-
 .../sockets/command/ExecuteRegionFunction.java  |   52 +-
 .../command/ExecuteRegionFunction61.java        |   54 +-
 .../command/ExecuteRegionFunction65.java        |   56 +-
 .../command/ExecuteRegionFunction66.java        |   64 +-
 .../command/ExecuteRegionFunctionSingleHop.java |   56 +-
 .../sockets/command/GatewayReceiverCommand.java |   70 +-
 .../cache/tier/sockets/command/Get70.java       |   58 +-
 .../cache/tier/sockets/command/GetAll.java      |   34 +-
 .../cache/tier/sockets/command/GetAll651.java   |   36 +-
 .../cache/tier/sockets/command/GetAll70.java    |   50 +-
 .../cache/tier/sockets/command/GetAllForRI.java |    8 +-
 .../sockets/command/GetAllWithCallback.java     |   48 +-
 .../command/GetClientPRMetadataCommand.java     |   26 +-
 .../command/GetClientPRMetadataCommand66.java   |   24 +-
 .../GetClientPartitionAttributesCommand.java    |   26 +-
 .../GetClientPartitionAttributesCommand66.java  |   30 +-
 .../cache/tier/sockets/command/GetEntry70.java  |   18 +-
 .../tier/sockets/command/GetEntryCommand.java   |   16 +-
 .../sockets/command/GetFunctionAttribute.java   |   18 +-
 .../tier/sockets/command/GetPDXEnumById.java    |   18 +-
 .../tier/sockets/command/GetPDXIdForEnum.java   |   18 +-
 .../tier/sockets/command/GetPDXIdForType.java   |   18 +-
 .../tier/sockets/command/GetPDXTypeById.java    |   18 +-
 .../tier/sockets/command/GetPdxEnums70.java     |   16 +-
 .../tier/sockets/command/GetPdxTypes70.java     |   16 +-
 .../cache/tier/sockets/command/Invalid.java     |   12 +-
 .../cache/tier/sockets/command/Invalidate.java  |   44 +-
 .../tier/sockets/command/Invalidate70.java      |   18 +-
 .../cache/tier/sockets/command/KeySet.java      |   34 +-
 .../cache/tier/sockets/command/MakePrimary.java |    6 +-
 .../tier/sockets/command/ManagementCommand.java |    8 +-
 .../cache/tier/sockets/command/PeriodicAck.java |    8 +-
 .../cache/tier/sockets/command/Ping.java        |   18 +-
 .../cache/tier/sockets/command/Put.java         |   44 +-
 .../cache/tier/sockets/command/Put61.java       |   46 +-
 .../cache/tier/sockets/command/Put65.java       |   64 +-
 .../cache/tier/sockets/command/Put70.java       |   18 +-
 .../cache/tier/sockets/command/PutAll.java      |   48 +-
 .../cache/tier/sockets/command/PutAll70.java    |   56 +-
 .../cache/tier/sockets/command/PutAll80.java    |   60 +-
 .../sockets/command/PutAllWithCallback.java     |    8 +-
 .../sockets/command/PutUserCredentials.java     |   14 +-
 .../cache/tier/sockets/command/Query.java       |   26 +-
 .../cache/tier/sockets/command/Query651.java    |   22 +-
 .../command/RegisterDataSerializers.java        |   20 +-
 .../sockets/command/RegisterInstantiators.java  |   34 +-
 .../tier/sockets/command/RegisterInterest.java  |   36 +-
 .../sockets/command/RegisterInterest61.java     |   44 +-
 .../sockets/command/RegisterInterestList.java   |   30 +-
 .../sockets/command/RegisterInterestList61.java |   28 +-
 .../sockets/command/RegisterInterestList66.java |   30 +-
 .../cache/tier/sockets/command/RemoveAll.java   |   54 +-
 .../tier/sockets/command/RemoveUserAuth.java    |   16 +-
 .../cache/tier/sockets/command/Request.java     |   44 +-
 .../tier/sockets/command/RequestEventValue.java |   38 +-
 .../tier/sockets/command/RollbackCommand.java   |   18 +-
 .../cache/tier/sockets/command/Size.java        |   30 +-
 .../tier/sockets/command/TXFailoverCommand.java |   26 +-
 .../command/TXSynchronizationCommand.java       |   38 +-
 .../sockets/command/UnregisterInterest.java     |   28 +-
 .../sockets/command/UnregisterInterestList.java |   26 +-
 .../command/UpdateClientNotification.java       |    8 +-
 .../internal/cache/tier/sockets/package.html    |    2 +-
 .../cache/tx/AbstractPeerTXRegionStub.java      |   20 +-
 .../internal/cache/tx/ClientTXRegionStub.java   |   32 +-
 .../internal/cache/tx/ClientTXStateStub.java    |   36 +-
 .../cache/tx/DistClientTXStateStub.java         |   22 +-
 .../internal/cache/tx/DistTxEntryEvent.java     |   36 +-
 .../geode/internal/cache/tx/DistTxKeyInfo.java  |    4 +-
 .../cache/tx/DistributedTXRegionStub.java       |   68 +-
 .../cache/tx/PartitionedTXRegionStub.java       |   64 +-
 .../geode/internal/cache/tx/TXRegionStub.java   |   20 +-
 .../cache/tx/TransactionalOperation.java        |    2 +-
 .../cache/versions/CompactVersionHolder.java    |    2 +-
 .../ConcurrentCacheModificationException.java   |    2 +-
 .../cache/versions/DiskRegionVersionVector.java |    6 +-
 .../internal/cache/versions/DiskVersionTag.java |   10 +-
 .../internal/cache/versions/RVVException.java   |    8 +-
 .../internal/cache/versions/RVVExceptionB.java  |    4 +-
 .../internal/cache/versions/RVVExceptionT.java  |    6 +-
 .../cache/versions/RegionVersionHolder.java     |   16 +-
 .../cache/versions/RegionVersionVector.java     |   42 +-
 .../cache/versions/VMRegionVersionVector.java   |    8 +-
 .../internal/cache/versions/VMVersionTag.java   |    8 +-
 .../internal/cache/versions/VersionHolder.java  |    2 +-
 .../internal/cache/versions/VersionSource.java  |    4 +-
 .../internal/cache/versions/VersionStamp.java   |   10 +-
 .../internal/cache/versions/VersionTag.java     |   18 +-
 .../internal/cache/vmotion/VMotionObserver.java |    4 +-
 .../cache/vmotion/VMotionObserverAdapter.java   |    4 +-
 .../cache/vmotion/VMotionObserverHolder.java    |    4 +-
 .../cache/wan/AbstractGatewaySender.java        |  108 +-
 .../AbstractGatewaySenderEventProcessor.java    |   38 +-
 .../AsyncEventQueueConfigurationException.java  |    4 +-
 .../internal/cache/wan/BatchException70.java    |    4 +-
 .../cache/wan/DistributedSystemListener.java    |    2 +-
 .../cache/wan/GatewayEventFilterImpl.java       |    8 +-
 .../cache/wan/GatewayReceiverException.java     |    4 +-
 .../cache/wan/GatewayReceiverStats.java         |   12 +-
 .../cache/wan/GatewaySenderAdvisor.java         |   62 +-
 .../cache/wan/GatewaySenderAttributes.java      |   16 +-
 .../GatewaySenderConfigurationException.java    |    2 +-
 .../wan/GatewaySenderEventCallbackArgument.java |   14 +-
 .../GatewaySenderEventCallbackDispatcher.java   |   14 +-
 .../cache/wan/GatewaySenderEventDispatcher.java |    2 +-
 .../cache/wan/GatewaySenderEventImpl.java       |   76 +-
 .../cache/wan/GatewaySenderException.java       |    4 +-
 .../internal/cache/wan/GatewaySenderStats.java  |   20 +-
 .../cache/wan/InternalGatewaySenderFactory.java |   10 +-
 .../cache/wan/TransportFilterServerSocket.java  |    4 +-
 .../cache/wan/TransportFilterSocket.java        |    4 +-
 .../cache/wan/TransportFilterSocketFactory.java |    6 +-
 .../internal/cache/wan/WANServiceProvider.java  |   14 +-
 .../BucketRegionQueueUnavailableException.java  |    4 +-
 ...rentParallelGatewaySenderEventProcessor.java |   42 +-
 .../ConcurrentParallelGatewaySenderQueue.java   |   30 +-
 .../ParallelGatewaySenderEventProcessor.java    |   42 +-
 .../parallel/ParallelGatewaySenderQueue.java    |  106 +-
 .../ParallelQueueBatchRemovalMessage.java       |   50 +-
 .../parallel/ParallelQueueRemovalMessage.java   |   42 +-
 .../cache/wan/parallel/RREventIDResolver.java   |    8 +-
 .../cache/wan/serial/BatchDestroyOperation.java |   44 +-
 ...urrentSerialGatewaySenderEventProcessor.java |   44 +-
 .../SerialGatewaySenderEventProcessor.java      |   60 +-
 .../wan/serial/SerialGatewaySenderQueue.java    |   82 +-
 .../serial/SerialSecondaryGatewayListener.java  |   14 +-
 .../internal/cache/wan/spi/WANFactory.java      |   12 +-
 .../cache/xmlcache/AbstractXmlParser.java       |    4 +-
 .../cache/xmlcache/AsyncEventQueueCreation.java |   14 +-
 .../cache/xmlcache/BindingCreation.java         |    2 +-
 .../internal/cache/xmlcache/CacheCreation.java  |  174 +-
 .../cache/xmlcache/CacheServerCreation.java     |   20 +-
 .../CacheTransactionManagerCreation.java        |   14 +-
 .../geode/internal/cache/xmlcache/CacheXml.java |   40 +-
 .../cache/xmlcache/CacheXmlGenerator.java       |  138 +-
 .../internal/cache/xmlcache/CacheXmlParser.java |  156 +-
 .../xmlcache/CacheXmlPropertyResolver.java      |    8 +-
 .../CacheXmlPropertyResolverHelper.java         |    8 +-
 .../cache/xmlcache/CacheXmlVersion.java         |    2 +-
 .../cache/xmlcache/ClientCacheCreation.java     |   62 +-
 .../cache/xmlcache/ClientHaQueueCreation.java   |    4 +-
 .../internal/cache/xmlcache/Declarable2.java    |    4 +-
 .../cache/xmlcache/DefaultEntityResolver2.java  |    4 +-
 .../xmlcache/DiskStoreAttributesCreation.java   |   14 +-
 .../cache/xmlcache/FunctionServiceCreation.java |    6 +-
 .../cache/xmlcache/GatewayReceiverCreation.java |   22 +-
 .../cache/xmlcache/GeodeEntityResolver.java     |    2 +-
 .../cache/xmlcache/IndexCreationData.java       |   10 +-
 .../ParallelAsyncEventQueueCreation.java        |   28 +-
 .../xmlcache/ParallelGatewaySenderCreation.java |   28 +-
 .../cache/xmlcache/PivotalEntityResolver.java   |    2 +-
 .../cache/xmlcache/PropertyResolver.java        |    2 +-
 .../xmlcache/RegionAttributesCreation.java      |   54 +-
 .../internal/cache/xmlcache/RegionCreation.java |   50 +-
 .../cache/xmlcache/ResourceManagerCreation.java |   30 +-
 .../xmlcache/SerialAsyncEventQueueCreation.java |   26 +-
 .../xmlcache/SerialGatewaySenderCreation.java   |   26 +-
 .../cache/xmlcache/SerializerCreation.java      |   16 +-
 .../internal/cache/xmlcache/XmlGenerator.java   |    2 +-
 .../cache/xmlcache/XmlGeneratorUtils.java       |    2 +-
 .../internal/cache/xmlcache/XmlParser.java      |    8 +-
 .../geode/internal/cache/xmlcache/package.html  |    6 +-
 .../apache/geode/internal/concurrent/AL.java    |    2 +-
 .../geode/internal/concurrent/AtomicLong5.java  |    2 +-
 .../geode/internal/concurrent/Atomics.java      |   16 +-
 .../concurrent/CompactConcurrentHashSet2.java   |    2 +-
 .../internal/concurrent/ConcurrentHashSet.java  |    2 +-
 .../apache/geode/internal/concurrent/LI.java    |    2 +-
 .../geode/internal/concurrent/MapCallback.java  |    2 +-
 .../internal/concurrent/MapCallbackAdapter.java |    2 +-
 .../geode/internal/concurrent/MapResult.java    |    2 +-
 .../internal/datasource/AbstractDataSource.java |    6 +-
 .../internal/datasource/AbstractPoolCache.java  |   14 +-
 .../ClientConnectionFactoryWrapper.java         |    2 +-
 .../internal/datasource/ConfigProperty.java     |    2 +-
 .../ConfiguredDataSourceProperties.java         |    2 +-
 .../ConnectionEventListenerAdaptor.java         |    2 +-
 .../datasource/ConnectionPoolCache.java         |    2 +-
 .../datasource/ConnectionPoolCacheImpl.java     |   10 +-
 .../internal/datasource/ConnectionProvider.java |    2 +-
 .../datasource/ConnectionProviderException.java |    4 +-
 .../datasource/DataSourceCreateException.java   |    4 +-
 .../internal/datasource/DataSourceFactory.java  |   14 +-
 .../datasource/DataSourceResources.java         |    2 +-
 .../FacetsJCAConnectionManagerImpl.java         |   12 +-
 .../datasource/GemFireBasicDataSource.java      |   16 +-
 .../datasource/GemFireConnPooledDataSource.java |   10 +-
 .../GemFireConnectionPoolManager.java           |    2 +-
 .../GemFireTransactionDataSource.java           |   12 +-
 .../datasource/JCAConnectionManagerImpl.java    |   12 +-
 .../datasource/ManagedPoolCacheImpl.java        |    6 +-
 .../internal/datasource/PoolException.java      |    4 +-
 .../internal/datasource/TranxPoolCacheImpl.java |    6 +-
 .../org/apache/geode/internal/hll/Bits.java     |    2 +-
 .../internal/hll/CardinalityMergeException.java |    2 +-
 .../apache/geode/internal/hll/HyperLogLog.java  |    2 +-
 .../geode/internal/hll/HyperLogLogPlus.java     |    2 +-
 .../org/apache/geode/internal/hll/IBuilder.java |    2 +-
 .../apache/geode/internal/hll/ICardinality.java |    2 +-
 .../apache/geode/internal/hll/MurmurHash.java   |    2 +-
 .../apache/geode/internal/hll/RegisterSet.java  |    2 +-
 .../i18n/AbstractStringIdResourceBundle.java    |    8 +-
 .../geode/internal/i18n/LocalizedStrings.java   |   10 +-
 .../apache/geode/internal/i18n/StringId.java    |    2 +-
 .../internal/io/CompositeOutputStream.java      |    2 +-
 .../geode/internal/io/CompositePrintStream.java |    2 +-
 .../geode/internal/io/TeeOutputStream.java      |    2 +-
 .../geode/internal/io/TeePrintStream.java       |    2 +-
 .../apache/geode/internal/jndi/ContextImpl.java |   10 +-
 .../jndi/InitialContextFactoryImpl.java         |    6 +-
 .../apache/geode/internal/jndi/JNDIInvoker.java |   28 +-
 .../geode/internal/jndi/NameParserImpl.java     |    2 +-
 .../geode/internal/jta/GlobalTransaction.java   |   14 +-
 .../geode/internal/jta/TransactionImpl.java     |    6 +-
 .../internal/jta/TransactionManagerImpl.java    |   10 +-
 .../geode/internal/jta/TransactionUtils.java    |    8 +-
 .../geode/internal/jta/UserTransactionImpl.java |    8 +-
 .../org/apache/geode/internal/jta/XidImpl.java  |    2 +-
 .../apache/geode/internal/lang/ClassUtils.java  |    2 +-
 .../org/apache/geode/internal/lang/Filter.java  |    2 +-
 .../geode/internal/lang/InOutParameter.java     |    2 +-
 .../apache/geode/internal/lang/Initable.java    |    2 +-
 .../apache/geode/internal/lang/Initializer.java |    6 +-
 .../internal/lang/MutableIdentifiable.java      |    4 +-
 .../apache/geode/internal/lang/ObjectUtils.java |    2 +-
 .../apache/geode/internal/lang/Orderable.java   |    2 +-
 .../org/apache/geode/internal/lang/Ordered.java |    2 +-
 .../apache/geode/internal/lang/StringUtils.java |    6 +-
 .../apache/geode/internal/lang/SystemUtils.java |    2 +-
 .../apache/geode/internal/lang/ThreadUtils.java |    2 +-
 .../geode/internal/lang/ThrowableUtils.java     |    2 +-
 .../geode/internal/logging/DateFormatter.java   |    2 +-
 .../geode/internal/logging/DebugLogWriter.java  |    6 +-
 .../internal/logging/GemFireFormatter.java      |    6 +-
 .../geode/internal/logging/GemFireHandler.java  |    8 +-
 .../geode/internal/logging/GemFireLevel.java    |    6 +-
 .../internal/logging/InternalLogWriter.java     |    8 +-
 .../geode/internal/logging/LocalLogWriter.java  |    4 +-
 .../geode/internal/logging/LogConfig.java       |    6 +-
 .../geode/internal/logging/LogFileParser.java   |    6 +-
 .../geode/internal/logging/LogService.java      |   20 +-
 .../internal/logging/LogWriterFactory.java      |   24 +-
 .../geode/internal/logging/LogWriterImpl.java   |   18 +-
 .../internal/logging/LoggingThreadGroup.java    |   14 +-
 .../internal/logging/ManagerLogWriter.java      |   18 +-
 .../geode/internal/logging/MergeLogFiles.java   |   12 +-
 .../geode/internal/logging/PureLogWriter.java   |    8 +-
 .../logging/SecurityLocalLogWriter.java         |    6 +-
 .../internal/logging/SecurityLogConfig.java     |    4 +-
 .../internal/logging/SecurityLogWriter.java     |    6 +-
 .../logging/SecurityManagerLogWriter.java       |    4 +-
 .../geode/internal/logging/SortLogFile.java     |    6 +-
 .../internal/logging/StandardErrorPrinter.java  |    2 +-
 .../internal/logging/StandardOutputPrinter.java |    2 +-
 .../internal/logging/log4j/AlertAppender.java   |   18 +-
 .../internal/logging/log4j/AppenderContext.java |    8 +-
 .../internal/logging/log4j/ConfigLocator.java   |    2 +-
 .../internal/logging/log4j/Configurator.java    |    4 +-
 .../internal/logging/log4j/FastLogger.java      |    2 +-
 .../internal/logging/log4j/GemFireLogger.java   |    6 +-
 .../logging/log4j/LocalizedMessage.java         |    4 +-
 .../geode/internal/logging/log4j/LogMarker.java |    6 +-
 .../logging/log4j/LogWriterAppender.java        |   10 +-
 .../logging/log4j/LogWriterAppenders.java       |   16 +-
 .../internal/logging/log4j/LogWriterLogger.java |   20 +-
 .../logging/log4j/ThreadIdPatternConverter.java |    2 +-
 .../message/GemFireParameterizedMessage.java    |    6 +-
 .../GemFireParameterizedMessageFactory.java     |    2 +-
 .../geode/internal/memcached/Command.java       |   68 +-
 .../internal/memcached/CommandProcessor.java    |    6 +-
 .../internal/memcached/ConnectionHandler.java   |   14 +-
 .../geode/internal/memcached/KeyWrapper.java    |    6 +-
 .../apache/geode/internal/memcached/Reply.java  |    2 +-
 .../geode/internal/memcached/RequestReader.java |    8 +-
 .../internal/memcached/ResponseStatus.java      |    2 +-
 .../geode/internal/memcached/ValueWrapper.java  |    6 +-
 .../memcached/commands/AbstractCommand.java     |   28 +-
 .../internal/memcached/commands/AddCommand.java |   14 +-
 .../memcached/commands/AddQCommand.java         |    2 +-
 .../memcached/commands/AppendCommand.java       |   14 +-
 .../memcached/commands/AppendQCommand.java      |    2 +-
 .../internal/memcached/commands/CASCommand.java |   14 +-
 .../memcached/commands/ClientError.java         |    2 +-
 .../memcached/commands/DecrementCommand.java    |   20 +-
 .../memcached/commands/DecrementQCommand.java   |    2 +-
 .../memcached/commands/DeleteCommand.java       |   20 +-
 .../memcached/commands/DeleteQCommand.java      |    2 +-
 .../memcached/commands/FlushAllCommand.java     |   16 +-
 .../memcached/commands/FlushAllQCommand.java    |    2 +-
 .../internal/memcached/commands/GATCommand.java |    2 +-
 .../memcached/commands/GATQCommand.java         |    2 +-
 .../internal/memcached/commands/GetCommand.java |   18 +-
 .../memcached/commands/GetKCommand.java         |    2 +-
 .../memcached/commands/GetKQCommand.java        |    2 +-
 .../memcached/commands/GetQCommand.java         |   10 +-
 .../memcached/commands/IncrementCommand.java    |   18 +-
 .../memcached/commands/IncrementQCommand.java   |    2 +-
 .../memcached/commands/NoOpCommand.java         |    8 +-
 .../memcached/commands/NotSupportedCommand.java |   10 +-
 .../memcached/commands/PrependCommand.java      |   14 +-
 .../memcached/commands/PrependQCommand.java     |    2 +-
 .../memcached/commands/QuitCommand.java         |   10 +-
 .../memcached/commands/QuitQCommand.java        |    2 +-
 .../memcached/commands/ReplaceCommand.java      |   14 +-
 .../memcached/commands/ReplaceQCommand.java     |    2 +-
 .../internal/memcached/commands/SetCommand.java |   14 +-
 .../memcached/commands/SetQCommand.java         |    2 +-
 .../memcached/commands/StatsCommand.java        |   10 +-
 .../memcached/commands/StorageCommand.java      |   12 +-
 .../memcached/commands/TouchCommand.java        |   16 +-
 .../memcached/commands/VerbosityCommand.java    |   10 +-
 .../memcached/commands/VersionCommand.java      |   10 +-
 .../modules/util/RegionConfiguration.java       |   12 +-
 .../apache/geode/internal/net/SocketUtils.java  |    2 +-
 .../internal/offheap/AbstractStoredObject.java  |   16 +-
 .../offheap/AddressableMemoryManager.java       |    6 +-
 .../apache/geode/internal/offheap/DataType.java |   44 +-
 ...DisconnectingOutOfOffHeapMemoryListener.java |    6 +-
 .../apache/geode/internal/offheap/Fragment.java |    2 +-
 .../geode/internal/offheap/FreeListManager.java |    8 +-
 .../internal/offheap/LifecycleListener.java     |    2 +-
 .../geode/internal/offheap/MemoryAllocator.java |    2 +-
 .../internal/offheap/MemoryAllocatorImpl.java   |   18 +-
 .../geode/internal/offheap/MemoryBlock.java     |    2 +-
 .../geode/internal/offheap/MemoryBlockNode.java |    6 +-
 .../geode/internal/offheap/MemoryInspector.java |    2 +-
 .../internal/offheap/MemoryInspectorImpl.java   |    2 +-
 .../internal/offheap/MemoryUsageListener.java   |    2 +-
 .../geode/internal/offheap/OffHeapHelper.java   |   10 +-
 .../internal/offheap/OffHeapMemoryStats.java    |    4 +-
 .../offheap/OffHeapRegionEntryHelper.java       |   24 +-
 .../geode/internal/offheap/OffHeapStorage.java  |   24 +-
 .../internal/offheap/OffHeapStoredObject.java   |   22 +-
 .../OffHeapStoredObjectAddressStack.java        |    4 +-
 .../offheap/OffHeapStoredObjectSlice.java       |    2 +-
 .../OffHeapStoredObjectWithHeapForm.java        |    2 +-
 .../offheap/OutOfOffHeapMemoryListener.java     |    4 +-
 .../internal/offheap/RefCountChangeInfo.java    |    6 +-
 .../internal/offheap/ReferenceCountHelper.java  |    4 +-
 .../offheap/ReferenceCountHelperImpl.java       |    4 +-
 .../geode/internal/offheap/Releasable.java      |    2 +-
 .../org/apache/geode/internal/offheap/Slab.java |    2 +-
 .../geode/internal/offheap/SlabFactory.java     |    2 +-
 .../apache/geode/internal/offheap/SlabImpl.java |    2 +-
 .../geode/internal/offheap/StoredObject.java    |   10 +-
 .../internal/offheap/TinyStoredObject.java      |   14 +-
 .../offheap/annotations/OffHeapIdentifier.java  |   16 +-
 .../internal/offheap/annotations/Released.java  |    4 +-
 .../internal/offheap/annotations/Retained.java  |    4 +-
 .../offheap/annotations/Unretained.java         |    4 +-
 .../java/org/apache/geode/internal/package.html |    8 +-
 .../internal/process/AttachProcessUtils.java    |    4 +-
 .../process/BlockingProcessStreamReader.java    |    4 +-
 ...usterConfigurationNotAvailableException.java |    2 +-
 .../process/ConnectionFailedException.java      |    2 +-
 .../internal/process/ControlFileWatchdog.java   |    4 +-
 .../process/ControlNotificationHandler.java     |    4 +-
 .../internal/process/ControllableProcess.java   |    8 +-
 .../process/FileAlreadyExistsException.java     |    2 +-
 .../process/FileControllerParameters.java       |    4 +-
 .../internal/process/FileProcessController.java |   12 +-
 .../process/LocalProcessController.java         |    4 +-
 .../internal/process/LocalProcessLauncher.java  |    4 +-
 .../process/MBeanControllerParameters.java      |    4 +-
 .../process/MBeanInvocationFailedException.java |    2 +-
 .../process/MBeanProcessController.java         |    2 +-
 .../internal/process/NativeProcessUtils.java    |    6 +-
 .../process/NonBlockingProcessStreamReader.java |    6 +-
 .../apache/geode/internal/process/PidFile.java  |    6 +-
 .../process/PidUnavailableException.java        |    2 +-
 .../internal/process/ProcessController.java     |    4 +-
 .../process/ProcessControllerFactory.java       |    4 +-
 .../process/ProcessControllerParameters.java    |    2 +-
 .../process/ProcessLauncherContext.java         |    8 +-
 .../internal/process/ProcessStreamReader.java   |    4 +-
 .../ProcessTerminatedAbnormallyException.java   |    6 +-
 .../geode/internal/process/ProcessType.java     |    4 +-
 .../geode/internal/process/ProcessUtils.java    |    6 +-
 .../geode/internal/process/StartupStatus.java   |    6 +-
 .../internal/process/StartupStatusListener.java |    2 +-
 .../UnableToControlProcessException.java        |    2 +-
 .../AbstractSignalNotificationHandler.java      |    8 +-
 .../geode/internal/process/signal/Signal.java   |    6 +-
 .../internal/process/signal/SignalEvent.java    |    2 +-
 .../internal/process/signal/SignalListener.java |    2 +-
 .../internal/process/signal/SignalType.java     |    2 +-
 .../internal/security/AuthorizeRequest.java     |   26 +-
 .../internal/security/AuthorizeRequestPP.java   |   20 +-
 .../security/FilterPostAuthorization.java       |   36 +-
 .../security/FilterPreAuthorization.java        |   36 +-
 .../internal/security/GeodeSecurityUtil.java    |   30 +-
 .../security/IntegratedSecurityService.java     |    6 +-
 .../internal/security/ObjectWithAuthz.java      |    6 +-
 .../internal/security/SecurableComponent.java   |    4 +-
 .../internal/security/SecurityService.java      |    4 +-
 .../apache/geode/internal/security/package.html |    2 +-
 .../security/shiro/CustomAuthRealm.java         |    6 +-
 .../security/shiro/GeodePermissionResolver.java |    2 +-
 .../security/shiro/JMXShiroAuthenticator.java   |   12 +-
 .../internal/security/shiro/ShiroPrincipal.java |    2 +-
 .../geode/internal/sequencelog/EntryLogger.java |   18 +-
 .../geode/internal/sequencelog/GraphType.java   |    2 +-
 .../internal/sequencelog/MembershipLogger.java  |    4 +-
 .../internal/sequencelog/MessageLogger.java     |    6 +-
 .../internal/sequencelog/RegionLogger.java      |    6 +-
 .../internal/sequencelog/SequenceLogger.java    |    2 +-
 .../sequencelog/SequenceLoggerImpl.java         |    8 +-
 .../geode/internal/sequencelog/Transition.java  |    2 +-
 .../geode/internal/sequencelog/io/Filter.java   |    4 +-
 .../sequencelog/io/GemfireLogConverter.java     |   10 +-
 .../internal/sequencelog/io/GraphReader.java    |   10 +-
 .../sequencelog/io/InputStreamReader.java       |    8 +-
 .../sequencelog/io/OutputStreamAppender.java    |    4 +-
 .../geode/internal/sequencelog/model/Edge.java  |    2 +-
 .../geode/internal/sequencelog/model/Graph.java |    2 +-
 .../internal/sequencelog/model/GraphID.java     |    4 +-
 .../sequencelog/model/GraphReaderCallback.java  |    4 +-
 .../internal/sequencelog/model/GraphSet.java    |    4 +-
 .../internal/sequencelog/model/Vertex.java      |    2 +-
 .../visualization/text/TextDisplay.java         |   10 +-
 .../geode/internal/shared/NativeCalls.java      |    6 +-
 .../internal/shared/NativeCallsJNAImpl.java     |   20 +-
 .../internal/shared/NativeErrorException.java   |    2 +-
 .../apache/geode/internal/shared/OSType.java    |    2 +-
 .../internal/shared/StringPrintWriter.java      |    2 +-
 .../geode/internal/shared/TCPSocketOptions.java |    2 +-
 .../internal/size/CachingSingleObjectSizer.java |    4 +-
 .../size/InstrumentationSingleObjectSizer.java  |    2 +-
 .../geode/internal/size/ObjectGraphSizer.java   |    8 +-
 .../geode/internal/size/ObjectTraverser.java    |    4 +-
 .../internal/size/ReflectionObjectSizer.java    |   16 +-
 .../size/ReflectionSingleObjectSizer.java       |    8 +-
 .../geode/internal/size/SingleObjectSizer.java  |    2 +-
 .../internal/size/SizeClassOnceObjectSizer.java |    8 +-
 .../apache/geode/internal/size/SizeOfUtil0.java |    2 +-
 .../internal/size/WellKnownClassSizer.java      |    2 +-
 .../statistics/AbstractStatisticsFactory.java   |   14 +-
 .../internal/statistics/ArchiveSplitter.java    |    8 +-
 .../internal/statistics/CallbackSampler.java    |   10 +-
 .../internal/statistics/CounterMonitor.java     |    2 +-
 .../statistics/DummyStatisticsFactory.java      |    4 +-
 .../statistics/DummyStatisticsImpl.java         |    4 +-
 .../geode/internal/statistics/GaugeMonitor.java |    2 +-
 .../internal/statistics/GemFireStatSampler.java |   30 +-
 .../internal/statistics/HostStatHelper.java     |   34 +-
 .../internal/statistics/HostStatSampler.java    |   32 +-
 .../statistics/IgnoreResourceException.java     |    4 +-
 .../internal/statistics/LocalStatListener.java  |    2 +-
 .../statistics/LocalStatisticsFactory.java      |   26 +-
 .../statistics/LocalStatisticsImpl.java         |   18 +-
 .../MapBasedStatisticsNotification.java         |    8 +-
 .../internal/statistics/ResourceInstance.java   |    6 +-
 .../geode/internal/statistics/ResourceType.java |    6 +-
 .../internal/statistics/SampleCollector.java    |   18 +-
 .../internal/statistics/SampleHandler.java      |    2 +-
 .../internal/statistics/SimpleStatSampler.java  |   12 +-
 .../internal/statistics/SimpleStatisticId.java  |    6 +-
 .../statistics/StatArchiveDescriptor.java       |    2 +-
 .../internal/statistics/StatArchiveFormat.java  |    2 +-
 .../internal/statistics/StatArchiveHandler.java |   26 +-
 .../statistics/StatArchiveHandlerConfig.java    |    4 +-
 .../internal/statistics/StatArchiveReader.java  |   12 +-
 .../internal/statistics/StatArchiveWriter.java  |   20 +-
 .../internal/statistics/StatMonitorHandler.java |   10 +-
 .../internal/statistics/StatSamplerStats.java   |    4 +-
 .../statistics/StatisticDescriptorImpl.java     |    6 +-
 .../geode/internal/statistics/StatisticId.java  |    6 +-
 .../statistics/StatisticNotFoundException.java  |    4 +-
 .../internal/statistics/StatisticsImpl.java     |   18 +-
 .../internal/statistics/StatisticsListener.java |    2 +-
 .../internal/statistics/StatisticsManager.java  |    6 +-
 .../internal/statistics/StatisticsMonitor.java  |    2 +-
 .../statistics/StatisticsNotification.java      |    8 +-
 .../internal/statistics/StatisticsSampler.java  |    4 +-
 .../statistics/StatisticsTypeFactoryImpl.java   |    6 +-
 .../internal/statistics/StatisticsTypeImpl.java |    6 +-
 .../internal/statistics/StatisticsTypeXml.java  |   12 +-
 .../geode/internal/statistics/VMStats.java      |    8 +-
 .../internal/statistics/VMStatsContract.java    |    2 +-
 .../statistics/VMStatsContractFactory.java      |    6 +-
 .../geode/internal/statistics/ValueMonitor.java |   10 +-
 .../geode/internal/statistics/package.html      |    2 +-
 .../platform/LinuxProcFsStatistics.java         |    6 +-
 .../statistics/platform/LinuxProcessStats.java  |   14 +-
 .../statistics/platform/LinuxSystemStats.java   |    8 +-
 .../statistics/platform/OSXProcessStats.java    |   12 +-
 .../statistics/platform/OSXSystemStats.java     |    8 +-
 .../platform/OsStatisticsFactory.java           |    8 +-
 .../statistics/platform/ProcessStats.java       |    4 +-
 .../platform/SolarisProcessStats.java           |   16 +-
 .../statistics/platform/SolarisSystemStats.java |    8 +-
 .../platform/WindowsProcessStats.java           |   14 +-
 .../statistics/platform/WindowsSystemStats.java |    8 +-
 .../stats50/Atomic50StatisticsImpl.java         |   16 +-
 .../geode/internal/stats50/VMStats50.java       |   24 +-
 .../geode/internal/tcp/BaseMsgStreamer.java     |    4 +-
 .../org/apache/geode/internal/tcp/Buffers.java  |    6 +-
 .../internal/tcp/ByteBufferInputStream.java     |   10 +-
 .../geode/internal/tcp/ConnectExceptions.java   |    8 +-
 .../apache/geode/internal/tcp/Connection.java   |   44 +-
 .../geode/internal/tcp/ConnectionException.java |    4 +-
 .../geode/internal/tcp/ConnectionTable.java     |   36 +-
 .../geode/internal/tcp/DirectReplySender.java   |   24 +-
 .../tcp/ImmutableByteBufferInputStream.java     |    4 +-
 .../internal/tcp/MemberShunnedException.java    |    6 +-
 .../geode/internal/tcp/MsgDestreamer.java       |   32 +-
 .../geode/internal/tcp/MsgIdGenerator.java      |    4 +-
 .../geode/internal/tcp/MsgOutputStream.java     |    8 +-
 .../apache/geode/internal/tcp/MsgReader.java    |   12 +-
 .../apache/geode/internal/tcp/MsgStreamer.java  |   18 +-
 .../geode/internal/tcp/MsgStreamerList.java     |    6 +-
 .../apache/geode/internal/tcp/NIOMsgReader.java |    4 +-
 .../apache/geode/internal/tcp/OioMsgReader.java |    4 +-
 .../internal/tcp/ReenteredConnectException.java |    4 +-
 .../geode/internal/tcp/ServerDelegate.java      |   14 +-
 .../apache/geode/internal/tcp/TCPConduit.java   |   40 +-
 .../tcp/VersionedByteBufferInputStream.java     |    6 +-
 .../internal/tcp/VersionedMsgStreamer.java      |   10 +-
 .../org/apache/geode/internal/tcp/package.html  |   10 +-
 .../internal/util/AbortableTaskService.java     |    2 +-
 .../apache/geode/internal/util/ArrayUtils.java  |    6 +-
 .../apache/geode/internal/util/BlobHelper.java  |   22 +-
 .../apache/geode/internal/util/Breadcrumbs.java |    8 +-
 .../org/apache/geode/internal/util/Bytes.java   |    2 +-
 .../geode/internal/util/CollectionUtils.java    |    8 +-
 .../geode/internal/util/DebuggerSupport.java    |    8 +-
 .../geode/internal/util/DelayedAction.java      |    2 +-
 .../org/apache/geode/internal/util/Hex.java     |    2 +-
 .../apache/geode/internal/util/HostName.java    |    4 +-
 .../org/apache/geode/internal/util/IOUtils.java |    8 +-
 .../geode/internal/util/JavaCommandBuilder.java |    4 +-
 .../geode/internal/util/LogFileUtils.java       |    2 +-
 .../geode/internal/util/ObjectIntProcedure.java |    2 +-
 .../geode/internal/util/PasswordUtil.java       |    4 +-
 .../apache/geode/internal/util/PluckStacks.java |    2 +-
 .../geode/internal/util/SingletonCallable.java  |    2 +-
 .../geode/internal/util/SingletonValue.java     |    2 +-
 .../internal/util/StackTraceCollector.java      |    2 +-
 .../apache/geode/internal/util/StopWatch.java   |    4 +-
 .../internal/util/SunAPINotFoundException.java  |    2 +-
 .../geode/internal/util/TransformUtils.java     |    4 +-
 .../apache/geode/internal/util/Transformer.java |    2 +-
 .../apache/geode/internal/util/Versionable.java |    2 +-
 .../geode/internal/util/VersionedArrayList.java |   10 +-
 .../util/concurrent/CopyOnWriteHashMap.java     |    2 +-
 .../util/concurrent/CopyOnWriteWeakHashMap.java |    2 +-
 .../CustomEntryConcurrentHashMap.java           |   32 +-
 .../internal/util/concurrent/FutureResult.java  |    6 +-
 .../util/concurrent/ReentrantSemaphore.java     |    2 +-
 .../util/concurrent/SemaphoreReadWriteLock.java |    2 +-
 .../util/concurrent/StoppableCondition.java     |    8 +-
 .../concurrent/StoppableCountDownLatch.java     |    8 +-
 .../concurrent/StoppableCountDownOrUpLatch.java |    8 +-
 .../concurrent/StoppableNonReentrantLock.java   |    6 +-
 .../util/concurrent/StoppableReadWriteLock.java |    4 +-
 .../util/concurrent/StoppableReentrantLock.java |    6 +-
 .../StoppableReentrantReadWriteLock.java        |    6 +-
 .../geode/lang/AttachAPINotFoundException.java  |    2 +-
 .../org/apache/geode/lang/Identifiable.java     |    2 +-
 .../management/AlreadyRunningException.java     |    2 +-
 .../geode/management/AsyncEventQueueMXBean.java |    6 +-
 .../geode/management/CacheServerMXBean.java     |    6 +-
 .../geode/management/ClientHealthStatus.java    |    2 +-
 .../geode/management/ClientQueueDetail.java     |    2 +-
 .../DependenciesNotFoundException.java          |    4 +-
 .../geode/management/DiskBackupResult.java      |    2 +-
 .../geode/management/DiskBackupStatus.java      |    4 +-
 .../apache/geode/management/DiskMetrics.java    |    4 +-
 .../geode/management/DiskStoreMXBean.java       |    6 +-
 .../DistributedLockServiceMXBean.java           |    6 +-
 .../management/DistributedRegionMXBean.java     |   16 +-
 .../management/DistributedSystemMXBean.java     |   12 +-
 .../management/EvictionAttributesData.java      |   10 +-
 .../FixedPartitionAttributesData.java           |    4 +-
 .../geode/management/GatewayReceiverMXBean.java |    6 +-
 .../geode/management/GatewaySenderMXBean.java   |    6 +-
 .../geode/management/GemFireProperties.java     |    2 +-
 .../geode/management/JMXNotificationType.java   |    4 +-
 .../management/JMXNotificationUserData.java     |    4 +-
 .../org/apache/geode/management/JVMMetrics.java |    4 +-
 .../apache/geode/management/LocatorMXBean.java  |    6 +-
 .../geode/management/LockServiceMXBean.java     |    6 +-
 .../geode/management/ManagementException.java   |    4 +-
 .../geode/management/ManagementService.java     |   10 +-
 .../apache/geode/management/ManagerMXBean.java  |    6 +-
 .../apache/geode/management/MemberMXBean.java   |    6 +-
 .../management/MembershipAttributesData.java    |    6 +-
 .../apache/geode/management/NetworkMetrics.java |    4 +-
 .../org/apache/geode/management/OSMetrics.java  |    2 +-
 .../management/PartitionAttributesData.java     |    4 +-
 .../management/PersistentMemberDetails.java     |    2 +-
 .../geode/management/RegionAttributesData.java  |    4 +-
 .../apache/geode/management/RegionMXBean.java   |   12 +-
 .../apache/geode/management/ServerLoadData.java |    2 +-
 .../geode/management/cli/CliMetaData.java       |   12 +-
 .../cli/CommandProcessingException.java         |    2 +-
 .../geode/management/cli/CommandService.java    |   14 +-
 .../management/cli/CommandServiceException.java |    2 +-
 .../geode/management/cli/CommandStatement.java  |    2 +-
 .../geode/management/cli/ConverterHint.java     |    2 +-
 .../org/apache/geode/management/cli/Result.java |    2 +-
 .../geode/management/internal/AgentUtil.java    |    8 +-
 .../geode/management/internal/AlertDetails.java |   10 +-
 .../management/internal/ArrayConverter.java     |    2 +-
 .../internal/BaseManagementService.java         |   12 +-
 .../internal/CollectionConverter.java           |    2 +-
 .../management/internal/CompositeConverter.java |    2 +-
 .../management/internal/EnumConverter.java      |    2 +-
 .../management/internal/FederatingManager.java  |   46 +-
 .../internal/FederationComponent.java           |   14 +-
 .../geode/management/internal/FilterChain.java  |    2 +-
 .../geode/management/internal/FilterParam.java  |    2 +-
 .../management/internal/IdentityConverter.java  |    2 +-
 .../geode/management/internal/JettyHelper.java  |   10 +-
 .../management/internal/JmxManagerAdvisee.java  |   16 +-
 .../management/internal/JmxManagerAdvisor.java  |   34 +-
 .../management/internal/JmxManagerLocator.java  |   40 +-
 .../internal/JmxManagerLocatorRequest.java      |   10 +-
 .../internal/JmxManagerLocatorResponse.java     |    8 +-
 .../management/internal/LocalFilterChain.java   |    4 +-
 .../geode/management/internal/LocalManager.java |   38 +-
 .../management/internal/MBeanJMXAdapter.java    |   38 +-
 .../management/internal/MBeanProxyFactory.java  |   26 +-
 .../internal/MBeanProxyInfoRepository.java      |   12 +-
 .../internal/MBeanProxyInvocationHandler.java   |   14 +-
 .../internal/MXBeanProxyInvocationHandler.java  |    6 +-
 .../management/internal/ManagementAgent.java    |   40 +-
 .../internal/ManagementCacheListener.java       |    8 +-
 .../internal/ManagementConstants.java           |    6 +-
 .../management/internal/ManagementFunction.java |   12 +-
 .../internal/ManagementMembershipListener.java  |    8 +-
 .../internal/ManagementResourceRepo.java        |    6 +-
 .../management/internal/ManagementStrings.java  |    4 +-
 .../geode/management/internal/Manager.java      |   10 +-
 .../internal/ManagerStartupMessage.java         |   16 +-
 .../management/internal/MemberMessenger.java    |   18 +-
 .../internal/MonitoringRegionCacheListener.java |   10 +-
 .../internal/NotificationBroadCasterProxy.java  |    2 +-
 .../internal/NotificationCacheListener.java     |    8 +-
 .../management/internal/NotificationHub.java    |    8 +-
 .../internal/NotificationHubClient.java         |    6 +-
 .../management/internal/NotificationKey.java    |    2 +-
 .../geode/management/internal/OpenMethod.java   |    2 +-
 .../management/internal/OpenTypeConverter.java  |    4 +-
 .../geode/management/internal/OpenTypeUtil.java |    2 +-
 .../geode/management/internal/ProxyInfo.java    |    2 +-
 .../management/internal/ProxyInterface.java     |    2 +-
 .../management/internal/ProxyListener.java      |    4 +-
 .../management/internal/RemoteFilterChain.java  |    4 +-
 .../geode/management/internal/RestAgent.java    |   26 +-
 .../geode/management/internal/SSLUtil.java      |    4 +-
 .../management/internal/StringBasedFilter.java  |    4 +-
 .../internal/SystemManagementService.java       |   64 +-
 .../management/internal/TableConverter.java     |    2 +-
 .../internal/beans/AggregateHandler.java        |    4 +-
 .../internal/beans/AsyncEventQueueMBean.java    |    6 +-
 .../beans/AsyncEventQueueMBeanBridge.java       |   14 +-
 .../internal/beans/BeanUtilFuncs.java           |   16 +-
 .../internal/beans/CacheServerBridge.java       |   86 +-
 .../internal/beans/CacheServerMBean.java        |   10 +-
 .../internal/beans/CacheServiceMBeanBase.java   |    2 +-
 .../internal/beans/DiskRegionBridge.java        |   22 +-
 .../internal/beans/DiskStoreMBean.java          |    4 +-
 .../internal/beans/DiskStoreMBeanBridge.java    |   22 +-
 .../beans/DistributedLockServiceBridge.java     |    8 +-
 .../beans/DistributedLockServiceMBean.java      |    4 +-
 .../internal/beans/DistributedRegionBridge.java |   26 +-
 .../internal/beans/DistributedRegionMBean.java  |   16 +-
 .../internal/beans/DistributedSystemBridge.java |   94 +-
 .../internal/beans/DistributedSystemMBean.java  |   18 +-
 .../internal/beans/GatewayReceiverMBean.java    |    4 +-
 .../beans/GatewayReceiverMBeanBridge.java       |   24 +-
 .../internal/beans/GatewaySenderMBean.java      |    4 +-
 .../beans/GatewaySenderMBeanBridge.java         |   28 +-
 .../management/internal/beans/LocatorMBean.java |    4 +-
 .../internal/beans/LocatorMBeanBridge.java      |   20 +-
 .../internal/beans/LockServiceMBean.java        |    4 +-
 .../internal/beans/LockServiceMBeanBridge.java  |    8 +-
 .../internal/beans/MBeanAggregator.java         |   26 +-
 .../internal/beans/ManagementAdapter.java       |   88 +-
 .../internal/beans/ManagementListener.java      |   36 +-
 .../management/internal/beans/ManagerMBean.java |    4 +-
 .../internal/beans/ManagerMBeanBridge.java      |    4 +-
 .../management/internal/beans/MemberMBean.java  |   14 +-
 .../internal/beans/MemberMBeanBridge.java       |  114 +-
 .../internal/beans/MetricsCalculator.java       |    4 +-
 .../internal/beans/PartitionedRegionBridge.java |   30 +-
 .../internal/beans/QueryDataFunction.java       |   72 +-
 .../management/internal/beans/RegionMBean.java  |   14 +-
 .../internal/beans/RegionMBeanBridge.java       |   48 +-
 .../beans/RegionMBeanCompositeDataFactory.java  |   28 +-
 .../internal/beans/SequenceNumber.java          |    2 +-
 .../management/internal/beans/ServerBridge.java |   24 +-
 .../stats/AggregateRegionStatsMonitor.java      |   18 +-
 .../internal/beans/stats/GCStatsMonitor.java    |   12 +-
 .../GatewayReceiverClusterStatsMonitor.java     |    4 +-
 .../stats/GatewaySenderClusterStatsMonitor.java |    4 +-
 .../stats/IntegerStatsDeltaAggregator.java      |    4 +-
 .../beans/stats/LongStatsDeltaAggregator.java   |    4 +-
 .../internal/beans/stats/MBeanStatsMonitor.java |   20 +-
 .../beans/stats/MemberClusterStatsMonitor.java  |    4 +-
 .../beans/stats/MemberLevelDiskMonitor.java     |   20 +-
 .../beans/stats/RegionClusterStatsMonitor.java  |    6 +-
 .../beans/stats/ServerClusterStatsMonitor.java  |    4 +-
 .../internal/beans/stats/StatType.java          |    2 +-
 .../internal/beans/stats/StatsAggregator.java   |   10 +-
 .../beans/stats/StatsAverageLatency.java        |    4 +-
 .../internal/beans/stats/StatsKey.java          |    2 +-
 .../internal/beans/stats/StatsLatency.java      |    4 +-
 .../internal/beans/stats/StatsRate.java         |    4 +-
 .../internal/beans/stats/VMStatsMonitor.java    |   14 +-
 .../cli/AbstractCliAroundInterceptor.java       |    4 +-
 .../internal/cli/CliAroundInterceptor.java      |    6 +-
 .../geode/management/internal/cli/CliUtil.java  |   48 +-
 .../management/internal/cli/CommandManager.java |   28 +-
 .../management/internal/cli/CommandRequest.java |    6 +-
 .../internal/cli/CommandResponse.java           |    6 +-
 .../internal/cli/CommandResponseBuilder.java    |   10 +-
 .../internal/cli/CommandResponseWriter.java     |    4 +-
 .../internal/cli/GfshParseResult.java           |    8 +-
 .../management/internal/cli/GfshParser.java     |   52 +-
 .../geode/management/internal/cli/Launcher.java |   16 +-
 .../management/internal/cli/LogWrapper.java     |   10 +-
 .../internal/cli/MultipleValueAdapter.java      |    2 +-
 .../internal/cli/MultipleValueConverter.java    |    2 +-
 .../internal/cli/annotation/CliArgument.java    |    2 +-
 .../cli/commands/AbstractCommandsSupport.java   |   36 +-
 .../internal/cli/commands/ClientCommands.java   |   42 +-
 .../internal/cli/commands/ConfigCommands.java   |   64 +-
 .../CreateAlterDestroyRegionCommands.java       |   96 +-
 .../internal/cli/commands/DataCommands.java     |   88 +-
 .../internal/cli/commands/DeployCommands.java   |   50 +-
 .../cli/commands/DiskStoreCommands.java         |  116 +-
 .../cli/commands/DurableClientCommands.java     |   42 +-
 ...ExportImportSharedConfigurationCommands.java |   46 +-
 .../internal/cli/commands/FunctionCommands.java |   74 +-
 .../internal/cli/commands/GfshHelpCommands.java |   26 +-
 .../internal/cli/commands/IndexCommands.java    |   74 +-
 .../cli/commands/LauncherLifecycleCommands.java |  130 +-
 .../internal/cli/commands/MemberCommands.java   |   44 +-
 .../cli/commands/MiscellaneousCommands.java     |  128 +-
 .../internal/cli/commands/PDXCommands.java      |   36 +-
 .../internal/cli/commands/QueueCommands.java    |   44 +-
 .../internal/cli/commands/RegionCommands.java   |   54 +-
 .../internal/cli/commands/ShellCommands.java    |   76 +-
 .../internal/cli/commands/StatusCommands.java   |   30 +-
 .../internal/cli/commands/WanCommands.java      |   60 +-
 .../cli/commands/dto/RegionAttributesInfo.java  |    8 +-
 .../cli/commands/dto/RegionDetails.java         |   12 +-
 .../cli/commands/dto/RegionMemberDetails.java   |   12 +-
 .../cli/converters/BooleanConverter.java        |    2 +-
 .../ClusterMemberIdNameConverter.java           |    6 +-
 .../converters/ConnectionEndpointConverter.java |    4 +-
 .../internal/cli/converters/DirConverter.java   |    8 +-
 .../cli/converters/DirPathConverter.java        |    4 +-
 .../cli/converters/DiskStoreNameConverter.java  |    6 +-
 .../internal/cli/converters/EnumConverter.java  |    2 +-
 .../cli/converters/FilePathConverter.java       |    4 +-
 .../cli/converters/FilePathStringConverter.java |    4 +-
 .../converters/GatewayReceiverIdsConverter.java |    8 +-
 .../converters/GatewaySenderIdConverter.java    |    8 +-
 .../internal/cli/converters/HelpConverter.java  |    8 +-
 .../cli/converters/HintTopicConverter.java      |    6 +-
 .../cli/converters/IndexTypeConverter.java      |    4 +-
 .../LocatorDiscoveryConfigConverter.java        |    6 +-
 .../cli/converters/LocatorIdNameConverter.java  |    6 +-
 .../cli/converters/LogLevelConverter.java       |    6 +-
 .../cli/converters/MemberGroupConverter.java    |    6 +-
 .../cli/converters/MemberIdNameConverter.java   |    6 +-
 .../cli/converters/RegionPathConverter.java     |   10 +-
 .../cli/converters/StringArrayConverter.java    |    6 +-
 .../cli/converters/StringListConverter.java     |    6 +-
 .../cli/domain/AsyncEventQueueDetails.java      |    2 +-
 .../internal/cli/domain/CacheServerInfo.java    |    2 +-
 .../cli/domain/ConnectToLocatorResult.java      |    4 +-
 .../internal/cli/domain/DataCommandRequest.java |    6 +-
 .../internal/cli/domain/DataCommandResult.java  |   32 +-
 .../internal/cli/domain/DiskStoreDetails.java   |   16 +-
 .../cli/domain/DurableCqNamesResult.java        |    2 +-
 .../cli/domain/EvictionAttributesInfo.java      |   12 +-
 .../domain/FixedPartitionAttributesInfo.java    |    4 +-
 .../internal/cli/domain/IndexDetails.java       |   30 +-
 .../internal/cli/domain/IndexInfo.java          |    2 +-
 .../cli/domain/MemberConfigurationInfo.java     |    2 +-
 .../internal/cli/domain/MemberInformation.java  |    2 +-
 .../internal/cli/domain/MemberResult.java       |    2 +-
 .../cli/domain/PartitionAttributesInfo.java     |   14 +-
 .../cli/domain/RegionAttributesInfo.java        |   30 +-
 .../internal/cli/domain/RegionDescription.java  |   10 +-
 .../cli/domain/RegionDescriptionPerMember.java  |    8 +-
 .../internal/cli/domain/RegionInformation.java  |    8 +-
 .../cli/domain/StackTracesPerMember.java        |    2 +-
 .../cli/domain/SubscriptionQueueSizeResult.java |    2 +-
 .../cli/exceptions/CliCommandException.java     |    6 +-
 .../exceptions/CliCommandInvalidException.java  |    6 +-
 .../CliCommandMultiModeOptionException.java     |    8 +-
 .../CliCommandNotAvailableException.java        |    6 +-
 .../exceptions/CliCommandOptionException.java   |    8 +-
 ...CommandOptionHasMultipleValuesException.java |    8 +-
 .../CliCommandOptionInvalidException.java       |    8 +-
 .../CliCommandOptionMissingException.java       |    8 +-
 .../CliCommandOptionNotApplicableException.java |    8 +-
 ...liCommandOptionValueConversionException.java |    8 +-
 .../CliCommandOptionValueException.java         |    8 +-
 .../CliCommandOptionValueMissingException.java  |    8 +-
 .../internal/cli/exceptions/CliException.java   |    2 +-
 .../exceptions/CreateSubregionException.java    |    2 +-
 .../cli/exceptions/ExceptionGenerator.java      |    8 +-
 .../cli/exceptions/ExceptionHandler.java        |    4 +-
 .../cli/exceptions/IndexNotFoundException.java  |    4 +-
 .../functions/AlterRuntimeConfigFunction.java   |   24 +-
 .../functions/AsyncEventQueueFunctionArgs.java  |    2 +-
 .../cli/functions/ChangeLogLevelFunction.java   |   22 +-
 .../cli/functions/CliFunctionResult.java        |   10 +-
 .../functions/CloseDurableClientFunction.java   |   22 +-
 .../cli/functions/CloseDurableCqFunction.java   |   22 +-
 .../cli/functions/ContunuousQueryFunction.java  |   24 +-
 .../CreateAsyncEventQueueFunction.java          |   42 +-
 .../functions/CreateDefinedIndexesFunction.java |   22 +-
 .../cli/functions/CreateDiskStoreFunction.java  |   30 +-
 .../cli/functions/CreateIndexFunction.java      |   32 +-
 .../cli/functions/DataCommandFunction.java      |  104 +-
 .../internal/cli/functions/DeployFunction.java  |   26 +-
 .../functions/DescribeDiskStoreFunction.java    |   54 +-
 .../cli/functions/DestroyDiskStoreFunction.java |   26 +-
 .../cli/functions/DestroyIndexFunction.java     |   28 +-
 .../cli/functions/ExportConfigFunction.java     |   28 +-
 .../cli/functions/ExportDataFunction.java       |   20 +-
 .../ExportSharedConfigurationFunction.java      |   16 +-
 .../FetchRegionAttributesFunction.java          |   26 +-
 .../FetchSharedConfigurationStatusFunction.java |   18 +-
 .../functions/GarbageCollectionFunction.java    |   16 +-
 .../GatewayReceiverCreateFunction.java          |   34 +-
 .../functions/GatewayReceiverFunctionArgs.java  |    2 +-
 .../functions/GatewaySenderCreateFunction.java  |   38 +-
 .../functions/GatewaySenderFunctionArgs.java    |    2 +-
 .../GetMemberConfigInformationFunction.java     |   32 +-
 .../functions/GetMemberInformationFunction.java |   34 +-
 .../functions/GetRegionDescriptionFunction.java |   18 +-
 .../cli/functions/GetRegionsFunction.java       |   18 +-
 .../cli/functions/GetStackTracesFunction.java   |   16 +-
 .../GetSubscriptionQueueSizeFunction.java       |   28 +-
 .../cli/functions/ImportDataFunction.java       |   20 +-
 ...ortSharedConfigurationArtifactsFunction.java |   18 +-
 .../functions/ListAsyncEventQueuesFunction.java |   30 +-
 .../cli/functions/ListDeployedFunction.java     |   26 +-
 .../cli/functions/ListDiskStoresFunction.java   |   32 +-
 .../functions/ListDurableCqNamesFunction.java   |   38 +-
 .../cli/functions/ListFunctionFunction.java     |   22 +-
 .../cli/functions/ListIndexFunction.java        |   30 +-
 .../LoadSharedConfigurationFunction.java        |   16 +-
 .../internal/cli/functions/LogFileFunction.java |   30 +-
 .../cli/functions/MemberRegionFunction.java     |   18 +-
 .../cli/functions/MembersForRegionFunction.java |   16 +-
 .../internal/cli/functions/NetstatFunction.java |   20 +-
 .../cli/functions/RebalanceFunction.java        |   24 +-
 .../cli/functions/RegionAlterFunction.java      |   46 +-
 .../cli/functions/RegionCreateFunction.java     |   56 +-
 .../cli/functions/RegionDestroyFunction.java    |   20 +-
 .../cli/functions/RegionFunctionArgs.java       |   14 +-
 .../cli/functions/ShutDownFunction.java         |   14 +-
 .../cli/functions/UndeployFunction.java         |   26 +-
 .../cli/functions/UnregisterFunction.java       |   18 +-
 .../cli/functions/UserFunctionExecution.java    |   30 +-
 .../management/internal/cli/help/CliTopic.java  |    6 +-
 .../internal/cli/help/format/Block.java         |    2 +-
 .../internal/cli/help/format/DataNode.java      |    2 +-
 .../internal/cli/help/format/Help.java          |    2 +-
 .../internal/cli/help/format/NewHelp.java       |    6 +-
 .../internal/cli/help/format/Row.java           |    2 +-
 .../internal/cli/help/utils/FormatOutput.java   |    2 +-
 .../internal/cli/help/utils/HelpUtils.java      |   20 +-
 .../internal/cli/i18n/CliStrings.java           |   22 +-
 .../internal/cli/json/GfJsonArray.java          |    4 +-
 .../internal/cli/json/GfJsonException.java      |    2 +-
 .../internal/cli/json/GfJsonObject.java         |    2 +-
 .../management/internal/cli/json/TypedJson.java |   10 +-
 .../internal/cli/modes/CommandModes.java        |    8 +-
 .../cli/multistep/CLIMultiStepHelper.java       |   38 +-
 .../internal/cli/multistep/CLIRemoteStep.java   |    2 +-
 .../internal/cli/multistep/CLIStep.java         |    4 +-
 .../cli/multistep/CLIStepExecption.java         |    4 +-
 .../cli/multistep/MultiStepCommand.java         |    2 +-
 .../internal/cli/parser/Argument.java           |    2 +-
 .../internal/cli/parser/AvailabilityTarget.java |    8 +-
 .../internal/cli/parser/CommandTarget.java      |    4 +-
 .../internal/cli/parser/GfshMethodTarget.java   |    2 +-
 .../internal/cli/parser/GfshOptionParser.java   |    6 +-
 .../internal/cli/parser/MethodParameter.java    |    2 +-
 .../management/internal/cli/parser/Option.java  |    4 +-
 .../internal/cli/parser/OptionSet.java          |    2 +-
 .../internal/cli/parser/Parameter.java          |    4 +-
 .../internal/cli/parser/ParserUtils.java        |    4 +-
 .../internal/cli/parser/SyntaxConstants.java    |    2 +-
 .../cli/parser/jopt/JoptOptionParser.java       |   26 +-
 .../preprocessor/EnclosingCharacters.java       |    2 +-
 .../cli/parser/preprocessor/Preprocessor.java   |    4 +-
 .../parser/preprocessor/PreprocessorUtils.java  |    6 +-
 .../internal/cli/parser/preprocessor/Stack.java |    2 +-
 .../cli/parser/preprocessor/TrimmedInput.java   |    2 +-
 .../cli/remote/CommandExecutionContext.java     |    8 +-
 .../internal/cli/remote/CommandProcessor.java   |   26 +-
 .../cli/remote/CommandStatementImpl.java        |   14 +-
 .../cli/remote/MemberCommandService.java        |   12 +-
 .../cli/remote/RemoteExecutionStrategy.java     |   30 +-
 .../internal/cli/remote/WrapperThreadLocal.java |    2 +-
 .../internal/cli/result/AbstractResultData.java |   18 +-
 .../cli/result/CliJsonSerializable.java         |    4 +-
 .../cli/result/CliJsonSerializableFactory.java  |    8 +-
 .../cli/result/CliJsonSerializableIds.java      |    2 +-
 .../internal/cli/result/CommandResult.java      |   20 +-
 .../cli/result/CommandResultException.java      |    4 +-
 .../cli/result/CompositeResultData.java         |    8 +-
 .../internal/cli/result/ErrorResultData.java    |    8 +-
 .../internal/cli/result/FileResult.java         |    6 +-
 .../internal/cli/result/InfoResultData.java     |    6 +-
 .../internal/cli/result/ObjectResultData.java   |    8 +-
 .../internal/cli/result/ResultBuilder.java      |    8 +-
 .../internal/cli/result/ResultData.java         |    6 +-
 .../cli/result/ResultDataException.java         |    2 +-
 .../internal/cli/result/TableBuilder.java       |    6 +-
 .../internal/cli/result/TableBuilderHelper.java |    4 +-
 .../internal/cli/result/TabularResultData.java  |    8 +-
 .../management/internal/cli/shell/Gfsh.java     |   56 +-
 .../internal/cli/shell/GfshConfig.java          |    6 +-
 .../cli/shell/GfshExecutionStrategy.java        |   36 +-
 .../cli/shell/JMXConnectionException.java       |    2 +-
 .../cli/shell/JMXInvocationException.java       |    2 +-
 .../internal/cli/shell/JmxOperationInvoker.java |   30 +-
 .../internal/cli/shell/MultiCommandHelper.java  |    4 +-
 .../internal/cli/shell/OperationInvoker.java    |   10 +-
 .../internal/cli/shell/jline/ANSIBuffer.java    |    2 +-
 .../internal/cli/shell/jline/ANSIHandler.java   |    2 +-
 .../cli/shell/jline/CygwinMinttyTerminal.java   |    2 +-
 .../internal/cli/shell/jline/GfshHistory.java   |    4 +-
 .../shell/jline/GfshUnsupportedTerminal.java    |    2 +-
 .../cli/shell/unsafe/GfshSignalHandler.java     |   12 +-
 .../internal/cli/util/CLIConsoleBufferUtil.java |    4 +-
 .../internal/cli/util/CauseFinder.java          |    2 +-
 .../cli/util/ClasspathScanLoadHelper.java       |    6 +-
 .../internal/cli/util/CommandStringBuilder.java |   10 +-
 .../internal/cli/util/CommentSkipHelper.java    |    2 +-
 .../internal/cli/util/ConnectionEndpoint.java   |    2 +-
 .../internal/cli/util/DiskStoreCompacter.java   |   16 +-
 .../cli/util/DiskStoreNotFoundException.java    |    6 +-
 .../internal/cli/util/DiskStoreUpgrader.java    |   16 +-
 .../internal/cli/util/DiskStoreValidater.java   |    6 +-
 .../cli/util/EvictionAttributesInfo.java        |    8 +-
 .../cli/util/FixedPartitionAttributesInfo.java  |    4 +-
 .../internal/cli/util/GfshConsoleReader.java    |   10 +-
 .../internal/cli/util/HyphenFormatter.java      |    2 +-
 .../cli/util/JConsoleNotFoundException.java     |    6 +-
 .../management/internal/cli/util/JsonUtil.java  |   18 +-
 .../internal/cli/util/MemberInformation.java    |    2 +-
 .../cli/util/MemberNotFoundException.java       |    6 +-
 .../management/internal/cli/util/MergeLogs.java |    6 +-
 .../internal/cli/util/ReadWriteFile.java        |    8 +-
 .../cli/util/RegionAttributesDefault.java       |   20 +-
 .../cli/util/RegionAttributesNames.java         |    2 +-
 .../internal/cli/util/RegionPath.java           |   10 +-
 .../cli/util/VisualVmNotFoundException.java     |    6 +-
 .../SharedConfigurationWriter.java              |   28 +-
 .../callbacks/ConfigurationChangeListener.java  |   12 +-
 .../configuration/domain/CacheElement.java      |   14 +-
 .../configuration/domain/Configuration.java     |    8 +-
 .../domain/ConfigurationChangeResult.java       |    6 +-
 .../domain/SharedConfigurationStatus.java       |    2 +-
 .../configuration/domain/XmlEntity.java         |   24 +-
 .../configuration/functions/AddJarFunction.java |   16 +-
 .../functions/AddXmlEntityFunction.java         |   18 +-
 .../functions/DeleteJarFunction.java            |   16 +-
 .../functions/DeleteXmlEntityFunction.java      |   18 +-
 .../functions/GetAllJarsFunction.java           |   16 +-
 .../functions/ModifyPropertiesFunction.java     |   18 +-
 .../handlers/ConfigurationRequestHandler.java   |   18 +-
 ...SharedConfigurationStatusRequestHandler.java |   18 +-
 .../messages/ConfigurationRequest.java          |    8 +-
 .../messages/ConfigurationResponse.java         |   16 +-
 .../SharedConfigurationStatusRequest.java       |    4 +-
 .../SharedConfigurationStatusResponse.java      |   10 +-
 .../configuration/utils/DtdResolver.java        |    6 +-
 .../configuration/utils/XmlConstants.java       |    2 +-
 .../internal/configuration/utils/XmlUtils.java  |   16 +-
 .../internal/configuration/utils/ZipUtils.java  |    2 +-
 .../internal/messages/CompactRequest.java       |   34 +-
 .../internal/messages/CompactResponse.java      |   12 +-
 .../internal/security/AccessControlMBean.java   |    8 +-
 .../internal/security/AccessControlMXBean.java  |    2 +-
 .../internal/security/MBeanServerWrapper.java   |   10 +-
 .../internal/security/ResourceConstants.java    |    4 +-
 .../internal/security/ResourceOperation.java    |    2 +-
 .../unsafe/ReadOpFileAccessController.java      |    2 +-
 .../controllers/AbstractCommandsController.java |   68 +-
 .../AbstractMultiPartCommandsController.java    |    8 +-
 .../controllers/ClientCommandsController.java   |   10 +-
 .../controllers/ClusterCommandsController.java  |    6 +-
 .../controllers/ConfigCommandsController.java   |   14 +-
 .../web/controllers/DataCommandsController.java |   12 +-
 .../controllers/DeployCommandsController.java   |   14 +-
 .../DiskStoreCommandsController.java            |   12 +-
 .../DurableClientCommandsController.java        |   14 +-
 .../controllers/FunctionCommandsController.java |   12 +-
 .../controllers/IndexCommandsController.java    |   12 +-
 .../LauncherLifecycleCommandsController.java    |    6 +-
 .../controllers/MemberCommandsController.java   |   10 +-
 .../MiscellaneousCommandsController.java        |   12 +-
 .../web/controllers/PdxCommandsController.java  |   12 +-
 .../controllers/QueueCommandsController.java    |   12 +-
 .../controllers/RegionCommandsController.java   |   12 +-
 .../controllers/ShellCommandsController.java    |   32 +-
 .../web/controllers/WanCommandsController.java  |   12 +-
 .../support/LoginHandlerInterceptor.java        |   20 +-
 .../management/internal/web/domain/Link.java    |   18 +-
 .../internal/web/domain/LinkIndex.java          |    6 +-
 .../web/domain/QueryParameterSource.java        |    2 +-
 .../internal/web/http/ClientHttpRequest.java    |   28 +-
 .../internal/web/http/HttpHeader.java           |    4 +-
 .../internal/web/http/HttpMethod.java           |    2 +-
 .../SerializableObjectHttpMessageConverter.java |    6 +-
 .../web/http/support/SimpleHttpRequester.java   |    8 +-
 .../internal/web/io/MultipartFileAdapter.java   |    2 +-
 .../web/io/MultipartFileResourceAdapter.java    |    2 +-
 .../web/shell/AbstractHttpOperationInvoker.java |  108 +-
 .../web/shell/HttpOperationInvoker.java         |    6 +-
 .../web/shell/MBeanAccessException.java         |    2 +-
 .../RestApiCallForCommandNotFoundException.java |    2 +-
 .../web/shell/RestHttpOperationInvoker.java     |   96 +-
 .../web/shell/SimpleHttpOperationInvoker.java   |   52 +-
 .../shell/support/HttpInvocationHandler.java    |    6 +-
 .../shell/support/HttpMBeanProxyFactory.java    |    6 +-
 .../internal/web/util/ConvertUtils.java         |   16 +-
 .../management/internal/web/util/UriUtils.java  |    4 +-
 .../management/membership/ClientMembership.java |    4 +-
 .../membership/ClientMembershipEvent.java       |    8 +-
 .../membership/ClientMembershipListener.java    |    2 +-
 .../ClientMembershipListenerAdapter.java        |    2 +-
 .../management/membership/MembershipEvent.java  |    4 +-
 .../membership/MembershipListener.java          |    4 +-
 .../UniversalMembershipListenerAdapter.java     |   22 +-
 .../geode/memcached/GemFireMemcachedServer.java |   20 +-
 .../src/main/java/org/apache/geode/package.html |   36 +-
 .../java/org/apache/geode/pdx/FieldType.java    |    8 +-
 .../org/apache/geode/pdx/JSONFormatter.java     |   10 +-
 .../geode/pdx/JSONFormatterException.java       |    4 +-
 .../geode/pdx/NonPortableClassException.java    |    2 +-
 .../geode/pdx/PdxConfigurationException.java    |    4 +-
 .../pdx/PdxFieldAlreadyExistsException.java     |    4 +-
 .../pdx/PdxFieldDoesNotExistException.java      |    4 +-
 .../pdx/PdxFieldTypeMismatchException.java      |    4 +-
 .../geode/pdx/PdxInitializationException.java   |    4 +-
 .../java/org/apache/geode/pdx/PdxInstance.java  |    6 +-
 .../apache/geode/pdx/PdxInstanceFactory.java    |    6 +-
 .../java/org/apache/geode/pdx/PdxReader.java    |    6 +-
 .../geode/pdx/PdxRegistryMismatchException.java |    4 +-
 .../org/apache/geode/pdx/PdxSerializable.java   |    2 +-
 .../geode/pdx/PdxSerializationException.java    |    4 +-
 .../org/apache/geode/pdx/PdxSerializer.java     |    6 +-
 .../org/apache/geode/pdx/PdxUnreadFields.java   |    6 +-
 .../java/org/apache/geode/pdx/PdxWriter.java    |    4 +-
 .../pdx/ReflectionBasedAutoSerializer.java      |   14 +-
 .../apache/geode/pdx/WritablePdxInstance.java   |    2 +-
 .../pdx/internal/AutoSerializableManager.java   |   22 +-
 .../pdx/internal/CheckTypeRegistryState.java    |   22 +-
 .../pdx/internal/ClientTypeRegistration.java    |   40 +-
 .../geode/pdx/internal/ComparableEnum.java      |    2 +-
 .../geode/pdx/internal/ConvertableToBytes.java  |    2 +-
 .../org/apache/geode/pdx/internal/DataSize.java |    2 +-
 .../geode/pdx/internal/DefaultPdxField.java     |    6 +-
 .../org/apache/geode/pdx/internal/EnumId.java   |    6 +-
 .../org/apache/geode/pdx/internal/EnumInfo.java |   26 +-
 .../pdx/internal/FieldNotFoundInPdxVersion.java |    2 +-
 .../geode/pdx/internal/InternalPdxReader.java   |   10 +-
 .../pdx/internal/LonerTypeRegistration.java     |    8 +-
 .../pdx/internal/NullTypeRegistration.java      |    6 +-
 .../org/apache/geode/pdx/internal/PdxField.java |   12 +-
 .../geode/pdx/internal/PdxInputStream.java      |   14 +-
 .../geode/pdx/internal/PdxInstanceEnum.java     |   24 +-
 .../pdx/internal/PdxInstanceFactoryImpl.java    |   14 +-
 .../geode/pdx/internal/PdxInstanceImpl.java     |   28 +-
 .../pdx/internal/PdxInstanceInputStream.java    |    4 +-
 .../geode/pdx/internal/PdxOutputStream.java     |   16 +-
 .../geode/pdx/internal/PdxReaderImpl.java       |   36 +-
 .../apache/geode/pdx/internal/PdxString.java    |   10 +-
 .../org/apache/geode/pdx/internal/PdxType.java  |   20 +-
 .../geode/pdx/internal/PdxUnreadData.java       |   10 +-
 .../geode/pdx/internal/PdxWriterImpl.java       |   22 +-
 .../pdx/internal/PeerTypeRegistration.java      |   80 +-
 .../pdx/internal/TrackingPdxReaderImpl.java     |   10 +-
 .../geode/pdx/internal/TypeRegistration.java    |    4 +-
 .../apache/geode/pdx/internal/TypeRegistry.java |   32 +-
 .../geode/pdx/internal/UnreadPdxType.java       |    2 +-
 .../internal/WeakConcurrentIdentityHashMap.java |    2 +-
 .../pdx/internal/WritablePdxInstanceImpl.java   |   12 +-
 .../geode/pdx/internal/json/JsonHelper.java     |    2 +-
 .../pdx/internal/json/PdxInstanceHelper.java    |   14 +-
 .../geode/pdx/internal/json/PdxListHelper.java  |   10 +-
 .../geode/pdx/internal/json/PdxToJSON.java      |   16 +-
 .../pdx/internal/unsafe/UnsafeWrapper.java      |    2 +-
 .../main/java/org/apache/geode/pdx/package.html |   28 +-
 .../java/org/apache/geode/ra/GFConnection.java  |    2 +-
 .../apache/geode/ra/GFConnectionFactory.java    |    2 +-
 .../apache/geode/redis/GeodeRedisServer.java    |   40 +-
 .../geode/redis/internal/ByteArrayWrapper.java  |    4 +-
 .../org/apache/geode/redis/internal/Coder.java  |    4 +-
 .../geode/redis/internal/DoubleWrapper.java     |    4 +-
 .../redis/internal/ExecutionHandlerContext.java |   20 +-
 .../geode/redis/internal/RedisDataType.java     |    2 +-
 .../redis/internal/RegionCreationException.java |    2 +-
 .../geode/redis/internal/RegionProvider.java    |   34 +-
 .../internal/executor/AbstractExecutor.java     |    4 +-
 .../redis/internal/executor/DelExecutor.java    |    2 +-
 .../internal/executor/FlushAllExecutor.java     |    4 +-
 .../internal/executor/hash/HDelExecutor.java    |    2 +-
 .../internal/executor/hash/HExistsExecutor.java |    2 +-
 .../internal/executor/hash/HGetAllExecutor.java |    2 +-
 .../internal/executor/hash/HGetExecutor.java    |    2 +-
 .../internal/executor/hash/HIncrByExecutor.java |    2 +-
 .../executor/hash/HIncrByFloatExecutor.java     |    2 +-
 .../internal/executor/hash/HKeysExecutor.java   |    2 +-
 .../internal/executor/hash/HLenExecutor.java    |    2 +-
 .../internal/executor/hash/HMGetExecutor.java   |    2 +-
 .../internal/executor/hash/HMSetExecutor.java   |    2 +-
 .../internal/executor/hash/HScanExecutor.java   |    2 +-
 .../internal/executor/hash/HSetExecutor.java    |    2 +-
 .../internal/executor/hash/HValsExecutor.java   |    2 +-
 .../internal/executor/hash/HashExecutor.java    |    2 +-
 .../internal/executor/hll/PFAddExecutor.java    |    4 +-
 .../internal/executor/hll/PFCountExecutor.java  |    6 +-
 .../internal/executor/hll/PFMergeExecutor.java  |    6 +-
 .../internal/executor/list/LIndexExecutor.java  |    8 +-
 .../internal/executor/list/LLenExecutor.java    |    2 +-
 .../internal/executor/list/LRangeExecutor.java  |    8 +-
 .../internal/executor/list/LRemExecutor.java    |    8 +-
 .../internal/executor/list/LSetExecutor.java    |    6 +-
 .../internal/executor/list/LTrimExecutor.java   |    6 +-
 .../internal/executor/list/ListExecutor.java    |    6 +-
 .../internal/executor/list/PopExecutor.java     |    2 +-
 .../internal/executor/list/PushExecutor.java    |    2 +-
 .../internal/executor/list/PushXExecutor.java   |    2 +-
 .../internal/executor/set/SAddExecutor.java     |    2 +-
 .../internal/executor/set/SCardExecutor.java    |    2 +-
 .../executor/set/SIsMemberExecutor.java         |    2 +-
 .../internal/executor/set/SMembersExecutor.java |    2 +-
 .../internal/executor/set/SMoveExecutor.java    |    2 +-
 .../internal/executor/set/SPopExecutor.java     |    2 +-
 .../executor/set/SRandMemberExecutor.java       |    2 +-
 .../internal/executor/set/SRemExecutor.java     |    2 +-
 .../internal/executor/set/SScanExecutor.java    |    2 +-
 .../internal/executor/set/SetOpExecutor.java    |    2 +-
 .../executor/sortedset/SortedSetExecutor.java   |    2 +-
 .../executor/sortedset/ZAddExecutor.java        |    2 +-
 .../executor/sortedset/ZCardExecutor.java       |    2 +-
 .../executor/sortedset/ZCountExecutor.java      |   14 +-
 .../executor/sortedset/ZIncrByExecutor.java     |    2 +-
 .../executor/sortedset/ZLexCountExecutor.java   |    6 +-
 .../executor/sortedset/ZRangeByLexExecutor.java |   14 +-
 .../sortedset/ZRangeByScoreExecutor.java        |   16 +-
 .../executor/sortedset/ZRangeExecutor.java      |    6 +-
 .../executor/sortedset/ZRankExecutor.java       |    6 +-
 .../executor/sortedset/ZRemExecutor.java        |    2 +-
 .../sortedset/ZRemRangeByLexExecutor.java       |    6 +-
 .../sortedset/ZRemRangeByRankExecutor.java      |   10 +-
 .../sortedset/ZRemRangeByScoreExecutor.java     |    8 +-
 .../executor/sortedset/ZScanExecutor.java       |    2 +-
 .../executor/sortedset/ZScoreExecutor.java      |    2 +-
 .../executor/string/AppendExecutor.java         |    2 +-
 .../executor/string/BitCountExecutor.java       |    2 +-
 .../internal/executor/string/BitOpExecutor.java |    2 +-
 .../executor/string/BitPosExecutor.java         |    2 +-
 .../executor/string/DecrByExecutor.java         |    2 +-
 .../internal/executor/string/DecrExecutor.java  |    2 +-
 .../executor/string/GetBitExecutor.java         |    2 +-
 .../internal/executor/string/GetExecutor.java   |    2 +-
 .../executor/string/GetRangeExecutor.java       |    2 +-
 .../executor/string/GetSetExecutor.java         |    2 +-
 .../executor/string/IncrByExecutor.java         |    2 +-
 .../executor/string/IncrByFloatExecutor.java    |    2 +-
 .../internal/executor/string/IncrExecutor.java  |    2 +-
 .../internal/executor/string/MGetExecutor.java  |    2 +-
 .../internal/executor/string/MSetExecutor.java  |    2 +-
 .../executor/string/MSetNXExecutor.java         |    2 +-
 .../executor/string/SetBitExecutor.java         |    2 +-
 .../internal/executor/string/SetEXExecutor.java |    2 +-
 .../internal/executor/string/SetExecutor.java   |    2 +-
 .../internal/executor/string/SetNXExecutor.java |    2 +-
 .../executor/string/SetRangeExecutor.java       |    2 +-
 .../executor/string/StrlenExecutor.java         |    2 +-
 .../executor/transactions/DiscardExecutor.java  |    4 +-
 .../executor/transactions/ExecExecutor.java     |    6 +-
 .../executor/transactions/MultiExecutor.java    |    4 +-
 .../apache/geode/security/AccessControl.java    |   14 +-
 .../apache/geode/security/AuthInitialize.java   |   12 +-
 .../security/AuthenticationFailedException.java |    2 +-
 .../AuthenticationRequiredException.java        |    2 +-
 .../apache/geode/security/Authenticator.java    |   10 +-
 .../security/GemFireSecurityException.java      |    6 +-
 .../geode/security/NotAuthorizedException.java  |    2 +-
 .../geode/security/SecurableComponents.java     |    2 +-
 .../apache/geode/security/SecurityManager.java  |    4 +-
 .../templates/SampleSecurityManager.java        |    8 +-
 .../geode.apache.org/schema/cache/cache-1.0.xsd |    2 +-
 .../services/org.xml.sax.ext.EntityResolver2    |    4 +-
 geode-core/src/main/resources/log4j2-cli.xml    |    2 +-
 geode-core/src/main/resources/log4j2.xml        |    2 +-
 .../geode/admin/jmx/mbeans-descriptors.xml      |  110 +-
 .../membership/gms/messenger/jgroups-config.xml |    6 +-
 .../membership/gms/messenger/jgroups-mcast.xml  |    6 +-
 .../internal/i18n/StringIdResourceBundle_ja.txt |    6 +-
 .../internal/logging/log4j/log4j2-legacy.xml    |    2 +-
 .../batterytest/greplogs/ExpectedStrings.java   |    2 +-
 .../java/batterytest/greplogs/LogConsumer.java  |    2 +-
 .../src/test/java/hydra/MethExecutor.java       |    2 +-
 .../src/test/java/hydra/SchedulingOrder.java    |    2 +-
 .../test/java/org/apache/geode/AppObject.java   |    2 +-
 .../java/org/apache/geode/CopyJUnitTest.java    |   16 +-
 .../java/org/apache/geode/DeltaTestImpl.java    |   12 +-
 .../geode/DiskInstantiatorsJUnitTest.java       |   12 +-
 .../geode/JtaNoninvolvementJUnitTest.java       |   14 +-
 .../java/org/apache/geode/LonerDMJUnitTest.java |   18 +-
 .../apache/geode/SystemFailureJUnitTest.java    |    4 +-
 .../org/apache/geode/TXExpiryJUnitTest.java     |   22 +-
 .../test/java/org/apache/geode/TXJUnitTest.java |   32 +-
 .../org/apache/geode/TXWriterJUnitTest.java     |   16 +-
 .../org/apache/geode/TXWriterOOMEJUnitTest.java |   14 +-
 .../java/org/apache/geode/TXWriterTestCase.java |   14 +-
 .../org/apache/geode/TestDataSerializer.java    |   12 +-
 .../java/org/apache/geode/UnitTestDoclet.java   |    2 +-
 .../org/apache/geode/admin/AdminTestHelper.java |    4 +-
 .../apache/geode/admin/AlertLevelJUnitTest.java |    6 +-
 .../BindDistributedSystemJUnitTest.java         |   16 +-
 .../internal/CacheHealthEvaluatorJUnitTest.java |   10 +-
 .../internal/DistributedSystemTestCase.java     |    6 +-
 .../admin/internal/HealthEvaluatorTestCase.java |   10 +-
 .../MemberHealthEvaluatorJUnitTest.java         |   14 +-
 .../geode/cache/AttributesFactoryJUnitTest.java |   10 +-
 .../geode/cache/CacheListenerJUnitTest.java     |   18 +-
 .../cache/CacheRegionClearStatsDUnitTest.java   |   28 +-
 .../org/apache/geode/cache/ClientHelper.java    |   10 +-
 .../cache/ClientServerTimeSyncDUnitTest.java    |   28 +-
 .../cache/ConnectionPoolAndLoaderDUnitTest.java |   28 +-
 .../cache/ConnectionPoolAutoDUnitTest.java      |   10 +-
 .../geode/cache/ConnectionPoolDUnitTest.java    |  224 +-
 .../cache/ConnectionPoolFactoryJUnitTest.java   |   16 +-
 ...alStaticArrayShouldNotCauseSegFaultTest.java |    4 +-
 ...MembershipAttributesAreSerializableTest.java |    4 +-
 .../apache/geode/cache/OperationJUnitTest.java  |    4 +-
 .../geode/cache/PoolManagerJUnitTest.java       |   18 +-
 .../org/apache/geode/cache/ProxyJUnitTest.java  |   30 +-
 .../geode/cache/RegionFactoryJUnitTest.java     |   34 +-
 .../geode/cache/RoleExceptionJUnitTest.java     |    6 +-
 ...ventQueueEvictionAndExpirationJUnitTest.java |   20 +-
 .../SerialAsyncEventQueueImplJUnitTest.java     |   12 +-
 .../client/ClientCacheFactoryJUnitTest.java     |   38 +-
 .../client/ClientRegionFactoryJUnitTest.java    |   28 +-
 .../ClientServerRegisterInterestsDUnitTest.java |   40 +-
 .../internal/AutoConnectionSourceDUnitTest.java |   22 +-
 .../AutoConnectionSourceImplJUnitTest.java      |   46 +-
 .../CacheServerSSLConnectionDUnitTest.java      |   46 +-
 .../internal/ConnectionPoolImplJUnitTest.java   |   30 +-
 .../internal/LocatorLoadBalancingDUnitTest.java |   58 +-
 .../cache/client/internal/LocatorTestBase.java  |   24 +-
 .../internal/OpExecutorImplJUnitTest.java       |   30 +-
 .../client/internal/QueueManagerJUnitTest.java  |   38 +-
 .../internal/SSLNoClientAuthDUnitTest.java      |   36 +-
 .../internal/ServerBlackListJUnitTest.java      |   12 +-
 .../locator/LocatorStatusResponseJUnitTest.java |    6 +-
 .../pooling/ConnectionManagerJUnitTest.java     |   42 +-
 .../cache/execute/FunctionAdapterJUnitTest.java |    4 +-
 .../management/MXMemoryPoolListenerExample.java |   14 +-
 .../management/MemoryThresholdsDUnitTest.java   |  130 +-
 .../MemoryThresholdsOffHeapDUnitTest.java       |  116 +-
 .../management/ResourceManagerDUnitTest.java    |   92 +-
 .../ExceptionHandlingJUnitTest.java             |   12 +-
 .../mapInterface/MapFunctionalJUnitTest.java    |   12 +-
 .../mapInterface/PutAllGlobalLockJUnitTest.java |   26 +-
 .../PutOperationContextJUnitTest.java           |   24 +-
 .../GetOperationContextImplJUnitTest.java       |   18 +-
 .../PartitionRegionHelperDUnitTest.java         |   60 +-
 .../BaseLineAndCompareQueryPerfJUnitTest.java   |   10 +-
 .../query/Bug32947ValueConstraintJUnitTest.java |   12 +-
 .../apache/geode/cache/query/BugJUnitTest.java  |   32 +-
 .../apache/geode/cache/query/CacheUtils.java    |   16 +-
 .../geode/cache/query/MultithreadedTester.java  |    2 +-
 .../cache/query/PdxStringQueryJUnitTest.java    |   42 +-
 .../org/apache/geode/cache/query/PerfQuery.java |   24 +-
 .../geode/cache/query/QueryJUnitTest.java       |   20 +-
 .../cache/query/QueryServiceJUnitTest.java      |    8 +-
 .../geode/cache/query/QueryTestUtils.java       |   72 +-
 .../cache/query/QueryTestUtilsJUnitTest.java    |   10 +-
 ...QueryWithBucketParameterIntegrationTest.java |   24 +-
 .../geode/cache/query/RegionJUnitTest.java      |   20 +-
 .../cache/query/TypedIteratorJUnitTest.java     |   26 +-
 .../org/apache/geode/cache/query/Utils.java     |    8 +-
 .../query/cq/dunit/CqQueryTestListener.java     |   18 +-
 .../apache/geode/cache/query/data/Address.java  |    2 +-
 .../org/apache/geode/cache/query/data/City.java |    2 +-
 .../cache/query/data/CollectionHolder.java      |    4 +-
 .../cache/query/data/ComparableWrapper.java     |    2 +-
 .../apache/geode/cache/query/data/Country.java  |    2 +-
 .../org/apache/geode/cache/query/data/Data.java |    2 +-
 .../apache/geode/cache/query/data/District.java |    2 +-
 .../apache/geode/cache/query/data/Employee.java |    2 +-
 .../geode/cache/query/data/Inventory.java       |    2 +-
 .../apache/geode/cache/query/data/Keywords.java |    2 +-
 .../apache/geode/cache/query/data/Manager.java  |    2 +-
 .../apache/geode/cache/query/data/Numbers.java  |    2 +-
 .../apache/geode/cache/query/data/PhoneNo.java  |    2 +-
 .../geode/cache/query/data/Portfolio.java       |    8 +-
 .../geode/cache/query/data/PortfolioData.java   |    4 +-
 .../geode/cache/query/data/PortfolioNoDS.java   |    4 +-
 .../geode/cache/query/data/PortfolioPdx.java    |   14 +-
 .../apache/geode/cache/query/data/Position.java |    4 +-
 .../geode/cache/query/data/PositionNoDS.java    |    2 +-
 .../geode/cache/query/data/PositionPdx.java     |   10 +-
 .../query/data/ProhibitedSecurityQuote.java     |    2 +-
 .../apache/geode/cache/query/data/Quote.java    |    2 +-
 .../geode/cache/query/data/Restricted.java      |    2 +-
 .../geode/cache/query/data/SecurityMaster.java  |    2 +-
 .../apache/geode/cache/query/data/State.java    |    2 +-
 .../apache/geode/cache/query/data/Street.java   |    2 +-
 .../apache/geode/cache/query/data/Student.java  |    2 +-
 .../apache/geode/cache/query/data/TestData.java |    4 +-
 .../apache/geode/cache/query/data/Vehicle.java  |    2 +-
 .../apache/geode/cache/query/data/Village.java  |    2 +-
 .../query/dunit/CloseCacheAuthorization.java    |   18 +-
 .../query/dunit/CompactRangeIndexDUnitTest.java |   36 +-
 .../dunit/CompactRangeIndexQueryDUnitTest.java  |   54 +-
 .../cache/query/dunit/CompiledInDUnitTest.java  |   44 +-
 .../cache/query/dunit/CqTimeTestListener.java   |   16 +-
 .../cache/query/dunit/GroupByDUnitImpl.java     |   30 +-
 .../dunit/GroupByPartitionedQueryDUnitTest.java |   38 +-
 .../query/dunit/GroupByQueryDUnitTest.java      |   50 +-
 .../cache/query/dunit/HashIndexDUnitTest.java   |   26 +-
 .../geode/cache/query/dunit/HelperTestCase.java |   64 +-
 .../dunit/NonDistinctOrderByDUnitImpl.java      |   30 +-
 .../NonDistinctOrderByPartitionedDUnitTest.java |   40 +-
 ...itionedRegionCompactRangeIndexDUnitTest.java |   30 +-
 .../query/dunit/PdxStringQueryDUnitTest.java    |   96 +-
 .../dunit/QueryAPITestPartitionResolver.java    |    6 +-
 .../cache/query/dunit/QueryAuthorization.java   |   16 +-
 .../dunit/QueryDataInconsistencyDUnitTest.java  |   74 +-
 .../dunit/QueryIndexUsingXMLDUnitTest.java      |   98 +-
 .../QueryParamsAuthorizationDUnitTest.java      |   46 +-
 .../QueryUsingFunctionContextDUnitTest.java     |   94 +-
 .../query/dunit/QueryUsingPoolDUnitTest.java    |  100 +-
 .../cache/query/dunit/RemoteQueryDUnitTest.java |   86 +-
 ...esourceManagerWithQueryMonitorDUnitTest.java |  108 +-
 .../query/dunit/SelectStarQueryDUnitTest.java   |   60 +-
 .../geode/cache/query/facets/lang/Address.java  |    2 +-
 .../geode/cache/query/facets/lang/Course.java   |    4 +-
 .../cache/query/facets/lang/Department.java     |    2 +-
 .../query/facets/lang/DerivedEmployee.java      |    2 +-
 .../geode/cache/query/facets/lang/Employee.java |    2 +-
 .../geode/cache/query/facets/lang/Faculty.java  |    2 +-
 .../cache/query/facets/lang/G_Student.java      |    2 +-
 .../geode/cache/query/facets/lang/Person.java   |    2 +-
 .../geode/cache/query/facets/lang/Student.java  |    2 +-
 .../cache/query/facets/lang/UG_Student.java     |    2 +-
 .../geode/cache/query/facets/lang/Utils.java    |   22 +-
 .../ComparisonOperatorsJUnitTest.java           |   16 +-
 .../query/functional/ConstantsJUnitTest.java    |   12 +-
 .../query/functional/CountStarJUnitTest.java    |   30 +-
 .../CustomerOptimizationsJUnitTest.java         |   34 +-
 .../DistinctAndNonDistinctQueryJUnitTest.java   |   18 +-
 ...ctResultsWithDupValuesInRegionJUnitTest.java |   20 +-
 .../query/functional/FunctionJUnitTest.java     |   26 +-
 .../functional/GroupByPartitionedJUnitTest.java |   12 +-
 .../functional/GroupByReplicatedJUnitTest.java  |    8 +-
 .../cache/query/functional/GroupByTestImpl.java |   26 +-
 .../query/functional/GroupByTestInterface.java  |    2 +-
 .../query/functional/INOperatorJUnitTest.java   |   24 +-
 .../functional/IUM6Bug32345ReJUnitTest.java     |   32 +-
 .../cache/query/functional/IUMJUnitTest.java    |   32 +-
 .../IUMRCompositeIteratorJUnitTest.java         |   34 +-
 .../IUMRMultiIndexesMultiRegionJUnitTest.java   |   36 +-
 .../IUMRShuffleIteratorsJUnitTest.java          |   30 +-
 .../functional/IUMRSingleRegionJUnitTest.java   |   22 +-
 ...ependentOperandsInWhereClause2JUnitTest.java |   26 +-
 .../IndexCreationDeadLockJUnitTest.java         |   40 +-
 .../functional/IndexCreationJUnitTest.java      |   80 +-
 .../IndexMaintenanceAsynchJUnitTest.java        |   34 +-
 .../functional/IndexOnEntrySetJUnitTest.java    |   16 +-
 .../functional/IndexOperatorJUnitTest.java      |   18 +-
 .../IndexPrimaryKeyUsageJUnitTest.java          |   30 +-
 .../IndexUsageInNestedQueryJUnitTest.java       |   26 +-
 ...IndexUsageWithAliasAsProjAtrbtJUnitTest.java |   24 +-
 .../IndexUseMultFrmSnglCondJUnitTest.java       |   32 +-
 ...ndexWithSngleFrmAndMultCondQryJUnitTest.java |   46 +-
 .../functional/IteratorTypeDefEmpJUnitTest.java |   22 +-
 .../functional/IteratorTypeDefJUnitTest.java    |   30 +-
 .../IteratorTypeDefaultTypesJUnitTest.java      |   38 +-
 .../functional/IumMultConditionJUnitTest.java   |   30 +-
 .../functional/JavaSerializationJUnitTest.java  |   14 +-
 .../functional/LikePredicateJUnitTest.java      |   48 +-
 .../query/functional/LimitClauseJUnitTest.java  |   38 +-
 .../functional/LogicalOperatorsJUnitTest.java   |   14 +-
 .../cache/query/functional/MiscJUnitTest.java   |   36 +-
 .../functional/MultiIndexCreationJUnitTest.java |   34 +-
 .../MultiRegionIndexUsageJUnitTest.java         |   22 +-
 .../functional/MultipleRegionsJUnitTest.java    |   16 +-
 .../NegativeNumberQueriesJUnitTest.java         |   14 +-
 .../query/functional/NestedQueryJUnitTest.java  |   30 +-
 .../NonDistinctOrderByPartitionedJUnitTest.java |   34 +-
 .../NonDistinctOrderByReplicatedJUnitTest.java  |   36 +-
 .../NonDistinctOrderByTestImplementation.java   |   40 +-
 .../query/functional/NumericQueryJUnitTest.java |   32 +-
 .../functional/OrderByPartitionedJUnitTest.java |   40 +-
 .../functional/OrderByReplicatedJUnitTest.java  |   36 +-
 .../functional/OrderByTestImplementation.java   |   40 +-
 .../functional/ParameterBindingJUnitTest.java   |   18 +-
 .../PdxGroupByPartitionedJUnitTest.java         |   12 +-
 .../PdxGroupByReplicatedJUnitTest.java          |    8 +-
 .../query/functional/PdxGroupByTestImpl.java    |   26 +-
 .../query/functional/PdxOrderByJUnitTest.java   |   46 +-
 .../functional/QRegionInterfaceJUnitTest.java   |   16 +-
 .../QueryREUpdateInProgressJUnitTest.java       |   32 +-
 .../functional/QueryUndefinedJUnitTest.java     |   22 +-
 .../functional/ReservedKeywordsJUnitTest.java   |   14 +-
 .../ResultsDataSerializabilityJUnitTest.java    |   42 +-
 .../query/functional/SelectToDateJUnitTest.java |   18 +-
 .../functional/StructMemberAccessJUnitTest.java |   32 +-
 .../query/functional/StructSetOrResultsSet.java |   42 +-
 .../TestNewFunctionSSorRSIntegrationTest.java   |   24 +-
 .../CompiledAggregateFunctionJUnitTest.java     |   38 +-
 .../CompiledGroupBySelectJUnitTest.java         |   18 +-
 .../query/internal/CompiledInJUnitTest.java     |   10 +-
 .../CompiledJunctionInternalsJUnitTest.java     |   26 +-
 .../internal/CopyOnReadQueryJUnitTest.java      |   20 +-
 .../internal/ExecutionContextJUnitTest.java     |   20 +-
 .../query/internal/IndexManagerJUnitTest.java   |   20 +-
 .../internal/NWayMergeResultsJUnitTest.java     |   12 +-
 .../internal/OrderByComparatorJUnitTest.java    |   22 +-
 .../internal/ProjectionAttributeJUnitTest.java  |   34 +-
 .../query/internal/QCompilerJUnitTest.java      |    8 +-
 .../QueryExecutionContextJUnitTest.java         |    4 +-
 ...ueryFromClauseCanonicalizationJUnitTest.java |   14 +-
 .../QueryObjectSerializationJUnitTest.java      |   12 +-
 .../QueryObserverCallbackJUnitTest.java         |   30 +-
 .../query/internal/QueryTraceJUnitTest.java     |   34 +-
 .../query/internal/QueryUtilsJUnitTest.java     |   18 +-
 .../query/internal/ResultsBagJUnitTest.java     |   14 +-
 .../ResultsBagLimitBehaviourJUnitTest.java      |   12 +-
 .../ResultsCollectionWrapperLimitJUnitTest.java |    6 +-
 .../SelectResultsComparatorJUnitTest.java       |    8 +-
 .../StructBagLimitBehaviourJUnitTest.java       |   14 +-
 .../query/internal/StructSetJUnitTest.java      |   14 +-
 .../internal/aggregate/AggregatorJUnitTest.java |    4 +-
 .../internal/cq/CqAttributesImplJUnitTest.java  |    8 +-
 ...syncIndexUpdaterThreadShutdownJUnitTest.java |   16 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java  |   26 +-
 .../CompactRangeIndexIndexMapJUnitTest.java     |   14 +-
 .../index/CompactRangeIndexJUnitTest.java       |   24 +-
 ...rrentIndexInitOnOverflowRegionDUnitTest.java |   70 +-
 ...ndexOperationsOnOverflowRegionDUnitTest.java |   58 +-
 ...pdateWithInplaceObjectModFalseDUnitTest.java |   70 +-
 ...ConcurrentIndexUpdateWithoutWLDUnitTest.java |   68 +-
 .../index/CopyOnReadIndexDUnitTest.java         |   68 +-
 .../index/CopyOnReadIndexJUnitTest.java         |   14 +-
 .../DeclarativeIndexCreationJUnitTest.java      |   20 +-
 .../internal/index/EquiJoinIntegrationTest.java |   38 +-
 .../internal/index/HashIndexJUnitTest.java      |   42 +-
 .../internal/index/HashIndexSetJUnitTest.java   |    8 +-
 .../index/IndexCreationInternalsJUnitTest.java  |   26 +-
 .../internal/index/IndexElemArrayJUnitTest.java |    6 +-
 .../internal/index/IndexHintJUnitTest.java      |   22 +-
 .../query/internal/index/IndexJUnitTest.java    |   16 +-
 .../index/IndexMaintainceJUnitTest.java         |   42 +-
 .../index/IndexMaintenanceJUnitTest.java        |   50 +-
 .../index/IndexStatisticsJUnitTest.java         |   36 +-
 .../IndexTrackingQueryObserverDUnitTest.java    |   60 +-
 .../IndexTrackingQueryObserverJUnitTest.java    |   28 +-
 .../query/internal/index/IndexUseJUnitTest.java |   42 +-
 .../IndexedMergeEquiJoinScenariosJUnitTest.java |   36 +-
 ...itializeIndexEntryDestroyQueryDUnitTest.java |   58 +-
 .../internal/index/MapIndexStoreJUnitTest.java  |   30 +-
 .../MapRangeIndexMaintenanceJUnitTest.java      |   24 +-
 .../index/MemoryIndexStoreJUnitTest.java        |   16 +-
 ...exStoreWithInplaceModificationJUnitTest.java |   10 +-
 .../index/MultiIndexCreationDUnitTest.java      |   46 +-
 .../NewDeclarativeIndexCreationJUnitTest.java   |   12 +-
 ...artitionedRegionEquiJoinIntegrationTest.java |   28 +-
 .../index/PdxCopyOnReadQueryJUnitTest.java      |   24 +-
 ...gRegionCreationIndexUpdateTypeJUnitTest.java |   10 +-
 .../index/PutAllWithIndexPerfDUnitTest.java     |   42 +-
 .../internal/index/RangeIndexAPIJUnitTest.java  |   44 +-
 .../query/internal/types/TypeUtilTest.java      |    8 +-
 .../PRBasicIndexCreationDUnitTest.java          |   44 +-
 .../PRBasicIndexCreationDeadlockDUnitTest.java  |   34 +-
 .../PRBasicMultiIndexCreationDUnitTest.java     |   34 +-
 .../partitioned/PRBasicQueryDUnitTest.java      |   42 +-
 .../PRBasicRemoveIndexDUnitTest.java            |   16 +-
 .../PRColocatedEquiJoinDUnitTest.java           |   78 +-
 .../partitioned/PRIndexStatisticsJUnitTest.java |   32 +-
 .../partitioned/PRInvalidQueryDUnitTest.java    |   20 +-
 .../partitioned/PRInvalidQueryJUnitTest.java    |   14 +-
 .../partitioned/PRQueryCacheCloseDUnitTest.java |   32 +-
 .../PRQueryCacheClosedJUnitTest.java            |   22 +-
 .../query/partitioned/PRQueryDUnitHelper.java   |  224 +-
 .../query/partitioned/PRQueryDUnitTest.java     |   46 +-
 .../query/partitioned/PRQueryJUnitTest.java     |   26 +-
 .../partitioned/PRQueryNumThreadsJUnitTest.java |   20 +-
 .../PRQueryRegionCloseDUnitTest.java            |   30 +-
 .../PRQueryRegionClosedJUnitTest.java           |   20 +-
 .../PRQueryRegionDestroyedDUnitTest.java        |   30 +-
 .../PRQueryRegionDestroyedJUnitTest.java        |   22 +-
 .../PRQueryRemoteNodeExceptionDUnitTest.java    |   44 +-
 .../geode/cache/query/transaction/Person.java   |    2 +-
 .../query/transaction/QueryAndJtaJUnitTest.java |   42 +-
 .../internal/ConnectionCountProbeJUnitTest.java |    6 +-
 .../cache/snapshot/CacheSnapshotJUnitTest.java  |   12 +-
 .../snapshot/ParallelSnapshotDUnitTest.java     |   32 +-
 .../geode/cache/snapshot/RegionGenerator.java   |   14 +-
 .../cache/snapshot/RegionSnapshotJUnitTest.java |   22 +-
 .../snapshot/SnapshotByteArrayDUnitTest.java    |   30 +-
 .../geode/cache/snapshot/SnapshotDUnitTest.java |   34 +-
 .../snapshot/SnapshotPerformanceDUnitTest.java  |   28 +-
 .../geode/cache/snapshot/SnapshotTestCase.java  |   14 +-
 .../cache/snapshot/WanSnapshotJUnitTest.java    |   14 +-
 .../geode/cache/util/PasswordUtilJUnitTest.java |    8 +-
 .../apache/geode/cache30/Bug34387DUnitTest.java |   38 +-
 .../apache/geode/cache30/Bug34948DUnitTest.java |   38 +-
 .../apache/geode/cache30/Bug35214DUnitTest.java |   60 +-
 .../apache/geode/cache30/Bug38013DUnitTest.java |   36 +-
 .../apache/geode/cache30/Bug38741DUnitTest.java |   70 +-
 .../apache/geode/cache30/Bug40255JUnitTest.java |   18 +-
 .../apache/geode/cache30/Bug40662JUnitTest.java |   10 +-
 .../apache/geode/cache30/Bug44418JUnitTest.java |   18 +-
 .../geode/cache30/CacheCloseDUnitTest.java      |   20 +-
 .../geode/cache30/CacheListenerTestCase.java    |   32 +-
 .../geode/cache30/CacheLoaderTestCase.java      |   34 +-
 .../geode/cache30/CacheLogRollDUnitTest.java    |   16 +-
 .../geode/cache30/CacheMapTxnDUnitTest.java     |   36 +-
 ...cheRegionsReliablityStatsCheckDUnitTest.java |   40 +-
 .../cache30/CacheSerializableRunnable.java      |   12 +-
 .../geode/cache30/CacheStatisticsDUnitTest.java |   36 +-
 .../org/apache/geode/cache30/CacheTestCase.java |    6 +-
 .../geode/cache30/CacheWriterTestCase.java      |   12 +-
 .../cache30/CacheXMLPartitionResolver.java      |   12 +-
 .../geode/cache30/CacheXml30DUnitTest.java      |   68 +-
 .../geode/cache30/CacheXml40DUnitTest.java      |   20 +-
 .../geode/cache30/CacheXml41DUnitTest.java      |   42 +-
 .../geode/cache30/CacheXml45DUnitTest.java      |   66 +-
 .../geode/cache30/CacheXml51DUnitTest.java      |   42 +-
 .../geode/cache30/CacheXml55DUnitTest.java      |    8 +-
 .../geode/cache30/CacheXml57DUnitTest.java      |   76 +-
 .../geode/cache30/CacheXml58DUnitTest.java      |   50 +-
 .../geode/cache30/CacheXml60DUnitTest.java      |   38 +-
 .../geode/cache30/CacheXml61DUnitTest.java      |   20 +-
 .../geode/cache30/CacheXml65DUnitTest.java      |   74 +-
 .../geode/cache30/CacheXml66DUnitTest.java      |   50 +-
 .../geode/cache30/CacheXml70DUnitTest.java      |   42 +-
 .../geode/cache30/CacheXml80DUnitTest.java      |   42 +-
 .../geode/cache30/CacheXml81DUnitTest.java      |   26 +-
 .../geode/cache30/CacheXmlGeode10DUnitTest.java |   36 +-
 .../apache/geode/cache30/CacheXmlTestCase.java  |   20 +-
 .../geode/cache30/CachedAllEventsDUnitTest.java |   30 +-
 .../geode/cache30/CallbackArgDUnitTest.java     |   42 +-
 .../cache30/CertifiableTestCacheListener.java   |   12 +-
 .../cache30/ClearMultiVmCallBkDUnitTest.java    |   36 +-
 .../geode/cache30/ClearMultiVmDUnitTest.java    |   48 +-
 .../cache30/ClientMembershipDUnitTest.java      |   74 +-
 .../ClientMembershipSelectorDUnitTest.java      |    4 +-
 .../ClientRegisterInterestDUnitTest.java        |   34 +-
 ...ClientRegisterInterestSelectorDUnitTest.java |    4 +-
 .../geode/cache30/ClientServerCCEDUnitTest.java |   62 +-
 .../geode/cache30/ClientServerTestCase.java     |   44 +-
 .../ConcurrentLeaveDuringGIIDUnitTest.java      |   44 +-
 ...ibutedNoAckAsyncOverflowRegionDUnitTest.java |   22 +-
 ...iskDistributedNoAckAsyncRegionDUnitTest.java |   12 +-
 .../DiskDistributedNoAckRegionTestCase.java     |    4 +-
 ...ributedNoAckSyncOverflowRegionDUnitTest.java |   18 +-
 .../geode/cache30/DiskRegionDUnitTest.java      |   72 +-
 .../geode/cache30/DiskRegionTestImpl.java       |   28 +-
 .../cache30/DistAckMapMethodsDUnitTest.java     |   50 +-
 ...istributedAckOverflowRegionCCEDUnitTest.java |   20 +-
 ...tedAckOverflowRegionCCEOffHeapDUnitTest.java |   16 +-
 ...tributedAckPersistentRegionCCEDUnitTest.java |   18 +-
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java |   16 +-
 .../DistributedAckRegionCCEDUnitTest.java       |   88 +-
 ...DistributedAckRegionCCEOffHeapDUnitTest.java |   16 +-
 ...istributedAckRegionCompressionDUnitTest.java |   12 +-
 .../cache30/DistributedAckRegionDUnitTest.java  |   28 +-
 .../DistributedAckRegionOffHeapDUnitTest.java   |   16 +-
 .../DistributedMulticastRegionDUnitTest.java    |   48 +-
 ...MulticastRegionWithUDPSecurityDUnitTest.java |    4 +-
 .../DistributedNoAckRegionCCEDUnitTest.java     |   50 +-
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java |   16 +-
 .../DistributedNoAckRegionDUnitTest.java        |   40 +-
 .../DistributedNoAckRegionOffHeapDUnitTest.java |   16 +-
 .../geode/cache30/DynamicRegionDUnitTest.java   |   38 +-
 .../geode/cache30/GlobalLockingDUnitTest.java   |   36 +-
 .../geode/cache30/GlobalRegionCCEDUnitTest.java |   36 +-
 .../GlobalRegionCCEOffHeapDUnitTest.java        |   16 +-
 .../geode/cache30/GlobalRegionDUnitTest.java    |   40 +-
 .../cache30/GlobalRegionOffHeapDUnitTest.java   |   16 +-
 .../cache30/LRUEvictionControllerDUnitTest.java |   66 +-
 .../geode/cache30/LocalRegionDUnitTest.java     |   28 +-
 .../MemLRUEvictionControllerDUnitTest.java      |   38 +-
 .../geode/cache30/MultiVMRegionTestCase.java    |  318 +--
 .../geode/cache30/MyGatewayEventFilter1.java    |   10 +-
 .../geode/cache30/MyGatewayEventFilter2.java    |   14 +-
 .../cache30/MyGatewayTransportFilter1.java      |    6 +-
 .../cache30/MyGatewayTransportFilter2.java      |    6 +-
 .../OffHeapLRUEvictionControllerDUnitTest.java  |   18 +-
 .../PRBucketSynchronizationDUnitTest.java       |   64 +-
 .../PartitionedRegionCompressionDUnitTest.java  |   16 +-
 .../cache30/PartitionedRegionDUnitTest.java     |   60 +-
 ...tionedRegionMembershipListenerDUnitTest.java |   26 +-
 .../PartitionedRegionOffHeapDUnitTest.java      |   16 +-
 .../geode/cache30/PreloadedRegionTestCase.java  |   24 +-
 .../apache/geode/cache30/ProxyDUnitTest.java    |   56 +-
 .../cache30/PutAllCallBkRemoteVMDUnitTest.java  |   44 +-
 .../cache30/PutAllCallBkSingleVMDUnitTest.java  |   40 +-
 .../geode/cache30/PutAllMultiVmDUnitTest.java   |   36 +-
 .../apache/geode/cache30/QueueMsgDUnitTest.java |   42 +-
 .../cache30/RRSynchronizationDUnitTest.java     |   22 +-
 .../geode/cache30/ReconnectDUnitTest.java       |   54 +-
 .../ReconnectWithUDPSecurityDUnitTest.java      |    6 +-
 .../ReconnectedCacheServerDUnitTest.java        |   24 +-
 .../geode/cache30/RegionAttributesTestCase.java |   14 +-
 .../cache30/RegionExpirationDUnitTest.java      |   32 +-
 .../RegionMembershipListenerDUnitTest.java      |   52 +-
 .../RegionReliabilityDistAckDUnitTest.java      |   10 +-
 .../RegionReliabilityDistNoAckDUnitTest.java    |   10 +-
 .../RegionReliabilityGlobalDUnitTest.java       |   10 +-
 .../RegionReliabilityListenerDUnitTest.java     |   36 +-
 .../cache30/RegionReliabilityTestCase.java      |   98 +-
 .../apache/geode/cache30/RegionTestCase.java    |  100 +-
 .../geode/cache30/ReliabilityTestCase.java      |   10 +-
 .../cache30/RemoveAllMultiVmDUnitTest.java      |   34 +-
 .../geode/cache30/RequiredRolesDUnitTest.java   |   42 +-
 .../geode/cache30/SearchAndLoadDUnitTest.java   |   48 +-
 .../apache/geode/cache30/SlowRecDUnitTest.java  |   52 +-
 .../geode/cache30/TXDistributedDUnitTest.java   |  100 +-
 .../apache/geode/cache30/TXOrderDUnitTest.java  |   68 +-
 .../geode/cache30/TXRestrictionsDUnitTest.java  |   28 +-
 .../apache/geode/cache30/TestCacheCallback.java |    8 +-
 .../apache/geode/cache30/TestCacheListener.java |    6 +-
 .../apache/geode/cache30/TestCacheLoader.java   |    4 +-
 .../apache/geode/cache30/TestCacheWriter.java   |    6 +-
 .../apache/geode/cache30/TestDiskRegion.java    |   36 +-
 .../org/apache/geode/cache30/TestHeapLRU.java   |   12 +-
 .../apache/geode/cache30/TestPdxSerializer.java |   12 +-
 .../geode/cache30/TestTransactionListener.java  |    6 +-
 .../geode/cache30/TestTransactionWriter.java    |   10 +-
 .../AnalyzeSerializablesJUnitTest.java          |   16 +-
 .../codeAnalysis/ClassAndMethodDetails.java     |    8 +-
 .../geode/codeAnalysis/ClassAndMethods.java     |    6 +-
 .../codeAnalysis/ClassAndVariableDetails.java   |    6 +-
 .../geode/codeAnalysis/ClassAndVariables.java   |    6 +-
 .../geode/codeAnalysis/CompiledClassUtils.java  |    8 +-
 .../codeAnalysis/decode/CompiledAttribute.java  |    4 +-
 .../codeAnalysis/decode/CompiledClass.java      |   22 +-
 .../geode/codeAnalysis/decode/CompiledCode.java |    2 +-
 .../codeAnalysis/decode/CompiledField.java      |    4 +-
 .../codeAnalysis/decode/CompiledMethod.java     |    4 +-
 .../apache/geode/codeAnalysis/decode/cp/Cp.java |    2 +-
 .../geode/codeAnalysis/decode/cp/CpClass.java   |    4 +-
 .../geode/codeAnalysis/decode/cp/CpDouble.java  |    2 +-
 .../codeAnalysis/decode/cp/CpFieldref.java      |    4 +-
 .../geode/codeAnalysis/decode/cp/CpFloat.java   |    2 +-
 .../geode/codeAnalysis/decode/cp/CpInteger.java |    2 +-
 .../decode/cp/CpInterfaceMethodref.java         |    2 +-
 .../codeAnalysis/decode/cp/CpInvokeDynamic.java |    4 +-
 .../geode/codeAnalysis/decode/cp/CpLong.java    |    2 +-
 .../codeAnalysis/decode/cp/CpMethodHandle.java  |    4 +-
 .../codeAnalysis/decode/cp/CpMethodType.java    |    4 +-
 .../codeAnalysis/decode/cp/CpMethodref.java     |    2 +-
 .../codeAnalysis/decode/cp/CpNameAndType.java   |    2 +-
 .../geode/codeAnalysis/decode/cp/CpString.java  |    2 +-
 .../geode/codeAnalysis/decode/cp/CpUtf8.java    |    2 +-
 .../AbstractLauncherIntegrationTest.java        |    8 +-
 .../AbstractLauncherIntegrationTestCase.java    |   24 +-
 .../AbstractLauncherServiceStatusTest.java      |   14 +-
 .../geode/distributed/AbstractLauncherTest.java |   10 +-
 ...tractLocatorLauncherIntegrationTestCase.java |   14 +-
 ...ocatorLauncherRemoteIntegrationTestCase.java |    6 +-
 ...stractServerLauncherIntegrationTestCase.java |   14 +-
 ...ServerLauncherRemoteIntegrationTestCase.java |    6 +-
 .../geode/distributed/AuthInitializer.java      |    8 +-
 .../distributed/DistributedLockBlackboard.java  |    2 +-
 .../DistributedLockBlackboardImpl.java          |    6 +-
 .../DistributedLockServiceDUnitTest.java        |   62 +-
 .../distributed/DistributedMemberDUnitTest.java |   28 +-
 .../DistributedSystemConnectPerf.java           |    4 +-
 .../distributed/DistributedSystemDUnitTest.java |   44 +-
 .../DistributedSystemIntegrationJUnitTest.java  |    4 +-
 .../distributed/DistributedSystemJUnitTest.java |    4 +-
 .../distributed/HostedLocatorsDUnitTest.java    |   42 +-
 .../LauncherMemberMXBeanIntegrationTest.java    |   16 +-
 .../geode/distributed/LocatorDUnitTest.java     |  176 +-
 .../geode/distributed/LocatorJUnitTest.java     |   46 +-
 .../LocatorLauncherIntegrationTest.java         |   14 +-
 ...LocatorLauncherLocalFileIntegrationTest.java |    8 +-
 .../LocatorLauncherLocalIntegrationTest.java    |   26 +-
 ...ocatorLauncherRemoteFileIntegrationTest.java |   20 +-
 .../LocatorLauncherRemoteIntegrationTest.java   |   40 +-
 ...rRemoteWithCustomLoggingIntegrationTest.java |   16 +-
 .../geode/distributed/LocatorLauncherTest.java  |   20 +-
 .../geode/distributed/LocatorStateTest.java     |   14 +-
 .../LocatorUDPSecurityDUnitTest.java            |   30 +-
 .../MockServerLauncherCacheProvider.java        |    4 +-
 .../geode/distributed/MyAuthenticator.java      |    8 +-
 .../apache/geode/distributed/MyPrincipal.java   |    2 +-
 .../apache/geode/distributed/RoleDUnitTest.java |   20 +-
 .../ServerLauncherIntegrationTest.java          |   14 +-
 .../ServerLauncherLocalFileIntegrationTest.java |    6 +-
 .../ServerLauncherLocalIntegrationTest.java     |   56 +-
 ...ServerLauncherRemoteFileIntegrationTest.java |   18 +-
 .../ServerLauncherRemoteIntegrationTest.java    |   56 +-
 ...rRemoteWithCustomLoggingIntegrationTest.java |   12 +-
 .../geode/distributed/ServerLauncherTest.java   |   28 +-
 ...rverLauncherWithProviderIntegrationTest.java |   14 +-
 .../geode/distributed/SystemAdminDUnitTest.java |   16 +-
 .../AbstractDistributionConfigTest.java         |    6 +-
 .../AtomicLongWithTerminalStateJUnitTest.java   |    4 +-
 .../distributed/internal/Bug40751DUnitTest.java |   32 +-
 .../ConsoleDistributionManagerDUnitTest.java    |   64 +-
 .../geode/distributed/internal/DateMessage.java |    8 +-
 .../internal/DistributionAdvisorDUnitTest.java  |   16 +-
 .../internal/DistributionConfigJUnitTest.java   |   14 +-
 .../internal/DistributionManagerDUnitTest.java  |   86 +-
 .../InternalDistributedSystemJUnitTest.java     |   26 +-
 .../apache/geode/distributed/internal/LDM.java  |    8 +-
 .../LocatorLoadSnapshotIntegrationTest.java     |    6 +-
 .../internal/LocatorLoadSnapshotJUnitTest.java  |    6 +-
 .../internal/ProduceDateMessages.java           |    8 +-
 .../internal/ProductUseLogDUnitTest.java        |   36 +-
 .../internal/ProductUseLogJUnitTest.java        |    4 +-
 .../internal/ServerLocatorJUnitTest.java        |   16 +-
 .../internal/SharedConfigurationJUnitTest.java  |   10 +-
 .../internal/StartupMessageDataJUnitTest.java   |   14 +-
 .../DeadlockDetectorIntegrationTest.java        |    4 +-
 .../internal/deadlock/DeadlockDetectorTest.java |    4 +-
 .../deadlock/DependencyGraphJUnitTest.java      |    4 +-
 .../GemFireDeadlockDetectorDUnitTest.java       |   46 +-
 .../deadlock/UnsafeThreadLocalJUnitTest.java    |    4 +-
 .../internal/locks/CollaborationJUnitTest.java  |   20 +-
 .../internal/locks/DLockGrantorHelper.java      |    6 +-
 .../locks/DLockReentrantLockJUnitTest.java      |   10 +-
 .../membership/InternalRoleJUnitTest.java       |    4 +-
 .../membership/MembershipJUnitTest.java         |   36 +-
 .../internal/membership/NetViewJUnitTest.java   |    8 +-
 .../membership/gms/GMSMemberJUnitTest.java      |    8 +-
 .../membership/gms/MembershipManagerHelper.java |   30 +-
 .../auth/AbstractGMSAuthenticatorTestCase.java  |   22 +-
 .../GMSAuthenticatorWithAuthenticatorTest.java  |    8 +-
 ...GMSAuthenticatorWithSecurityManagerTest.java |   10 +-
 .../gms/fd/GMSHealthMonitorJUnitTest.java       |   42 +-
 .../locator/GMSLocatorRecoveryJUnitTest.java    |   32 +-
 .../gms/membership/GMSJoinLeaveJUnitTest.java   |   46 +-
 .../gms/membership/GMSJoinLeaveTestHelper.java  |   18 +-
 .../gms/membership/StatRecorderJUnitTest.java   |   26 +-
 .../gms/messenger/GMSEncryptJUnitTest.java      |   22 +-
 .../messenger/GMSQuorumCheckerJUnitTest.java    |   10 +-
 .../membership/gms/messenger/InterceptUDP.java  |    2 +-
 .../messenger/JGroupsMessengerJUnitTest.java    |   82 +-
 .../gms/mgr/GMSMembershipManagerJUnitTest.java  |   44 +-
 .../StreamingOperationManyDUnitTest.java        |   24 +-
 .../StreamingOperationOneDUnitTest.java         |   24 +-
 .../TcpServerBackwardCompatDUnitTest.java       |   40 +-
 .../internal/tcpserver/TcpServerJUnitTest.java  |   16 +-
 .../support/DistributedSystemAdapter.java       |   18 +-
 .../geode/disttx/CacheMapDistTXDUnitTest.java   |   12 +-
 .../geode/disttx/DistTXDebugDUnitTest.java      |   50 +-
 .../geode/disttx/DistTXExpiryJUnitTest.java     |   24 +-
 .../apache/geode/disttx/DistTXJUnitTest.java    |   18 +-
 .../disttx/DistTXManagerImplJUnitTest.java      |   20 +-
 .../geode/disttx/DistTXOrderDUnitTest.java      |   10 +-
 .../disttx/DistTXPersistentDebugDUnitTest.java  |   34 +-
 .../DistTXReleasesOffHeapOnCloseJUnitTest.java  |   18 +-
 .../disttx/DistTXRestrictionsDUnitTest.java     |    8 +-
 .../geode/disttx/DistTXWithDeltaDUnitTest.java  |    8 +-
 .../geode/disttx/DistTXWriterJUnitTest.java     |   24 +-
 .../geode/disttx/DistTXWriterOOMEJUnitTest.java |   24 +-
 .../disttx/DistributedTransactionDUnitTest.java |   82 +-
 .../apache/geode/disttx/PRDistTXDUnitTest.java  |    8 +-
 .../apache/geode/disttx/PRDistTXJUnitTest.java  |   20 +-
 .../disttx/PRDistTXWithVersionsDUnitTest.java   |    8 +-
 ...entPartitionedRegionWithDistTXDUnitTest.java |    8 +-
 .../geode/internal/AbstractConfigJUnitTest.java |    6 +-
 .../geode/internal/AvailablePortHelper.java     |    4 +-
 .../geode/internal/AvailablePortJUnitTest.java  |    8 +-
 ...wardCompatibilitySerializationDUnitTest.java |   16 +-
 .../geode/internal/Bug49856JUnitTest.java       |   12 +-
 .../geode/internal/Bug51616JUnitTest.java       |   10 +-
 .../apache/geode/internal/ByteArrayData.java    |    4 +-
 .../org/apache/geode/internal/ClassBuilder.java |    2 +-
 .../ClassNotFoundExceptionDUnitTest.java        |   52 +-
 .../ClassPathLoaderIntegrationTest.java         |   10 +-
 .../geode/internal/ClassPathLoaderTest.java     |   12 +-
 .../geode/internal/ConfigSourceJUnitTest.java   |    4 +-
 .../internal/CopyOnWriteHashSetJUnitTest.java   |    4 +-
 .../internal/DataSerializableJUnitTest.java     |   22 +-
 .../geode/internal/FileUtilJUnitTest.java       |    4 +-
 .../GemFireVersionIntegrationJUnitTest.java     |   12 +-
 .../geode/internal/GemFireVersionJUnitTest.java |    8 +-
 .../internal/HeapDataOutputStreamJUnitTest.java |    8 +-
 .../geode/internal/InlineKeyJUnitTest.java      |   18 +-
 .../geode/internal/JSSESocketJUnitTest.java     |   16 +-
 .../geode/internal/JarClassLoaderJUnitTest.java |   56 +-
 .../geode/internal/JarDeployerDUnitTest.java    |   30 +-
 .../org/apache/geode/internal/JavaExec.java     |    2 +-
 .../geode/internal/LineWrapUnitJUnitTest.java   |    4 +-
 .../org/apache/geode/internal/LongBuffer.java   |    2 +-
 .../geode/internal/NanoTimerJUnitTest.java      |    6 +-
 .../geode/internal/ObjIdMapJUnitTest.java       |    4 +-
 .../internal/OneTaskOnlyDecoratorJUnitTest.java |    4 +-
 .../geode/internal/PdxDeleteFieldDUnitTest.java |   42 +-
 .../geode/internal/PdxDeleteFieldJUnitTest.java |   22 +-
 .../geode/internal/PdxRenameDUnitTest.java      |   44 +-
 .../geode/internal/PdxRenameJUnitTest.java      |   22 +-
 .../PutAllOperationContextJUnitTest.java        |   12 +-
 ...lityShouldUseArrayEqualsIntegrationTest.java |   16 +-
 .../internal/SSLConfigIntegrationJUnitTest.java |   16 +-
 .../geode/internal/SSLConfigJUnitTest.java      |   10 +-
 ...hreadPoolExecutorWithKeepAliveJUnitTest.java |    6 +-
 .../geode/internal/SocketCloserJUnitTest.java   |    8 +-
 .../internal/SocketCloserWithWaitJUnitTest.java |    4 +-
 .../internal/UniqueIdGeneratorJUnitTest.java    |    4 +-
 .../apache/geode/internal/VersionJUnitTest.java |    4 +-
 .../remote/DistributionLocatorIdJUnitTest.java  |    6 +-
 .../internal/cache/ARMLockTestHookAdapter.java  |    6 +-
 .../AbstractDistributedRegionJUnitTest.java     |   20 +-
 .../internal/cache/AbstractRegionJUnitTest.java |   44 +-
 .../internal/cache/AbstractRegionMapTest.java   |   10 +-
 .../geode/internal/cache/BackupDUnitTest.java   |   74 +-
 .../geode/internal/cache/BackupJUnitTest.java   |   16 +-
 .../internal/cache/BucketRegionJUnitTest.java   |    6 +-
 .../geode/internal/cache/Bug33359DUnitTest.java |   34 +-
 .../geode/internal/cache/Bug33726DUnitTest.java |   30 +-
 .../geode/internal/cache/Bug33726JUnitTest.java |   12 +-
 .../Bug34179TooManyFilesOpenJUnitTest.java      |    6 +-
 .../geode/internal/cache/Bug34583JUnitTest.java |   16 +-
 .../geode/internal/cache/Bug37241DUnitTest.java |   30 +-
 .../geode/internal/cache/Bug37244JUnitTest.java |   20 +-
 .../geode/internal/cache/Bug37377DUnitTest.java |   26 +-
 .../geode/internal/cache/Bug37500JUnitTest.java |    6 +-
 .../geode/internal/cache/Bug39079DUnitTest.java |   40 +-
 .../geode/internal/cache/Bug40299DUnitTest.java |   38 +-
 .../geode/internal/cache/Bug40632DUnitTest.java |   18 +-
 .../geode/internal/cache/Bug41091DUnitTest.java |   40 +-
 .../geode/internal/cache/Bug41733DUnitTest.java |   38 +-
 .../geode/internal/cache/Bug41957DUnitTest.java |   48 +-
 .../geode/internal/cache/Bug42055DUnitTest.java |   34 +-
 .../geode/internal/cache/Bug45164DUnitTest.java |   26 +-
 .../geode/internal/cache/Bug45934DUnitTest.java |   30 +-
 .../geode/internal/cache/Bug47667DUnitTest.java |   30 +-
 .../geode/internal/cache/Bug48182JUnitTest.java |   12 +-
 .../internal/cache/CacheAdvisorDUnitTest.java   |   48 +-
 .../cache/CacheLifecycleListenerJUnitTest.java  |    8 +-
 .../cache/CacheServerLauncherJUnitTest.java     |    6 +-
 .../internal/cache/CacheServiceJUnitTest.java   |    8 +-
 .../internal/cache/ClearDAckDUnitTest.java      |   42 +-
 .../internal/cache/ClearGlobalDUnitTest.java    |   32 +-
 .../cache/ClearRvvLockingDUnitTest.java         |   40 +-
 ...ssagesRegionCreationAndDestroyJUnitTest.java |   22 +-
 .../cache/ClientServerGetAllDUnitTest.java      |   54 +-
 ...ServerInvalidAndDestroyedEntryDUnitTest.java |   70 +-
 .../ClientServerTransactionCCEDUnitTest.java    |   24 +-
 .../cache/ClientServerTransactionDUnitTest.java |   84 +-
 .../internal/cache/ColocationHelperTest.java    |   16 +-
 .../geode/internal/cache/CommitFunction.java    |   30 +-
 .../cache/ComplexDiskRegionJUnitTest.java       |   12 +-
 .../ConcurrentDestroySubRegionDUnitTest.java    |   34 +-
 ...entFlushingAndRegionOperationsJUnitTest.java |    8 +-
 .../cache/ConcurrentMapLocalJUnitTest.java      |   16 +-
 .../cache/ConcurrentMapOpsDUnitTest.java        |   64 +-
 .../ConcurrentRegionOperationsJUnitTest.java    |   12 +-
 ...rentRollingAndRegionOperationsJUnitTest.java |   12 +-
 .../internal/cache/ConflationJUnitTest.java     |    4 +-
 .../cache/ConnectDisconnectDUnitTest.java       |   22 +-
 .../cache/CustomerIDPartitionResolver.java      |   12 +-
 .../internal/cache/DeltaFaultInDUnitTest.java   |   34 +-
 .../cache/DeltaPropagationDUnitTest.java        |  112 +-
 .../cache/DeltaPropagationStatsDUnitTest.java   |   58 +-
 .../internal/cache/DeltaSizingDUnitTest.java    |   42 +-
 .../geode/internal/cache/DiskIFJUnitTest.java   |   22 +-
 .../geode/internal/cache/DiskIdJUnitTest.java   |    4 +-
 .../internal/cache/DiskInitFileJUnitTest.java   |    8 +-
 .../cache/DiskOfflineCompactionJUnitTest.java   |   30 +-
 .../internal/cache/DiskOldAPIsJUnitTest.java    |   24 +-
 ...iskRandomOperationsAndRecoveryJUnitTest.java |   18 +-
 .../cache/DiskRegByteArrayDUnitTest.java        |   36 +-
 .../cache/DiskRegCacheXmlJUnitTest.java         |   24 +-
 .../DiskRegCachexmlGeneratorJUnitTest.java      |   16 +-
 .../internal/cache/DiskRegCbkChkJUnitTest.java  |   12 +-
 .../DiskRegOplogSwtchingAndRollerJUnitTest.java |   16 +-
 .../cache/DiskRegRecoveryJUnitTest.java         |   14 +-
 .../cache/DiskRegionAsyncRecoveryJUnitTest.java |   10 +-
 ...RegionChangingRegionAttributesJUnitTest.java |    6 +-
 .../cache/DiskRegionClearJUnitTest.java         |   30 +-
 .../internal/cache/DiskRegionHelperFactory.java |    4 +-
 .../DiskRegionIllegalArguementsJUnitTest.java   |   14 +-
 ...iskRegionIllegalCacheXMLvaluesJUnitTest.java |   14 +-
 .../internal/cache/DiskRegionJUnitTest.java     |   32 +-
 .../internal/cache/DiskRegionProperties.java    |    4 +-
 .../internal/cache/DiskRegionTestingBase.java   |   28 +-
 .../cache/DiskStoreFactoryJUnitTest.java        |   26 +-
 .../cache/DiskWriteAttributesJUnitTest.java     |   22 +-
 ...DistrbutedRegionProfileOffHeapDUnitTest.java |   30 +-
 .../cache/DistributedCacheTestCase.java         |   40 +-
 .../cache/DistributedRegionJUnitTest.java       |    6 +-
 .../internal/cache/EntryEventImplTest.java      |   14 +-
 .../cache/EnumListenerEventJUnitTest.java       |    4 +-
 .../internal/cache/EventTrackerDUnitTest.java   |   46 +-
 .../geode/internal/cache/EvictionDUnitTest.java |   12 +-
 .../cache/EvictionObjectSizerDUnitTest.java     |   44 +-
 .../internal/cache/EvictionStatsDUnitTest.java  |   56 +-
 .../geode/internal/cache/EvictionTestBase.java  |   64 +-
 .../internal/cache/FaultingInJUnitTest.java     |    4 +-
 .../cache/FixedPRSinglehopDUnitTest.java        |   66 +-
 .../geode/internal/cache/GIIDeltaDUnitTest.java |   56 +-
 .../internal/cache/GIIFlowControlDUnitTest.java |   48 +-
 .../internal/cache/GemFireCacheImplTest.java    |   10 +-
 .../internal/cache/GridAdvisorDUnitTest.java    |   40 +-
 .../HAOverflowMemObjectSizerDUnitTest.java      |   46 +-
 .../cache/IncrementalBackupDUnitTest.java       |   64 +-
 .../cache/InterruptClientServerDUnitTest.java   |   46 +-
 .../internal/cache/InterruptDiskJUnitTest.java  |   16 +-
 ...InterruptsConserveSocketsFalseDUnitTest.java |    6 +-
 .../internal/cache/InterruptsDUnitTest.java     |   32 +-
 .../geode/internal/cache/IteratorDUnitTest.java |   20 +-
 .../LIFOEvictionAlgoEnabledRegionJUnitTest.java |   14 +-
 ...victionAlgoMemoryEnabledRegionJUnitTest.java |   20 +-
 .../geode/internal/cache/LocalDataSetTest.java  |    6 +-
 .../internal/cache/MapClearGIIDUnitTest.java    |   44 +-
 .../internal/cache/MapInterface2JUnitTest.java  |   30 +-
 .../internal/cache/MapInterfaceJUnitTest.java   |   28 +-
 .../geode/internal/cache/MockCacheService.java  |    4 +-
 .../internal/cache/MockCacheServiceImpl.java    |    6 +-
 .../MultipleOplogsRollingFeatureJUnitTest.java  |    8 +-
 .../cache/NestedTransactionFunction.java        |   20 +-
 .../cache/NetSearchMessagingDUnitTest.java      |   50 +-
 .../cache/OffHeapEvictionDUnitTest.java         |   34 +-
 .../cache/OffHeapEvictionStatsDUnitTest.java    |   18 +-
 .../geode/internal/cache/OffHeapTestUtil.java   |   12 +-
 .../cache/OffHeapValueWrapperJUnitTest.java     |   18 +-
 .../cache/OfflineSnapshotJUnitTest.java         |   20 +-
 .../geode/internal/cache/OldVLJUnitTest.java    |    6 +-
 .../cache/OldValueImporterTestBase.java         |   20 +-
 .../cache/OplogEntryIdMapJUnitTest.java         |    6 +-
 .../cache/OplogEntryIdSetJUnitTest.java         |    6 +-
 .../geode/internal/cache/OplogJUnitTest.java    |   54 +-
 .../geode/internal/cache/OplogRVVJUnitTest.java |   20 +-
 .../cache/OrderedTombstoneMapJUnitTest.java     |    8 +-
 .../cache/P2PDeltaPropagationDUnitTest.java     |   44 +-
 .../internal/cache/PRBadToDataDUnitTest.java    |   30 +-
 .../cache/PRConcurrentMapOpsJUnitTest.java      |   10 +-
 .../cache/PRDataStoreMemoryJUnitTest.java       |   18 +-
 .../PRDataStoreMemoryOffHeapJUnitTest.java      |    8 +-
 .../geode/internal/cache/PRTXJUnitTest.java     |   42 +-
 .../cache/PartitionAttributesImplJUnitTest.java |   14 +-
 .../cache/PartitionListenerDUnitTest.java       |   34 +-
 ...dRegionAPIConserveSocketsFalseDUnitTest.java |    8 +-
 .../cache/PartitionedRegionAPIDUnitTest.java    |   54 +-
 .../PartitionedRegionAsSubRegionDUnitTest.java  |   30 +-
 ...gionBucketCreationDistributionDUnitTest.java |   54 +-
 .../PartitionedRegionCacheCloseDUnitTest.java   |   44 +-
 ...rtitionedRegionCacheLoaderForRootRegion.java |   10 +-
 ...artitionedRegionCacheLoaderForSubRegion.java |   12 +-
 ...rtitionedRegionCacheXMLExampleDUnitTest.java |   20 +-
 .../PartitionedRegionCreationDUnitTest.java     |   48 +-
 .../PartitionedRegionCreationJUnitTest.java     |   24 +-
 .../cache/PartitionedRegionDUnitTestCase.java   |   46 +-
 .../PartitionedRegionDataStoreJUnitTest.java    |   18 +-
 ...rtitionedRegionDelayedRecoveryDUnitTest.java |   38 +-
 .../PartitionedRegionDestroyDUnitTest.java      |   46 +-
 .../PartitionedRegionEntryCountDUnitTest.java   |   34 +-
 .../PartitionedRegionEvictionDUnitTest.java     |   68 +-
 .../cache/PartitionedRegionHADUnitTest.java     |   50 +-
 ...onedRegionHAFailureAndRecoveryDUnitTest.java |   46 +-
 .../cache/PartitionedRegionHelperJUnitTest.java |    4 +-
 .../PartitionedRegionInvalidateDUnitTest.java   |   32 +-
 ...artitionedRegionLocalMaxMemoryDUnitTest.java |   28 +-
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java |   16 +-
 .../PartitionedRegionMultipleDUnitTest.java     |   30 +-
 ...rtitionedRegionOffHeapEvictionDUnitTest.java |   18 +-
 .../cache/PartitionedRegionPRIDDUnitTest.java   |   26 +-
 .../cache/PartitionedRegionQueryDUnitTest.java  |   88 +-
 ...onedRegionQueryEvaluatorIntegrationTest.java |   22 +-
 .../PartitionedRegionQueryEvaluatorTest.java    |   28 +-
 ...artitionedRegionRedundancyZoneDUnitTest.java |   30 +-
 ...tionedRegionSerializableObjectJUnitTest.java |    8 +-
 .../PartitionedRegionSingleHopDUnitTest.java    |   94 +-
 ...RegionSingleHopWithServerGroupDUnitTest.java |   70 +-
 ...onedRegionSingleNodeOperationsJUnitTest.java |   30 +-
 .../cache/PartitionedRegionSizeDUnitTest.java   |   50 +-
 .../cache/PartitionedRegionStatsDUnitTest.java  |   44 +-
 .../cache/PartitionedRegionStatsJUnitTest.java  |   26 +-
 .../cache/PartitionedRegionTestHelper.java      |   16 +-
 .../PartitionedRegionTestUtilsDUnitTest.java    |   28 +-
 .../PartitionedRegionWithSameNameDUnitTest.java |   40 +-
 .../PersistentPartitionedRegionJUnitTest.java   |   10 +-
 .../internal/cache/PutAllDAckDUnitTest.java     |   40 +-
 .../internal/cache/PutAllGlobalDUnitTest.java   |   52 +-
 .../cache/RegionEntryFlagsJUnitTest.java        |   14 +-
 .../internal/cache/RegionListenerJUnitTest.java |    8 +-
 .../cache/RemoteOperationMessageTest.java       |   16 +-
 .../cache/RemotePutReplyMessageJUnitTest.java   |   12 +-
 .../cache/RemoteTransactionCCEDUnitTest.java    |    8 +-
 .../cache/RemoteTransactionDUnitTest.java       |  146 +-
 .../internal/cache/RemoveAllDAckDUnitTest.java  |   38 +-
 .../internal/cache/RemoveDAckDUnitTest.java     |   32 +-
 .../internal/cache/RemoveGlobalDUnitTest.java   |   42 +-
 .../cache/ReplaceWithOverflowJUnitTest.java     |   18 +-
 .../geode/internal/cache/RollbackFunction.java  |   28 +-
 .../cache/SearchLoadAndWriteProcessorTest.java  |   10 +-
 .../cache/SimpleDiskRegionJUnitTest.java        |   20 +-
 .../internal/cache/SingleHopStatsDUnitTest.java |   56 +-
 .../internal/cache/SizingFlagDUnitTest.java     |   70 +-
 .../geode/internal/cache/SnapshotTestUtil.java  |    6 +-
 .../internal/cache/SystemFailureDUnitTest.java  |   62 +-
 .../internal/cache/TXManagerImplJUnitTest.java  |   12 +-
 .../geode/internal/cache/TXManagerImplTest.java |   14 +-
 .../cache/TXReservationMgrJUnitTest.java        |   14 +-
 .../apache/geode/internal/cache/TestDelta.java  |   10 +-
 .../internal/cache/TestHelperForHydraTests.java |    2 +-
 .../internal/cache/TestNonSizerObject.java      |    2 +-
 .../internal/cache/TestObjectSizerImpl.java     |    4 +-
 .../apache/geode/internal/cache/TestUtils.java  |    2 +-
 .../cache/TombstoneCreationJUnitTest.java       |   18 +-
 .../cache/TransactionsWithDeltaDUnitTest.java   |   42 +-
 .../internal/cache/UnitTestValueHolder.java     |    2 +-
 .../apache/geode/internal/cache/UnzipUtil.java  |    2 +-
 .../internal/cache/UpdateVersionJUnitTest.java  |   20 +-
 .../geode/internal/cache/VLJUnitTest.java       |    6 +-
 .../cache/control/FilterByPathJUnitTest.java    |    6 +-
 .../cache/control/MemoryMonitorJUnitTest.java   |   34 +-
 .../control/MemoryMonitorOffHeapJUnitTest.java  |   20 +-
 .../control/MemoryThresholdsJUnitTest.java      |    6 +-
 .../control/RebalanceOperationDUnitTest.java    |  108 +-
 .../control/TestMemoryThresholdListener.java    |    6 +-
 ...skRegOverflowAsyncGetInMemPerfJUnitTest.java |   12 +-
 ...iskRegOverflowAsyncJUnitPerformanceTest.java |   18 +-
 ...lowSyncGetInMemPerfJUnitPerformanceTest.java |   12 +-
 ...DiskRegOverflowSyncJUnitPerformanceTest.java |   18 +-
 ...egionOverflowAsyncRollingOpLogJUnitTest.java |   26 +-
 ...RegionOverflowSyncRollingOpLogJUnitTest.java |   16 +-
 .../DiskRegionPerfJUnitPerformanceTest.java     |   14 +-
 .../DiskRegionPersistOnlySyncJUnitTest.java     |   20 +-
 ...DiskRegionRollOpLogJUnitPerformanceTest.java |   14 +-
 ...ltiThreadedOplogPerJUnitPerformanceTest.java |   14 +-
 .../cache/execute/Bug51193DUnitTest.java        |   60 +-
 .../ClientServerFunctionExecutionDUnitTest.java |   58 +-
 .../execute/ColocationFailoverDUnitTest.java    |   50 +-
 .../cache/execute/CustomResultCollector.java    |    8 +-
 .../execute/CustomerIDPartitionResolver.java    |   12 +-
 ...ributedRegionFunctionExecutionDUnitTest.java |   84 +-
 .../FunctionExecution_ExceptionDUnitTest.java   |   40 +-
 .../cache/execute/FunctionServiceBase.java      |   26 +-
 .../FunctionServiceClientAccessorPRBase.java    |   34 +-
 ...unctionServiceClientAccessorPRDUnitTest.java |   26 +-
 ...lientAccessorPRMultipleMembersDUnitTest.java |   32 +-
 ...essorPRMultipleMembersMultihopDUnitTest.java |    6 +-
 .../execute/FunctionServiceClientBase.java      |   12 +-
 ...nServiceClientMultipleOnServerDUnitTest.java |   22 +-
 .../FunctionServiceClientOnServerBase.java      |   12 +-
 .../FunctionServiceClientOnServerDUnitTest.java |    4 +-
 .../FunctionServiceLocalPRDUnitTest.java        |   16 +-
 .../FunctionServiceLocalRRDUnitTest.java        |   12 +-
 ...unctionServiceMultipleOnMemberDUnitTest.java |   14 +-
 .../FunctionServicePeerAccessorPRBase.java      |   16 +-
 .../FunctionServicePeerAccessorPRDUnitTest.java |   18 +-
 ...ePeerAccessorPRMultipleMembersDUnitTest.java |   18 +-
 .../FunctionServicePeerAccessorRRDUnitTest.java |   18 +-
 .../FunctionServiceSingleOnMemberDUnitTest.java |   10 +-
 .../execute/FunctionServiceStatsDUnitTest.java  |   70 +-
 .../cache/execute/LocalDataSetDUnitTest.java    |   46 +-
 .../cache/execute/LocalDataSetFunction.java     |   16 +-
 .../execute/LocalDataSetIndexingDUnitTest.java  |   96 +-
 .../LocalFunctionExecutionDUnitTest.java        |   46 +-
 .../MemberFunctionExecutionDUnitTest.java       |   66 +-
 .../MultiRegionFunctionExecutionDUnitTest.java  |   46 +-
 .../execute/MyFunctionExecutionException.java   |    2 +-
 .../cache/execute/MyTransactionFunction.java    |   58 +-
 .../OnGroupsFunctionExecutionDUnitTest.java     |   58 +-
 ...ntServerFunctionExecutionNoAckDUnitTest.java |   24 +-
 ...tServerRegionFunctionExecutionDUnitTest.java |   70 +-
 ...egionFunctionExecutionFailoverDUnitTest.java |   66 +-
 ...onFunctionExecutionNoSingleHopDUnitTest.java |   56 +-
 ...onExecutionSelectorNoSingleHopDUnitTest.java |   54 +-
 ...gionFunctionExecutionSingleHopDUnitTest.java |   54 +-
 .../cache/execute/PRClientServerTestBase.java   |   66 +-
 .../cache/execute/PRColocationDUnitTest.java    |   90 +-
 .../execute/PRCustomPartitioningDUnitTest.java  |   32 +-
 .../execute/PRFunctionExecutionDUnitTest.java   |  102 +-
 .../PRFunctionExecutionTimeOutDUnitTest.java    |   48 +-
 ...ctionExecutionWithResultSenderDUnitTest.java |   58 +-
 .../execute/PRPerformanceTestDUnitTest.java     |   54 +-
 .../cache/execute/PRTransactionDUnitTest.java   |   56 +-
 .../PRTransactionWithVersionsDUnitTest.java     |    8 +-
 .../internal/cache/execute/PerfFunction.java    |   18 +-
 .../internal/cache/execute/PerfTxFunction.java  |   20 +-
 .../cache/execute/PerformanceTestFunction.java  |   12 +-
 .../execute/SingleHopGetAllPutAllDUnitTest.java |   26 +-
 .../internal/cache/execute/TestFunction.java    |   16 +-
 .../internal/cache/execute/data/CustId.java     |    6 +-
 .../internal/cache/execute/data/Customer.java   |    8 +-
 .../internal/cache/execute/data/Order.java      |    8 +-
 .../internal/cache/execute/data/OrderId.java    |    6 +-
 .../internal/cache/execute/data/Shipment.java   |    8 +-
 .../internal/cache/execute/data/ShipmentId.java |    6 +-
 .../SimpleExtensionPointJUnitTest.java          |   10 +-
 .../extension/mock/AbstractMockExtension.java   |   10 +-
 .../mock/AbstractMockExtensionXmlGenerator.java |    4 +-
 .../mock/AlterMockCacheExtensionFunction.java   |   32 +-
 .../mock/AlterMockRegionExtensionFunction.java  |   32 +-
 .../mock/CreateMockCacheExtensionFunction.java  |   30 +-
 .../mock/CreateMockRegionExtensionFunction.java |   32 +-
 .../mock/DestroyMockCacheExtensionFunction.java |   32 +-
 .../DestroyMockRegionExtensionFunction.java     |   32 +-
 .../extension/mock/MockCacheExtension.java      |   12 +-
 .../mock/MockCacheExtensionXmlGenerator.java    |   12 +-
 .../extension/mock/MockExtensionCommands.java   |   34 +-
 .../extension/mock/MockExtensionXmlParser.java  |   12 +-
 .../extension/mock/MockRegionExtension.java     |    8 +-
 .../mock/MockRegionExtensionXmlGenerator.java   |   12 +-
 ...gionFunctionFunctionInvocationException.java |    8 +-
 .../functions/DistributedRegionFunction.java    |   22 +-
 .../cache/functions/LocalDataSetFunction.java   |   20 +-
 .../internal/cache/functions/TestFunction.java  |   60 +-
 .../ha/BlockingHARQAddOperationJUnitTest.java   |   14 +-
 .../cache/ha/BlockingHARQStatsJUnitTest.java    |    6 +-
 .../cache/ha/BlockingHARegionJUnitTest.java     |   20 +-
 .../ha/BlockingHARegionQueueJUnitTest.java      |   10 +-
 .../cache/ha/Bug36853EventsExpiryDUnitTest.java |   48 +-
 .../internal/cache/ha/Bug48571DUnitTest.java    |   52 +-
 .../internal/cache/ha/Bug48879DUnitTest.java    |   42 +-
 .../internal/cache/ha/ConflatableObject.java    |    6 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java  |   68 +-
 .../cache/ha/EventIdOptimizationJUnitTest.java  |    6 +-
 .../internal/cache/ha/FailoverDUnitTest.java    |   60 +-
 .../internal/cache/ha/HABugInPutDUnitTest.java  |   40 +-
 .../internal/cache/ha/HAClearDUnitTest.java     |   56 +-
 .../cache/ha/HAConflationDUnitTest.java         |   50 +-
 .../internal/cache/ha/HADuplicateDUnitTest.java |   50 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java |   74 +-
 .../internal/cache/ha/HAExpiryDUnitTest.java    |   50 +-
 .../internal/cache/ha/HAGIIBugDUnitTest.java    |   56 +-
 .../geode/internal/cache/ha/HAGIIDUnitTest.java |   72 +-
 .../geode/internal/cache/ha/HAHelper.java       |    4 +-
 .../cache/ha/HARQAddOperationJUnitTest.java     |   34 +-
 .../cache/ha/HARQueueNewImplDUnitTest.java      |   62 +-
 .../internal/cache/ha/HARegionDUnitTest.java    |   40 +-
 .../internal/cache/ha/HARegionJUnitTest.java    |   48 +-
 .../cache/ha/HARegionQueueDUnitTest.java        |   54 +-
 .../cache/ha/HARegionQueueJUnitTest.java        |   36 +-
 .../ha/HARegionQueueStartStopJUnitTest.java     |   22 +-
 .../cache/ha/HARegionQueueStatsJUnitTest.java   |   12 +-
 .../cache/ha/HASlowReceiverDUnitTest.java       |   44 +-
 .../ha/OperationsPropagationDUnitTest.java      |   42 +-
 .../internal/cache/ha/PutAllDUnitTest.java      |   58 +-
 .../internal/cache/ha/StatsBugDUnitTest.java    |   42 +-
 .../cache/ha/TestBlockingHARegionQueue.java     |    8 +-
 .../cache/ha/ThreadIdentifierJUnitTest.java     |    6 +-
 .../cache/locks/TXLockServiceDUnitTest.java     |   42 +-
 .../internal/cache/lru/LRUClockJUnitTest.java   |   36 +-
 .../cache/lru/TransactionsWithOverflowTest.java |   10 +-
 .../cache/partitioned/Bug39356DUnitTest.java    |   50 +-
 .../cache/partitioned/Bug43684DUnitTest.java    |   46 +-
 .../cache/partitioned/Bug47388DUnitTest.java    |   54 +-
 .../cache/partitioned/Bug51400DUnitTest.java    |   46 +-
 .../partitioned/ElidedPutAllDUnitTest.java      |   48 +-
 .../FetchEntriesMessageJUnitTest.java           |   26 +-
 .../OfflineMembersDetailsJUnitTest.java         |    8 +-
 .../cache/partitioned/PartitionMessageTest.java |   24 +-
 .../partitioned/PartitionResolverDUnitTest.java |   58 +-
 .../PartitionedRegionLoadModelJUnitTest.java    |   24 +-
 .../PartitionedRegionLoaderWriterDUnitTest.java |   40 +-
 ...rtitionedRegionMetaDataCleanupDUnitTest.java |   32 +-
 .../partitioned/PersistPRKRFDUnitTest.java      |   38 +-
 ...tentColocatedPartitionedRegionDUnitTest.java |   72 +-
 .../PersistentPartitionedRegionDUnitTest.java   |  116 +-
 ...tentPartitionedRegionOldConfigDUnitTest.java |   18 +-
 .../PersistentPartitionedRegionTestBase.java    |   76 +-
 ...rtitionedRegionWithTransactionDUnitTest.java |   30 +-
 .../PutPutReplyMessageJUnitTest.java            |   14 +-
 .../cache/partitioned/ShutdownAllDUnitTest.java |   68 +-
 ...treamingPartitionOperationManyDUnitTest.java |   46 +-
 ...StreamingPartitionOperationOneDUnitTest.java |   48 +-
 .../fixed/CustomerFixedPartitionResolver.java   |   14 +-
 .../fixed/FixedPartitioningDUnitTest.java       |   28 +-
 .../fixed/FixedPartitioningTestBase.java        |  120 +-
 .../FixedPartitioningTestBaseJUnitTest.java     |    4 +-
 ...ngWithColocationAndPersistenceDUnitTest.java |   22 +-
 .../cache/partitioned/fixed/MyDate1.java        |    6 +-
 .../cache/partitioned/fixed/MyDate2.java        |    6 +-
 .../cache/partitioned/fixed/MyDate3.java        |    6 +-
 .../fixed/QuarterPartitionResolver.java         |   18 +-
 .../SingleHopQuarterPartitionResolver.java      |   18 +-
 .../rebalance/BucketOperatorImplTest.java       |   14 +-
 .../rebalance/BucketOperatorWrapperTest.java    |   14 +-
 .../persistence/BackupInspectorJUnitTest.java   |    6 +-
 .../PersistentRVVRecoveryDUnitTest.java         |  104 +-
 .../PersistentRecoveryOrderDUnitTest.java       |  110 +-
 ...rsistentRecoveryOrderOldConfigDUnitTest.java |   28 +-
 .../PersistentReplicatedTestBase.java           |   38 +-
 .../TemporaryResultSetFactoryJUnitTest.java     |   16 +-
 .../RegionEntryFactoryBuilderJUnitTest.java     |    4 +-
 .../GFSnapshotJUnitPerformanceTest.java         |   14 +-
 .../internal/cache/tier/Bug40396DUnitTest.java  |   38 +-
 .../tier/sockets/AcceptorImplJUnitTest.java     |   38 +-
 ...mpatibilityHigherVersionClientDUnitTest.java |   44 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java   |   50 +-
 .../cache/tier/sockets/Bug36457DUnitTest.java   |   50 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java   |   46 +-
 .../cache/tier/sockets/Bug36829DUnitTest.java   |   32 +-
 .../cache/tier/sockets/Bug36995DUnitTest.java   |   42 +-
 .../cache/tier/sockets/Bug37210DUnitTest.java   |   46 +-
 .../cache/tier/sockets/Bug37805DUnitTest.java   |   30 +-
 .../CacheServerMaxConnectionsJUnitTest.java     |   40 +-
 ...heServerSelectorMaxConnectionsJUnitTest.java |    4 +-
 .../cache/tier/sockets/CacheServerTestUtil.java |   66 +-
 .../CacheServerTransactionsDUnitTest.java       |   54 +-
 ...acheServerTransactionsSelectorDUnitTest.java |    8 +-
 .../tier/sockets/ClearPropagationDUnitTest.java |   64 +-
 .../tier/sockets/ClientConflationDUnitTest.java |   62 +-
 .../sockets/ClientHealthMonitorJUnitTest.java   |   44 +-
 .../ClientHealthMonitorSelectorJUnitTest.java   |    4 +-
 .../sockets/ClientInterestNotifyDUnitTest.java  |   60 +-
 .../ClientServerForceInvalidateDUnitTest.java   |   60 +-
 .../tier/sockets/ClientServerMiscDUnitTest.java |   72 +-
 .../ClientServerMiscSelectorDUnitTest.java      |    8 +-
 .../cache/tier/sockets/ConflationDUnitTest.java |   66 +-
 .../tier/sockets/ConnectionProxyJUnitTest.java  |   42 +-
 .../DataSerializerPropogationDUnitTest.java     |   70 +-
 .../cache/tier/sockets/DeltaEOFException.java   |    8 +-
 .../DestroyEntryPropagationDUnitTest.java       |   70 +-
 .../sockets/DurableClientBug39997DUnitTest.java |   40 +-
 .../DurableClientQueueSizeDUnitTest.java        |   46 +-
 .../DurableClientReconnectAutoDUnitTest.java    |   14 +-
 .../DurableClientReconnectDUnitTest.java        |   58 +-
 .../sockets/DurableClientStatsDUnitTest.java    |   44 +-
 .../sockets/DurableRegistrationDUnitTest.java   |   52 +-
 .../sockets/DurableResponseMatrixDUnitTest.java |   56 +-
 .../sockets/EventIDVerificationDUnitTest.java   |   62 +-
 .../EventIDVerificationInP2PDUnitTest.java      |   38 +-
 .../cache/tier/sockets/FaultyDelta.java         |   12 +-
 .../FilterProfileIntegrationJUnitTest.java      |   22 +-
 .../tier/sockets/FilterProfileJUnitTest.java    |   30 +-
 .../ForceInvalidateEvictionDUnitTest.java       |   66 +-
 ...ForceInvalidateOffHeapEvictionDUnitTest.java |   12 +-
 .../cache/tier/sockets/HABug36738DUnitTest.java |   38 +-
 .../sockets/HAInterestDistributedTestCase.java  |    2 +-
 .../tier/sockets/HAInterestPart1DUnitTest.java  |   14 +-
 .../tier/sockets/HAInterestPart2DUnitTest.java  |   26 +-
 .../cache/tier/sockets/HAInterestTestCase.java  |   64 +-
 .../sockets/HAStartupAndFailoverDUnitTest.java  |   60 +-
 .../internal/cache/tier/sockets/HaHelper.java   |    2 +-
 .../InstantiatorPropagationDUnitTest.java       |  108 +-
 .../tier/sockets/InterestListDUnitTest.java     |   78 +-
 .../sockets/InterestListEndpointDUnitTest.java  |   66 +-
 .../InterestListEndpointPRDUnitTest.java        |   10 +-
 .../InterestListEndpointSelectorDUnitTest.java  |    8 +-
 .../sockets/InterestListFailoverDUnitTest.java  |   32 +-
 .../sockets/InterestListRecoveryDUnitTest.java  |   60 +-
 .../sockets/InterestRegrListenerDUnitTest.java  |   50 +-
 .../sockets/InterestResultPolicyDUnitTest.java  |   50 +-
 .../cache/tier/sockets/MessageJUnitTest.java    |    6 +-
 .../sockets/NewRegionAttributesDUnitTest.java   |   30 +-
 .../tier/sockets/ObjectPartListJUnitTest.java   |    8 +-
 .../tier/sockets/RedundancyLevelJUnitTest.java  |   20 +-
 .../sockets/RedundancyLevelPart1DUnitTest.java  |   14 +-
 .../sockets/RedundancyLevelPart2DUnitTest.java  |   14 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java  |   16 +-
 .../tier/sockets/RedundancyLevelTestBase.java   |   62 +-
 .../tier/sockets/RegionCloseDUnitTest.java      |   46 +-
 ...erInterestBeforeRegionCreationDUnitTest.java |   52 +-
 .../sockets/RegisterInterestKeysDUnitTest.java  |   46 +-
 .../RegisterInterestKeysPRDUnitTest.java        |   10 +-
 .../sockets/ReliableMessagingDUnitTest.java     |   64 +-
 .../internal/cache/tier/sockets/TestFilter.java |    6 +-
 .../sockets/UnregisterInterestDUnitTest.java    |   50 +-
 .../sockets/UpdatePropagationDUnitTest.java     |   56 +-
 .../sockets/UpdatePropagationPRDUnitTest.java   |    8 +-
 .../VerifyEventIDGenerationInP2PDUnitTest.java  |   36 +-
 ...UpdatesFromNonInterestEndPointDUnitTest.java |   52 +-
 .../tier/sockets/command/CommitCommandTest.java |   14 +-
 .../tier/sockets/command/ContainsKey66Test.java |   22 +-
 .../tier/sockets/command/ContainsKeyTest.java   |   24 +-
 .../tier/sockets/command/CreateRegionTest.java  |   32 +-
 .../tier/sockets/command/Destroy65Test.java     |   28 +-
 .../tier/sockets/command/DestroyRegionTest.java |   30 +-
 .../cache/tier/sockets/command/DestroyTest.java |   28 +-
 .../sockets/command/ExecuteFunction65Test.java  |   46 +-
 .../sockets/command/ExecuteFunction66Test.java  |   42 +-
 .../sockets/command/ExecuteFunctionTest.java    |   46 +-
 .../cache/tier/sockets/command/Get70Test.java   |   30 +-
 .../tier/sockets/command/GetAll651Test.java     |   32 +-
 .../tier/sockets/command/GetAll70Test.java      |   34 +-
 .../cache/tier/sockets/command/GetAllTest.java  |   32 +-
 .../sockets/command/GetAllWithCallbackTest.java |   34 +-
 ...tClientPartitionAttributesCommand66Test.java |   16 +-
 ...GetClientPartitionAttributesCommandTest.java |   16 +-
 .../tier/sockets/command/InvalidateTest.java    |   34 +-
 .../cache/tier/sockets/command/KeySetTest.java  |   34 +-
 .../cache/tier/sockets/command/Put61Test.java   |   32 +-
 .../cache/tier/sockets/command/Put65Test.java   |   38 +-
 .../cache/tier/sockets/command/PutTest.java     |   32 +-
 .../sockets/command/RegisterInterest61Test.java |   32 +-
 .../command/RegisterInterestList61Test.java     |   32 +-
 .../command/RegisterInterestList66Test.java     |   32 +-
 .../command/RegisterInterestListTest.java       |   32 +-
 .../sockets/command/RegisterInterestTest.java   |   44 +-
 .../tier/sockets/command/RemoveAllTest.java     |   38 +-
 .../cache/tier/sockets/command/RequestTest.java |   28 +-
 .../sockets/command/UnregisterInterestTest.java |   34 +-
 .../cache/tx/AbstractPeerTXRegionStubTest.java  |   30 +-
 .../versions/AbstractVersionTagTestBase.java    |    2 +-
 .../cache/versions/RVVExceptionJUnitTest.java   |    4 +-
 .../versions/RegionVersionHolder2JUnitTest.java |    4 +-
 .../versions/RegionVersionHolderJUnitTest.java  |   10 +-
 .../RegionVersionHolderRandomJUnitTest.java     |    4 +-
 ...RegionVersionHolderSmallBitSetJUnitTest.java |    4 +-
 .../versions/RegionVersionVectorJUnitTest.java  |   18 +-
 .../cache/versions/VMVersionTagTest.java        |    4 +-
 .../cache/wan/AsyncEventQueueTestBase.java      |  122 +-
 .../cache/wan/CustomAsyncEventListener.java     |    6 +-
 .../geode/internal/cache/wan/Filter70.java      |    6 +-
 .../cache/wan/MyAsyncEventListener.java         |   10 +-
 .../cache/wan/MyAsyncEventListener2.java        |    6 +-
 .../cache/wan/MyDistributedSystemListener.java  |   10 +-
 .../cache/wan/MyGatewayEventFilter.java         |    8 +-
 .../cache/wan/MyGatewaySenderEventListener.java |    6 +-
 .../wan/MyGatewaySenderEventListener2.java      |    6 +-
 .../cache/wan/MyGatewayTransportFilter1.java    |    4 +-
 .../cache/wan/MyGatewayTransportFilter2.java    |    4 +-
 .../cache/wan/MyGatewayTransportFilter3.java    |    4 +-
 .../cache/wan/MyGatewayTransportFilter4.java    |    4 +-
 .../geode/internal/cache/wan/QueueListener.java |    8 +-
 .../asyncqueue/AsyncEventListenerDUnitTest.java |   44 +-
 .../AsyncEventListenerOffHeapDUnitTest.java     |    8 +-
 .../AsyncEventQueueStatsDUnitTest.java          |   14 +-
 .../AsyncEventQueueValidationsJUnitTest.java    |   30 +-
 .../ConcurrentAsyncEventQueueDUnitTest.java     |   18 +-
 ...ncurrentAsyncEventQueueOffHeapDUnitTest.java |    8 +-
 .../CommonParallelAsyncEventQueueDUnitTest.java |   14 +-
 ...ParallelAsyncEventQueueOffHeapDUnitTest.java |    8 +-
 .../ParallelGatewaySenderQueueJUnitTest.java    |   22 +-
 ...ialGatewaySenderEventProcessorJUnitTest.java |    8 +-
 .../xmlcache/AbstractEntityResolverTest.java    |    4 +-
 .../xmlcache/AbstractXmlParserJUnitTest.java    |    4 +-
 .../cache/xmlcache/CacheCreationJUnitTest.java  |   18 +-
 .../cache/xmlcache/CacheXmlParserJUnitTest.java |    8 +-
 .../xmlcache/CacheXmlVersionJUnitTest.java      |    6 +-
 .../xmlcache/GeodeEntityResolverJUnitTest.java  |    4 +-
 .../PivotalEntityResolverJUnitTest.java         |    4 +-
 .../cache/xmlcache/RegionCreationJUnitTest.java |   12 +-
 .../xmlcache/XmlGeneratorUtilsJUnitTest.java    |    4 +-
 .../classpathloaderjunittest/DoesExist.java     |    2 +-
 .../CompressionCacheConfigDUnitTest.java        |   30 +-
 .../CompressionCacheListenerDUnitTest.java      |   38 +-
 ...ompressionCacheListenerOffHeapDUnitTest.java |   14 +-
 .../CompressionRegionConfigDUnitTest.java       |   44 +-
 .../CompressionRegionFactoryDUnitTest.java      |   26 +-
 .../CompressionRegionOperationsDUnitTest.java   |   26 +-
 ...ressionRegionOperationsOffHeapDUnitTest.java |   16 +-
 .../compression/CompressionStatsDUnitTest.java  |   30 +-
 .../compression/SnappyCompressorJUnitTest.java  |    8 +-
 .../datasource/AbstractPoolCacheJUnitTest.java  |   20 +-
 .../internal/datasource/CleanUpJUnitTest.java   |   14 +-
 .../ConnectionPoolCacheImplJUnitTest.java       |   14 +-
 .../datasource/ConnectionPoolingJUnitTest.java  |   16 +-
 .../datasource/DataSourceFactoryJUnitTest.java  |   14 +-
 .../internal/datasource/RestartJUnitTest.java   |   18 +-
 .../geode/internal/i18n/BasicI18nJUnitTest.java |   10 +-
 .../io/CompositeOutputStreamJUnitTest.java      |    4 +-
 .../geode/internal/jndi/ContextJUnitTest.java   |    6 +-
 .../internal/jta/BlockingTimeOutJUnitTest.java  |   18 +-
 .../apache/geode/internal/jta/CacheUtils.java   |   18 +-
 .../internal/jta/DataSourceJTAJUnitTest.java    |   18 +-
 .../geode/internal/jta/ExceptionJUnitTest.java  |    8 +-
 .../jta/GlobalTransactionJUnitTest.java         |   18 +-
 .../org/apache/geode/internal/jta/JTAUtils.java |   10 +-
 .../internal/jta/JtaIntegrationJUnitTest.java   |   14 +-
 .../org/apache/geode/internal/jta/SyncImpl.java |    2 +-
 .../internal/jta/TransactionImplJUnitTest.java  |    8 +-
 .../jta/TransactionManagerImplJUnitTest.java    |    8 +-
 .../jta/TransactionTimeOutJUnitTest.java        |   16 +-
 .../jta/UserTransactionImplJUnitTest.java       |    8 +-
 .../geode/internal/jta/dunit/CommitThread.java  |    8 +-
 .../internal/jta/dunit/ExceptionsDUnitTest.java |   26 +-
 .../jta/dunit/IdleTimeOutDUnitTest.java         |   32 +-
 .../jta/dunit/LoginTimeOutDUnitTest.java        |   38 +-
 .../jta/dunit/MaxPoolSizeDUnitTest.java         |   34 +-
 .../internal/jta/dunit/RollbackThread.java      |    8 +-
 .../jta/dunit/TransactionTimeOutDUnitTest.java  |   38 +-
 .../dunit/TxnManagerMultiThreadDUnitTest.java   |   38 +-
 .../internal/jta/dunit/TxnTimeOutDUnitTest.java |   34 +-
 .../internal/jta/functional/CacheJUnitTest.java |   58 +-
 .../jta/functional/TestXACacheLoader.java       |    8 +-
 .../internal/lang/ClassUtilsJUnitTest.java      |    6 +-
 .../internal/lang/InOutParameterJUnitTest.java  |    6 +-
 .../internal/lang/InitializerJUnitTest.java     |    6 +-
 .../internal/lang/ObjectUtilsJUnitTest.java     |    6 +-
 .../internal/lang/StringUtilsJUnitTest.java     |   12 +-
 .../internal/lang/SystemUtilsJUnitTest.java     |    6 +-
 .../internal/lang/ThreadUtilsJUnitTest.java     |    6 +-
 .../geode/internal/lang/ThrowableUtilsTest.java |    4 +-
 .../DistributedSystemLogFileJUnitTest.java      |   22 +-
 .../logging/LocatorLogFileJUnitTest.java        |   20 +-
 .../logging/LogServiceIntegrationJUnitTest.java |    8 +-
 .../LogServiceIntegrationTestSupport.java       |    2 +-
 .../internal/logging/LogServiceJUnitTest.java   |    8 +-
 .../LogWriterDisabledPerformanceTest.java       |    6 +-
 .../logging/LogWriterImplJUnitTest.java         |    4 +-
 .../logging/LogWriterPerformanceTest.java       |   14 +-
 .../logging/LoggingIntegrationTestSuite.java    |    6 +-
 .../logging/LoggingPerformanceTestCase.java     |    6 +-
 .../internal/logging/LoggingUnitTestSuite.java  |   14 +-
 .../logging/MergeLogFilesJUnitTest.java         |   10 +-
 .../geode/internal/logging/NullLogWriter.java   |    6 +-
 .../internal/logging/SortLogFileJUnitTest.java  |    6 +-
 .../internal/logging/TestLogWriterFactory.java  |   20 +-
 .../logging/log4j/AlertAppenderJUnitTest.java   |   14 +-
 .../logging/log4j/ConfigLocatorJUnitTest.java   |    4 +-
 .../log4j/FastLoggerIntegrationJUnitTest.java   |    6 +-
 .../logging/log4j/FastLoggerJUnitTest.java      |    4 +-
 .../FastLoggerWithDefaultConfigJUnitTest.java   |    8 +-
 .../log4j/LocalizedMessageJUnitTest.java        |    6 +-
 .../log4j/Log4J2DisabledPerformanceTest.java    |    4 +-
 .../logging/log4j/Log4J2PerformanceTest.java    |   14 +-
 .../log4j/Log4jIntegrationTestSuite.java        |    2 +-
 .../logging/log4j/Log4jUnitTestSuite.java       |    2 +-
 .../log4j/LogWriterAppenderJUnitTest.java       |   16 +-
 .../LogWriterLoggerDisabledPerformanceTest.java |    4 +-
 .../log4j/LogWriterLoggerPerformanceTest.java   |   14 +-
 .../logging/log4j/custom/BasicAppender.java     |    2 +-
 .../CustomConfigWithCacheIntegrationTest.java   |   20 +-
 ...stomConfigWithLogServiceIntegrationTest.java |   10 +-
 .../log4j/custom/CustomConfiguration.java       |    2 +-
 .../internal/net/SocketUtilsJUnitTest.java      |    6 +-
 .../offheap/AbstractStoredObjectTestBase.java   |    4 +-
 .../internal/offheap/DataTypeJUnitTest.java     |   58 +-
 ...tingOutOfOffHeapMemoryListenerJUnitTest.java |   12 +-
 .../internal/offheap/FragmentJUnitTest.java     |    4 +-
 .../internal/offheap/FreeListManagerTest.java   |    6 +-
 .../offheap/FreeListOffHeapRegionJUnitTest.java |    6 +-
 .../internal/offheap/InlineKeyJUnitTest.java    |   20 +-
 .../offheap/LifecycleListenerJUnitTest.java     |    4 +-
 ...moryAllocatorFillPatternIntegrationTest.java |    6 +-
 .../MemoryAllocatorFillPatternJUnitTest.java    |    6 +-
 .../offheap/MemoryAllocatorJUnitTest.java       |    8 +-
 .../offheap/MemoryBlockNodeJUnitTest.java       |   14 +-
 .../offheap/MemoryInspectorImplJUnitTest.java   |    4 +-
 .../offheap/NullOffHeapMemoryStats.java         |    4 +-
 .../offheap/NullOutOfOffHeapMemoryListener.java |    4 +-
 .../offheap/OffHeapHelperJUnitTest.java         |    8 +-
 .../internal/offheap/OffHeapIndexJUnitTest.java |   18 +-
 .../internal/offheap/OffHeapRegionBase.java     |   42 +-
 .../OffHeapRegionEntryHelperJUnitTest.java      |   26 +-
 .../offheap/OffHeapStorageJUnitTest.java        |   22 +-
 ...ffHeapStoredObjectAddressStackJUnitTest.java |    4 +-
 .../offheap/OffHeapStoredObjectJUnitTest.java   |   22 +-
 .../OffHeapStoredObjectSliceJUnitTest.java      |    4 +-
 ...ffHeapStoredObjectWithHeapFormJUnitTest.java |    4 +-
 .../offheap/OffHeapValidationJUnitTest.java     |   28 +-
 .../OffHeapWriteObjectAsByteArrayJUnitTest.java |   10 +-
 .../OldFreeListOffHeapRegionJUnitTest.java      |    6 +-
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    |   40 +-
 .../offheap/RefCountChangeInfoJUnitTest.java    |    4 +-
 .../offheap/ReferenceCountHelperImplTest.java   |    6 +-
 .../offheap/ReferenceCountHelperJUnitTest.java  |    4 +-
 .../internal/offheap/StoredObjectTestSuite.java |    2 +-
 .../offheap/TinyMemoryBlockJUnitTest.java       |    8 +-
 .../offheap/TinyStoredObjectJUnitTest.java      |   14 +-
 .../TxReleasesOffHeapOnCloseJUnitTest.java      |   12 +-
 .../BlockingProcessStreamReaderJUnitTest.java   |   10 +-
 ...leProcessControllerIntegrationJUnitTest.java |   12 +-
 .../LocalProcessControllerJUnitTest.java        |    6 +-
 .../process/LocalProcessLauncherDUnitTest.java  |   10 +-
 .../process/LocalProcessLauncherJUnitTest.java  |    6 +-
 ...NonBlockingProcessStreamReaderJUnitTest.java |    8 +-
 .../internal/process/PidFileJUnitTest.java      |    8 +-
 .../ProcessControllerFactoryJUnitTest.java      |    4 +-
 .../process/ProcessStreamReaderTestCase.java    |    4 +-
 .../geode/internal/process/mbean/Process.java   |    2 +-
 .../internal/process/mbean/ProcessMBean.java    |    2 +-
 ...tractSignalNotificationHandlerJUnitTest.java |   14 +-
 .../security/GeodeSecurityUtilTest.java         |    8 +-
 .../security/SecurityConfigIntegrationTest.java |   10 +-
 .../internal/size/ObjectSizerJUnitTest.java     |    6 +-
 .../internal/size/ObjectTraverserJUnitTest.java |    8 +-
 .../internal/size/ObjectTraverserPerf.java      |   10 +-
 .../size/ReflectionObjectSizerJUnitTest.java    |    8 +-
 .../size/SizeClassOnceObjectSizerJUnitTest.java |    8 +-
 .../geode/internal/size/SizeTestUtil.java       |    2 +-
 .../size/WellKnownClassSizerJUnitTest.java      |    8 +-
 .../statistics/CallbackSamplerTest.java         |    6 +-
 ...tributedSystemStatisticsIntegrationTest.java |   16 +-
 ...utedSystemStatisticsTypeIntegrationTest.java |   14 +-
 .../GemFireStatSamplerIntegrationTest.java      |   34 +-
 .../internal/statistics/ResourceInstTest.java   |   10 +-
 .../statistics/SampleCollectorTest.java         |   20 +-
 .../SimpleStatSamplerIntegrationTest.java       |   14 +-
 ...iveWithConsecutiveResourceInstGenerator.java |   18 +-
 ...ithConsecutiveResourceInstGeneratorTest.java |    6 +-
 ...hConsecutiveResourceInstIntegrationTest.java |   12 +-
 .../StatArchiveWriterReaderIntegrationTest.java |   20 +-
 .../statistics/StatMonitorHandlerTest.java      |   10 +-
 .../statistics/StatSamplerIntegrationTest.java  |   16 +-
 .../statistics/StatSamplerTestCase.java         |   10 +-
 .../geode/internal/statistics/StatUtils.java    |    8 +-
 .../statistics/StatisticsDistributedTest.java   |   62 +-
 .../internal/statistics/StatisticsImplTest.java |    4 +-
 .../statistics/StatisticsMonitorTest.java       |    6 +-
 .../internal/statistics/TestSampleHandler.java  |    2 +-
 .../statistics/TestStatArchiveWriter.java       |    2 +-
 .../statistics/TestStatisticsManager.java       |    8 +-
 .../statistics/TestStatisticsSampler.java       |    4 +-
 .../statistics/ValueMonitorIntegrationTest.java |   18 +-
 .../internal/stats50/AtomicStatsJUnitTest.java  |   18 +-
 .../geode/internal/tcp/ConnectionJUnitTest.java |   16 +-
 .../util/AbortableTaskServiceJUnitTest.java     |    6 +-
 .../internal/util/ArrayUtilsJUnitTest.java      |    4 +-
 .../geode/internal/util/BlobHelperTest.java     |   16 +-
 ...bHelperWithThreadContextClassLoaderTest.java |   10 +-
 .../geode/internal/util/BytesJUnitTest.java     |    4 +-
 .../internal/util/CollectionUtilsJUnitTest.java |   10 +-
 .../internal/util/DelayedActionJUnitTest.java   |    4 +-
 .../geode/internal/util/HostNameTest.java       |    8 +-
 .../geode/internal/util/IOUtilsJUnitTest.java   |    6 +-
 .../apache/geode/internal/util/Valuable.java    |    2 +-
 .../CompactConcurrentHashSetJUnitTest.java      |    6 +-
 .../ConcurrentHashMapIteratorJUnitTest.java     |    8 +-
 .../concurrent/CopyOnWriteHashMapJUnitTest.java |    8 +-
 .../concurrent/ReentrantSemaphoreJUnitTest.java |    4 +-
 .../SemaphoreReadWriteLockJUnitTest.java        |    4 +-
 .../cm/ConcurrentHashMapJUnitTest.java          |    8 +-
 .../concurrent/cm/CountedMapLoopsJUnitTest.java |    6 +-
 .../concurrent/cm/IntMapCheckJUnitTest.java     |    6 +-
 .../util/concurrent/cm/LoopHelpers.java         |    2 +-
 .../util/concurrent/cm/MapCheckJUnitTest.java   |    6 +-
 .../util/concurrent/cm/MapLoopsJUnitTest.java   |    6 +-
 .../util/concurrent/cm/RLJBarJUnitTest.java     |    6 +-
 .../concurrent/cm/StringMapLoopsJUnitTest.java  |    6 +-
 .../management/CacheManagementDUnitTest.java    |   44 +-
 .../management/ClientHealthStatsDUnitTest.java  |   50 +-
 .../apache/geode/management/CompositeStats.java |    2 +-
 .../geode/management/CompositeTestMBean.java    |    2 +-
 .../geode/management/CompositeTestMXBean.java   |    2 +-
 .../management/CompositeTypeTestDUnitTest.java  |   24 +-
 .../ConnectToLocatorSSLDUnitTest.java           |   34 +-
 .../apache/geode/management/CustomMBean.java    |    2 +-
 .../apache/geode/management/CustomMXBean.java   |    2 +-
 .../management/DLockManagementDUnitTest.java    |   38 +-
 .../DataBrowserJSONValidationJUnitTest.java     |   42 +-
 .../management/DiskManagementDUnitTest.java     |   88 +-
 .../management/DistributedSystemDUnitTest.java  |   54 +-
 .../management/LocatorManagementDUnitTest.java  |   34 +-
 .../org/apache/geode/management/MBeanUtil.java  |   20 +-
 .../geode/management/ManagementTestBase.java    |   68 +-
 .../MemberMBeanAttributesDUnitTest.java         |   30 +-
 .../management/OffHeapManagementDUnitTest.java  |   42 +-
 .../geode/management/QueryDataDUnitTest.java    |   78 +-
 .../RegionCreateDestroyDUnitTest.java           |   32 +-
 .../management/RegionManagementDUnitTest.java   |   58 +-
 .../geode/management/TypedJsonJUnitTest.java    |   32 +-
 ...ersalMembershipListenerAdapterDUnitTest.java |   70 +-
 .../stats/AsyncEventQueueStatsJUnitTest.java    |    8 +-
 .../bean/stats/CacheServerStatsJUnitTest.java   |   10 +-
 .../bean/stats/DiskStatsJUnitTest.java          |   10 +-
 .../stats/DistributedSystemStatsDUnitTest.java  |   32 +-
 .../stats/DistributedSystemStatsJUnitTest.java  |   28 +-
 .../bean/stats/GatewayMBeanBridgeJUnitTest.java |   12 +-
 .../stats/GatewayReceiverStatsJUnitTest.java    |   10 +-
 .../bean/stats/MBeanStatsTestCase.java          |   14 +-
 .../bean/stats/MemberLevelStatsJUnitTest.java   |   30 +-
 .../bean/stats/RegionStatsJUnitTest.java        |   16 +-
 .../bean/stats/StatsRateJUnitTest.java          |   12 +-
 .../internal/JettyHelperJUnitTest.java          |    6 +-
 .../beans/DistributedSystemBridgeJUnitTest.java |   22 +-
 .../AbstractCliAroundInterceptorJUnitTest.java  |    8 +-
 .../cli/ClasspathScanLoadHelperJUnitTest.java   |   22 +-
 .../internal/cli/CliUtilDUnitTest.java          |   56 +-
 .../internal/cli/CommandManagerJUnitTest.java   |   22 +-
 .../internal/cli/CommandRequestTest.java        |    4 +-
 .../cli/CommandSeparatorEscapeJUnitTest.java    |    6 +-
 .../internal/cli/DataCommandJsonJUnitTest.java  |    8 +-
 .../internal/cli/GfshParserIntegrationTest.java |    4 +-
 .../internal/cli/GfshParserJUnitTest.java       |   26 +-
 .../management/internal/cli/HeadlessGfsh.java   |    8 +-
 .../cli/HeadlessGfshIntegrationTest.java        |   16 +-
 .../internal/cli/JoptOptionParserTest.java      |   18 +-
 .../management/internal/cli/ResultHandler.java  |    2 +-
 .../internal/cli/TableBuilderJUnitTest.java     |   16 +-
 .../cli/annotations/CliArgumentJUnitTest.java   |    6 +-
 .../AbstractCommandsSupportJUnitTest.java       |   26 +-
 .../cli/commands/CliCommandTestBase.java        |   36 +-
 .../cli/commands/ConfigCommandsDUnitTest.java   |   54 +-
 ...eateAlterDestroyRegionCommandsDUnitTest.java |   76 +-
 .../cli/commands/DeployCommandsDUnitTest.java   |   36 +-
 .../commands/DiskStoreCommandsDUnitTest.java    |   64 +-
 .../commands/DiskStoreCommandsJUnitTest.java    |   38 +-
 .../cli/commands/FunctionCommandsDUnitTest.java |   46 +-
 .../commands/GemfireDataCommandsDUnitTest.java  |  102 +-
 ...WithCacheLoaderDuringCacheMissDUnitTest.java |   50 +-
 .../HTTPServiceSSLSupportJUnitTest.java         |   12 +-
 .../commands/HelpCommandsIntegrationTest.java   |   26 +-
 .../cli/commands/IndexCommandsDUnitTest.java    |   38 +-
 .../cli/commands/IndexCommandsJUnitTest.java    |   28 +-
 ...stAndDescribeDiskStoreCommandsDUnitTest.java |   36 +-
 .../ListAndDescribeRegionDUnitTest.java         |   42 +-
 .../cli/commands/ListIndexCommandDUnitTest.java |   48 +-
 .../cli/commands/MemberCommandsDUnitTest.java   |   44 +-
 .../MiscellaneousCommandsDUnitTest.java         |   44 +-
 ...laneousCommandsExportLogsPart1DUnitTest.java |   30 +-
 ...laneousCommandsExportLogsPart2DUnitTest.java |   30 +-
 ...laneousCommandsExportLogsPart3DUnitTest.java |   38 +-
 ...laneousCommandsExportLogsPart4DUnitTest.java |   30 +-
 .../cli/commands/QueueCommandsDUnitTest.java    |   64 +-
 .../SharedConfigurationCommandsDUnitTest.java   |   60 +-
 .../cli/commands/ShellCommandsDUnitTest.java    |   38 +-
 .../cli/commands/ShowDeadlockDUnitTest.java     |   56 +-
 .../cli/commands/ShowMetricsDUnitTest.java      |   44 +-
 .../cli/commands/ShowStackTraceDUnitTest.java   |   32 +-
 .../cli/commands/ToUpperResultCollector.java    |    8 +-
 .../cli/commands/UserCommandsDUnitTest.java     |   34 +-
 .../RegionPathConverterJUnitTest.java           |    4 +-
 .../internal/cli/domain/AbstractImpl.java       |    2 +-
 .../management/internal/cli/domain/Impl1.java   |    2 +-
 .../management/internal/cli/domain/Impl12.java  |    2 +-
 .../internal/cli/domain/Interface1.java         |    2 +-
 .../internal/cli/domain/Interface2.java         |    2 +-
 .../management/internal/cli/domain/Stock.java   |    2 +-
 .../geode/management/internal/cli/dto/Car.java  |    2 +-
 .../geode/management/internal/cli/dto/Key1.java |    2 +-
 .../geode/management/internal/cli/dto/Key2.java |    2 +-
 .../internal/cli/dto/ObjectWithCharAttr.java    |    2 +-
 .../management/internal/cli/dto/Value1.java     |    2 +-
 .../management/internal/cli/dto/Value2.java     |    2 +-
 .../functions/DataCommandFunctionJUnitTest.java |   10 +-
 .../DescribeDiskStoreFunctionJUnitTest.java     |   52 +-
 .../ListDiskStoresFunctionJUnitTest.java        |   26 +-
 .../functions/ListIndexFunctionJUnitTest.java   |   36 +-
 .../cli/parser/ParserUtilsJUnitTest.java        |    4 +-
 .../preprocessor/PreprocessorJUnitTest.java     |    4 +-
 .../PreprocessorUtilsJUnitTest.java             |    6 +-
 .../cli/shell/GfshConfigInitFileJUnitTest.java  |    4 +-
 .../shell/GfshExecutionStrategyJUnitTest.java   |   20 +-
 .../cli/shell/GfshHistoryJUnitTest.java         |    4 +-
 .../cli/shell/GfshInitFileJUnitTest.java        |    6 +-
 .../cli/util/CommentSkipHelperTest.java         |    4 +-
 .../internal/cli/util/HyphenFormatterTest.java  |    4 +-
 .../SharedConfigurationDUnitTest.java           |   58 +-
 .../SharedConfigurationTestUtils.java           |   10 +-
 .../SharedConfigurationUsingDirDUnitTest.java   |   28 +-
 .../configuration/ZipUtilsJUnitTest.java        |    6 +-
 .../domain/CacheElementJUnitTest.java           |   14 +-
 .../utils/XmlUtilsAddNewNodeJUnitTest.java      |   24 +-
 .../configuration/utils/XmlUtilsJUnitTest.java  |   20 +-
 .../internal/pulse/TestClientIdsDUnitTest.java  |   62 +-
 .../internal/pulse/TestFunctionsDUnitTest.java  |   36 +-
 .../internal/pulse/TestHeapDUnitTest.java       |   24 +-
 .../internal/pulse/TestLocatorsDUnitTest.java   |   20 +-
 .../pulse/TestSubscriptionsDUnitTest.java       |   60 +-
 .../security/AccessControlMBeanJUnitTest.java   |   10 +-
 ...CacheServerMBeanAuthenticationJUnitTest.java |   10 +-
 .../CacheServerMBeanAuthorizationJUnitTest.java |   12 +-
 .../CacheServerMBeanShiroJUnitTest.java         |   10 +-
 .../security/CliCommandsSecurityTest.java       |   16 +-
 .../security/DataCommandsSecurityTest.java      |   14 +-
 .../DiskStoreMXBeanSecurityJUnitTest.java       |   12 +-
 .../GatewayReceiverMBeanSecurityTest.java       |   14 +-
 .../GatewaySenderMBeanSecurityTest.java         |   16 +-
 .../GeodeSecurityUtilCustomRealmJUnitTest.java  |   14 +-
 .../GeodeSecurityUtilWithIniFileJUnitTest.java  |   16 +-
 .../security/GfshCommandsPostProcessorTest.java |   14 +-
 .../security/GfshCommandsSecurityTest.java      |   22 +-
 .../security/GfshShellConnectionRule.java       |   18 +-
 .../security/JMXConnectionConfiguration.java    |    2 +-
 .../JsonAuthorizationCacheStartRule.java        |    8 +-
 .../LockServiceMBeanAuthorizationJUnitTest.java |   18 +-
 .../security/MBeanSecurityJUnitTest.java        |   18 +-
 .../security/MBeanServerConnectionRule.java     |    4 +-
 .../ManagerMBeanAuthorizationJUnitTest.java     |   14 +-
 .../security/MemberMBeanSecurityJUnitTest.java  |   12 +-
 .../internal/security/MultiUserDUnitTest.java   |   32 +-
 .../security/ResourcePermissionTest.java        |    6 +-
 .../internal/security/ShiroCacheStartRule.java  |    8 +-
 .../internal/security/TestCommand.java          |    4 +-
 .../ReadOpFileAccessControllerJUnitTest.java    |   18 +-
 .../WanCommandsControllerJUnitTest.java         |    6 +-
 .../geode/management/model/EmptyObject.java     |    2 +-
 .../org/apache/geode/management/model/Item.java |    2 +-
 .../apache/geode/management/model/Order.java    |    2 +-
 .../apache/geode/management/model/SubOrder.java |    2 +-
 .../DomainObjectsAsValuesJUnitTest.java         |   10 +-
 .../GemcachedBinaryClientJUnitTest.java         |   24 +-
 .../GemcachedDevelopmentJUnitTest.java          |   14 +-
 .../geode/memcached/IntegrationJUnitTest.java   |   12 +-
 .../geode/pdx/AutoSerializableJUnitTest.java    |   82 +-
 .../apache/geode/pdx/ByteSourceJUnitTest.java   |   12 +-
 .../ClientsWithVersioningRetryDUnitTest.java    |   90 +-
 .../java/org/apache/geode/pdx/DSInsidePdx.java  |    4 +-
 .../geode/pdx/DistributedSystemIdDUnitTest.java |   22 +-
 .../java/org/apache/geode/pdx/DomainObject.java |    4 +-
 .../org/apache/geode/pdx/DomainObjectBad.java   |    2 +-
 .../geode/pdx/DomainObjectClassLoadable.java    |    2 +-
 .../apache/geode/pdx/DomainObjectPdxAuto.java   |    2 +-
 ...DomainObjectPdxAutoNoDefaultConstructor.java |    2 +-
 .../java/org/apache/geode/pdx/Employee.java     |    2 +-
 .../geode/pdx/JSONFormatterJUnitTest.java       |   26 +-
 .../geode/pdx/JSONPdxClientServerDUnitTest.java |   48 +-
 .../java/org/apache/geode/pdx/NestedPdx.java    |    2 +-
 .../apache/geode/pdx/NonDelegatingLoader.java   |    6 +-
 .../OffHeapByteBufferByteSourceJUnitTest.java   |   14 +-
 .../geode/pdx/OffHeapByteSourceJUnitTest.java   |   22 +-
 .../geode/pdx/PDXAsyncEventQueueDUnitTest.java  |   38 +-
 .../geode/pdx/PdxAttributesJUnitTest.java       |   28 +-
 .../geode/pdx/PdxClientServerDUnitTest.java     |   62 +-
 .../geode/pdx/PdxDeserializationDUnitTest.java  |   62 +-
 .../java/org/apache/geode/pdx/PdxInsideDS.java  |    8 +-
 .../geode/pdx/PdxInstanceFactoryJUnitTest.java  |   26 +-
 .../apache/geode/pdx/PdxInstanceJUnitTest.java  |   20 +-
 .../geode/pdx/PdxSerializableDUnitTest.java     |   48 +-
 .../geode/pdx/PdxSerializableJUnitTest.java     |   58 +-
 .../apache/geode/pdx/PdxStringJUnitTest.java    |   16 +-
 .../geode/pdx/PdxTypeExportDUnitTest.java       |   42 +-
 .../geode/pdx/SeparateClassloaderPdx.java       |    2 +-
 .../java/org/apache/geode/pdx/SimpleClass.java  |    2 +-
 .../java/org/apache/geode/pdx/SimpleClass1.java |    2 +-
 .../java/org/apache/geode/pdx/SimpleClass2.java |    2 +-
 .../geode/pdx/TestObjectForJSONFormatter.java   |    6 +-
 .../org/apache/geode/redis/AuthJUnitTest.java   |   14 +-
 .../apache/geode/redis/ConcurrentStartTest.java |   16 +-
 .../org/apache/geode/redis/HashesJUnitTest.java |   10 +-
 .../org/apache/geode/redis/ListsJUnitTest.java  |   10 +-
 .../apache/geode/redis/RedisDistDUnitTest.java  |   30 +-
 .../org/apache/geode/redis/SetsJUnitTest.java   |   10 +-
 .../apache/geode/redis/SortedSetsJUnitTest.java |   10 +-
 .../apache/geode/redis/StringsJunitTest.java    |   10 +-
 .../security/AbstractSecureServerDUnitTest.java |   32 +-
 .../security/ClientAuthenticationDUnitTest.java |    8 +-
 .../ClientAuthenticationPart2DUnitTest.java     |    6 +-
 .../security/ClientAuthenticationTestCase.java  |   38 +-
 .../security/ClientAuthenticationTestUtils.java |    8 +-
 .../security/ClientAuthorizationDUnitTest.java  |   34 +-
 .../security/ClientAuthorizationTestCase.java   |   74 +-
 .../security/ClientMultiUserAuthzDUnitTest.java |   28 +-
 .../DeltaClientAuthorizationDUnitTest.java      |   26 +-
 .../DeltaClientPostAuthorizationDUnitTest.java  |   28 +-
 .../security/GemFireSecurityExceptionTest.java  |    6 +-
 .../security/IntegratedClientAuthDUnitTest.java |   16 +-
 ...tedClientContainsKeyAuthDistributedTest.java |   12 +-
 ...entDestroyInvalidateAuthDistributedTest.java |   16 +-
 ...dClientDestroyRegionAuthDistributedTest.java |   14 +-
 ...lientExecuteFunctionAuthDistributedTest.java |   16 +-
 ...xecuteRegionFunctionAuthDistributedTest.java |   16 +-
 ...tegratedClientGetAllAuthDistributedTest.java |   12 +-
 ...tGetClientPRMetaDataAuthDistributedTest.java |   20 +-
 ...ientPartitionAttrCmdAuthDistributedTest.java |   12 +-
 ...gratedClientGetEntryAuthDistributedTest.java |   18 +-
 ...tegratedClientGetPutAuthDistributedTest.java |   14 +-
 ...tedClientRegionClearAuthDistributedTest.java |   16 +-
 ...ientRegisterInterestAuthDistributedTest.java |   16 +-
 ...ratedClientRemoveAllAuthDistributedTest.java |   16 +-
 ...IntegratedClientSizeAuthDistributedTest.java |   14 +-
 ...ntUnregisterInterestAuthDistributedTest.java |   16 +-
 ...edSecurityCacheLifecycleDistributedTest.java |   34 +-
 ...edSecurityCacheLifecycleIntegrationTest.java |   16 +-
 ...tegratedSecurityPeerAuthDistributedTest.java |   32 +-
 .../security/NoShowValue1PostProcessor.java     |    2 +-
 .../NoShowValue1PostProcessorDUnitTest.java     |   16 +-
 .../security/NotAuthorizedExceptionTest.java    |    6 +-
 .../security/P2PAuthenticationDUnitTest.java    |   58 +-
 .../PDXGfshPostProcessorOnRemoteServerTest.java |   54 +-
 .../apache/geode/security/PDXPostProcessor.java |    6 +-
 .../security/PDXPostProcessorDUnitTest.java     |   46 +-
 .../geode/security/PostProcessorDUnitTest.java  |   26 +-
 .../geode/security/SecurityTestUtils.java       |   88 +-
 .../geode/security/SpySecurityManager.java      |    2 +-
 .../generator/AuthzCredentialGenerator.java     |   12 +-
 .../security/generator/CredentialGenerator.java |   14 +-
 .../DummyAuthzCredentialGenerator.java          |    8 +-
 .../generator/DummyCredentialGenerator.java     |    6 +-
 .../generator/LdapUserCredentialGenerator.java  |   20 +-
 .../generator/PKCSCredentialGenerator.java      |   12 +-
 .../generator/SSLCredentialGenerator.java       |    8 +-
 .../UserPasswordWithExtraPropsAuthInit.java     |   12 +-
 .../generator/XmlAuthzCredentialGenerator.java  |   12 +-
 .../security/templates/DummyAuthenticator.java  |   10 +-
 .../security/templates/DummyAuthorization.java  |   16 +-
 .../templates/FunctionSecurityPrmsHolder.java   |    2 +-
 .../templates/LdapUserAuthenticator.java        |   12 +-
 .../geode/security/templates/PKCSAuthInit.java  |   14 +-
 .../security/templates/PKCSAuthenticator.java   |   12 +-
 .../geode/security/templates/PKCSPrincipal.java |    2 +-
 .../security/templates/PKCSPrincipalTest.java   |    6 +-
 .../templates/SampleSecurityManagerTest.java    |    4 +-
 .../templates/UserPasswordAuthInit.java         |   12 +-
 .../security/templates/UsernamePrincipal.java   |    2 +-
 .../templates/UsernamePrincipalTest.java        |    6 +-
 .../security/templates/XmlAuthorization.java    |   22 +-
 .../security/templates/XmlErrorHandler.java     |    6 +-
 .../org/apache/geode/test/dunit/Assert.java     |    4 +-
 .../geode/test/dunit/AsyncInvocation.java       |    4 +-
 .../org/apache/geode/test/dunit/DUnitEnv.java   |    4 +-
 .../apache/geode/test/dunit/DebuggerUtils.java  |    8 +-
 .../geode/test/dunit/DistributedTestCase.java   |    6 +-
 .../geode/test/dunit/DistributedTestUtils.java  |   16 +-
 .../java/org/apache/geode/test/dunit/Host.java  |    4 +-
 .../geode/test/dunit/IgnoredException.java      |   10 +-
 .../org/apache/geode/test/dunit/Invoke.java     |    4 +-
 .../org/apache/geode/test/dunit/Jitter.java     |    2 +-
 .../apache/geode/test/dunit/LogWriterUtils.java |   22 +-
 .../apache/geode/test/dunit/NamedCallable.java  |    2 +-
 .../apache/geode/test/dunit/NamedRunnable.java  |    2 +-
 .../apache/geode/test/dunit/NetworkUtils.java   |    8 +-
 .../apache/geode/test/dunit/RMIException.java   |    4 +-
 .../geode/test/dunit/RepeatableRunnable.java    |    2 +-
 .../geode/test/dunit/SerializableCallable.java  |    2 +-
 .../test/dunit/SerializableCallableIF.java      |    2 +-
 .../geode/test/dunit/SerializableRunnable.java  |    2 +-
 .../test/dunit/SerializableRunnableIF.java      |    2 +-
 .../test/dunit/StoppableWaitCriterion.java      |    2 +-
 .../apache/geode/test/dunit/ThreadUtils.java    |   14 +-
 .../java/org/apache/geode/test/dunit/VM.java    |   10 +-
 .../java/org/apache/geode/test/dunit/Wait.java  |   10 +-
 .../apache/geode/test/dunit/WaitCriterion.java  |    2 +-
 .../dunit/cache/internal/CacheTestFixture.java  |    4 +-
 .../cache/internal/JUnit3CacheTestCase.java     |   28 +-
 .../cache/internal/JUnit4CacheTestCase.java     |   70 +-
 .../dunit/internal/DistributedTestFixture.java  |    2 +-
 .../internal/JUnit3DistributedTestCase.java     |   12 +-
 .../internal/JUnit4DistributedTestCase.java     |   72 +-
 .../dunit/rules/DistributedDisconnectRule.java  |    6 +-
 .../rules/DistributedExternalResource.java      |    4 +-
 .../DistributedRestoreSystemProperties.java     |    6 +-
 .../rules/LocatorServerConfigurationRule.java   |   28 +-
 .../geode/test/dunit/rules/RemoteInvoker.java   |    6 +-
 .../test/dunit/standalone/BounceResult.java     |    2 +-
 .../geode/test/dunit/standalone/ChildVM.java    |    8 +-
 .../test/dunit/standalone/DUnitLauncher.java    |   24 +-
 .../test/dunit/standalone/ProcessManager.java   |   10 +-
 .../test/dunit/standalone/RemoteDUnitVM.java    |    4 +-
 .../test/dunit/standalone/RemoteDUnitVMIF.java  |    2 +-
 .../dunit/standalone/StandAloneDUnitEnv.java    |    6 +-
 .../geode/test/dunit/tests/BasicDUnitTest.java  |   18 +-
 .../tests/GetDefaultDiskStoreNameDUnitTest.java |   10 +-
 .../dunit/tests/GetTestMethodNameDUnitTest.java |    8 +-
 .../test/dunit/tests/JUnit4BasicDUnitTest.java  |   20 +-
 .../JUnit4GetDefaultDiskStoreNameDUnitTest.java |   10 +-
 .../tests/JUnit4GetTestMethodNameDUnitTest.java |    8 +-
 ...ingGetPropertiesDisconnectsAllDUnitTest.java |   12 +-
 .../test/dunit/tests/JUnit4VMDUnitTest.java     |   18 +-
 ...ingGetPropertiesDisconnectsAllDUnitTest.java |   10 +-
 .../geode/test/dunit/tests/VMDUnitTest.java     |   16 +-
 .../java/org/apache/geode/test/fake/Fakes.java  |   30 +-
 .../geode/test/golden/ExecutableProcess.java    |    2 +-
 .../geode/test/golden/FailOutputTestCase.java   |    2 +-
 .../golden/FailWithErrorInOutputJUnitTest.java  |    8 +-
 .../FailWithExtraLineInOutputJUnitTest.java     |    6 +-
 ...WithLineMissingFromEndOfOutputJUnitTest.java |    6 +-
 ...hLineMissingFromMiddleOfOutputJUnitTest.java |    6 +-
 .../FailWithLoggerErrorInOutputJUnitTest.java   |    6 +-
 .../FailWithLoggerFatalInOutputJUnitTest.java   |    6 +-
 .../FailWithLoggerWarnInOutputJUnitTest.java    |    6 +-
 .../golden/FailWithProblemInOutputTestCase.java |    4 +-
 .../golden/FailWithSevereInOutputJUnitTest.java |    8 +-
 ...hTimeoutOfWaitForOutputToMatchJUnitTest.java |    6 +-
 .../FailWithWarningInOutputJUnitTest.java       |    8 +-
 .../geode/test/golden/GoldenComparator.java     |    4 +-
 .../test/golden/GoldenStringComparator.java     |    2 +-
 .../geode/test/golden/GoldenTestCase.java       |   10 +-
 .../golden/GoldenTestFrameworkTestSuite.java    |    2 +-
 .../apache/geode/test/golden/PassJUnitTest.java |    6 +-
 .../golden/PassWithExpectedErrorJUnitTest.java  |    8 +-
 .../golden/PassWithExpectedProblemTestCase.java |    4 +-
 .../golden/PassWithExpectedSevereJUnitTest.java |    8 +-
 .../PassWithExpectedWarningJUnitTest.java       |    8 +-
 .../test/golden/RegexGoldenComparator.java      |    2 +-
 .../test/golden/StringGoldenComparator.java     |    2 +-
 .../apache/geode/test/process/MainLauncher.java |    2 +-
 .../test/process/MainLauncherJUnitTest.java     |    4 +-
 .../geode/test/process/OutputFormatter.java     |    2 +-
 .../geode/test/process/ProcessOutputReader.java |    2 +-
 .../geode/test/process/ProcessStreamReader.java |    2 +-
 .../process/ProcessTestFrameworkTestSuite.java  |    2 +-
 .../geode/test/process/ProcessWrapper.java      |    6 +-
 .../test/process/ProcessWrapperJUnitTest.java   |    6 +-
 .../org/apache/geode/util/JSR166TestCase.java   |    4 +-
 .../org/apache/geode/util/test/TestUtil.java    |    4 +-
 .../org/apache/persistence/admin/Logger.java    |    4 +-
 .../apache/persistence/logging/Formatter.java   |    4 +-
 .../org/apache/persistence/logging/Handler.java |    2 +-
 .../org/apache/persistence/logging/Level.java   |    2 +-
 .../apache/persistence/logging/LogRecord.java   |    2 +-
 .../org/apache/persistence/logging/Logger.java  |    4 +-
 .../persistence/logging/SimpleFormatter.java    |    4 +-
 .../persistence/logging/StreamHandler.java      |    2 +-
 .../test/java/org/apache/sequence/Arrow.java    |    2 +-
 .../test/java/org/apache/sequence/Lifeline.java |    2 +-
 .../java/org/apache/sequence/LifelineState.java |    2 +-
 .../java/org/apache/sequence/LineMapper.java    |    2 +-
 .../org/apache/sequence/SequenceDiagram.java    |    2 +-
 .../java/org/apache/sequence/SequencePanel.java |    2 +-
 .../java/org/apache/sequence/StateColorMap.java |    2 +-
 .../test/java/org/apache/sequence/TimeAxis.java |    2 +-
 .../java/org/apache/sequence/ZoomingPanel.java  |    2 +-
 .../sequence/gemfire/DefaultLineMapper.java     |    4 +-
 .../gemfire/GemfireSequenceDisplay.java         |   12 +-
 .../sequence/gemfire/HydraLineMapper.java       |    4 +-
 .../sequence/gemfire/SelectGraphDialog.java     |    6 +-
 .../src/test/java/org/company/app/Customer.java |    2 +-
 .../src/test/java/org/company/app/DBLoader.java |    2 +-
 .../org/company/app/OrdersCacheListener.java    |    2 +-
 .../java/org/company/data/DatabaseLoader.java   |    2 +-
 .../java/org/company/data/MyDeclarable.java     |    2 +-
 .../src/test/java/org/company/data/MySizer.java |    4 +-
 .../org/company/data/MyTransactionListener.java |    2 +-
 .../src/test/java/org/examples/TestObject.java  |    4 +-
 .../java/org/examples/ds/CompanySerializer.java |    2 +-
 .../src/test/java/org/examples/ds/Employee.java |    4 +-
 .../org/examples/ds/PutDataSerializables.java   |    8 +-
 .../src/test/java/org/examples/ds/User.java     |    4 +-
 .../org/examples/snapshot/MyDataSerializer.java |    2 +-
 .../java/org/examples/snapshot/MyObject.java    |    4 +-
 .../snapshot/MyObjectDataSerializable.java      |    2 +-
 .../snapshot/MyObjectPdxSerializable.java       |    6 +-
 .../org/examples/snapshot/MyPdxSerializer.java  |   10 +-
 .../org/main/MyDistributedSystemListener.java   |   14 +-
 .../org/main/WANBootStrapping_Site1_Add.java    |   12 +-
 .../org/main/WANBootStrapping_Site1_Remove.java |    8 +-
 .../org/main/WANBootStrapping_Site2_Add.java    |   12 +-
 .../org/main/WANBootStrapping_Site2_Remove.java |    6 +-
 .../java/parReg/query/unittest/Position.java    |    2 +-
 ...eode.distributed.ServerLauncherCacheProvider |    2 +-
 ...org.apache.geode.internal.cache.CacheService |    2 +-
 ...ache.geode.internal.cache.xmlcache.XmlParser |    6 +-
 ...org.springframework.shell.core.CommandMarker |    8 +-
 .../query/internal/index/cachequeryindex.xml    |    4 +-
 .../internal/index/cachequeryindexwitherror.xml |    6 +-
 .../cache/query/partitioned/PRIndexCreation.xml |    2 +-
 .../geode/cache30/callbackNotDeclarable.xml     |    2 +-
 .../geode/cache30/callbackWithException.xml     |    2 +-
 .../apache/geode/cache30/loaderNotLoader.xml    |    2 +-
 .../geode/codeAnalysis/excludedClasses.txt      |  300 +--
 .../org/apache/geode/codeAnalysis/openBugs.txt  |    4 +-
 .../sanctionedDataSerializables.txt             | 1054 ++++-----
 .../codeAnalysis/sanctionedSerializables.txt    | 1332 ++++++------
 .../cache/PartitionRegionCacheExample1.xml      |    2 +-
 .../cache/PartitionRegionCacheExample2.xml      |    2 +-
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml |    4 +-
 ...ntQueueConfiguredFromXmlUsesFilter.cache.xml |    4 +-
 .../logging/log4j/custom/log4j2-custom.xml      |    4 +-
 .../internal/configuration/cluster-empty.xml    |    2 +-
 .../internal/configuration/cluster-region.xml   |    2 +-
 ...dNewNodeJUnitTest.testAddNewNodeNewNamed.xml |    2 +-
 ...ewNodeJUnitTest.testAddNewNodeNewUnnamed.xml |    2 +-
 ...itTest.testAddNewNodeNewUnnamedExtension.xml |    2 +-
 ...NodeJUnitTest.testAddNewNodeReplaceNamed.xml |    2 +-
 ...deJUnitTest.testAddNewNodeReplaceUnnamed.xml |    2 +-
 ...st.testAddNewNodeReplaceUnnamedExtension.xml |    2 +-
 ...sAddNewNodeJUnitTest.testDeleteNodeNamed.xml |    2 +-
 ...ddNewNodeJUnitTest.testDeleteNodeUnnamed.xml |    2 +-
 ...JUnitTest.testDeleteNodeUnnamedExtension.xml |    2 +-
 .../utils/XmlUtilsAddNewNodeJUnitTest.xml       |    2 +-
 ...Test.testBuildSchemaLocationMapAttribute.xml |    6 +-
 ...testBuildSchemaLocationMapEmptyAttribute.xml |    2 +-
 ...ationMapMapOfStringListOfStringAttribute.xml |    6 +-
 ....testBuildSchemaLocationMapNullAttribute.xml |    2 +-
 ...XmlUtilsJUnitTest.testQuerySingleElement.xml |    4 +-
 .../templates/generator/authz-dummy.xml         |    2 +-
 .../security/templates/generator/authz-ldap.xml |    2 +-
 .../generator/authz-multiUser-dummy.xml         |    2 +-
 .../generator/authz-multiUser-ldap.xml          |    2 +-
 .../apache/geode/test/golden/log4j2-test.xml    |    2 +-
 .../geode/cache/client/internal/CloseCQOp.java  |   14 +-
 .../geode/cache/client/internal/CreateCQOp.java |   30 +-
 .../cache/client/internal/CreateCQWithIROp.java |   18 +-
 .../cache/client/internal/GetDurableCQsOp.java  |   26 +-
 .../client/internal/ServerCQProxyImpl.java      |    8 +-
 .../geode/cache/client/internal/StopCQOp.java   |   14 +-
 .../cache/query/internal/cq/ClientCQImpl.java   |   54 +-
 .../internal/cq/CqAttributesMutatorImpl.java    |   10 +-
 .../cache/query/internal/cq/CqConflatable.java  |    8 +-
 .../cache/query/internal/cq/CqEventImpl.java    |   16 +-
 .../cache/query/internal/cq/CqListenerImpl.java |    8 +-
 .../cache/query/internal/cq/CqQueryImpl.java    |   56 +-
 .../query/internal/cq/CqServiceFactoryImpl.java |   28 +-
 .../cache/query/internal/cq/CqServiceImpl.java  |   88 +-
 .../internal/cq/CqServiceStatisticsImpl.java    |   12 +-
 .../query/internal/cq/CqServiceVsdStats.java    |   28 +-
 .../query/internal/cq/CqStatisticsImpl.java     |    4 +-
 .../cache/query/internal/cq/ServerCQImpl.java   |   86 +-
 .../tier/sockets/command/BaseCQCommand.java     |    4 +-
 .../cache/tier/sockets/command/CloseCQ.java     |   28 +-
 .../cache/tier/sockets/command/ExecuteCQ.java   |   44 +-
 .../cache/tier/sockets/command/ExecuteCQ61.java |   54 +-
 .../cache/tier/sockets/command/GetCQStats.java  |   18 +-
 .../tier/sockets/command/GetDurableCQs.java     |   30 +-
 .../cache/tier/sockets/command/MonitorCQ.java   |   18 +-
 .../cache/tier/sockets/command/StopCQ.java      |   30 +-
 ...cache.query.internal.cq.spi.CqServiceFactory |    2 +-
 .../geode/cache/query/cq/CQJUnitTest.java       |   24 +-
 .../cache/query/cq/dunit/CqDataDUnitTest.java   |   68 +-
 .../dunit/CqDataOptimizedExecuteDUnitTest.java  |   16 +-
 .../cq/dunit/CqDataUsingPoolDUnitTest.java      |   92 +-
 ...qDataUsingPoolOptimizedExecuteDUnitTest.java |   16 +-
 .../cache/query/cq/dunit/CqPerfDUnitTest.java   |   54 +-
 .../cq/dunit/CqPerfUsingPoolDUnitTest.java      |   52 +-
 .../cache/query/cq/dunit/CqQueryDUnitTest.java  |  110 +-
 .../dunit/CqQueryOptimizedExecuteDUnitTest.java |   30 +-
 .../cq/dunit/CqQueryUsingPoolDUnitTest.java     |  112 +-
 ...QueryUsingPoolOptimizedExecuteDUnitTest.java |   14 +-
 .../cq/dunit/CqResultSetUsingPoolDUnitTest.java |   46 +-
 ...ltSetUsingPoolOptimizedExecuteDUnitTest.java |   46 +-
 .../cache/query/cq/dunit/CqStateDUnitTest.java  |   36 +-
 .../cache/query/cq/dunit/CqStatsDUnitTest.java  |   54 +-
 .../dunit/CqStatsOptimizedExecuteDUnitTest.java |   16 +-
 .../cq/dunit/CqStatsUsingPoolDUnitTest.java     |   54 +-
 ...StatsUsingPoolOptimizedExecuteDUnitTest.java |   16 +-
 .../query/cq/dunit/CqTimeTestListener.java      |   16 +-
 .../PartitionedRegionCqQueryDUnitTest.java      |   76 +-
 ...dRegionCqQueryOptimizedExecuteDUnitTest.java |   28 +-
 .../query/cq/dunit/PrCqUsingPoolDUnitTest.java  |   70 +-
 .../PrCqUsingPoolOptimizedExecuteDUnitTest.java |   14 +-
 .../cache/query/dunit/PdxQueryCQDUnitTest.java  |   58 +-
 .../cache/query/dunit/PdxQueryCQTestBase.java   |   86 +-
 .../dunit/QueryIndexUpdateRIDUnitTest.java      |   66 +-
 .../query/dunit/QueryMonitorDUnitTest.java      |   88 +-
 .../cache/snapshot/ClientSnapshotDUnitTest.java |   52 +-
 .../AnalyzeCQSerializablesJUnitTest.java        |    6 +-
 .../cache/PRDeltaPropagationDUnitTest.java      |   88 +-
 .../geode/internal/cache/PutAllCSDUnitTest.java |  118 +-
 .../cache/RemoteCQTransactionDUnitTest.java     |   96 +-
 .../internal/cache/ha/CQListGIIDUnitTest.java   |  100 +-
 .../cache/ha/HADispatcherDUnitTest.java         |   62 +-
 .../sockets/ClientToServerDeltaDUnitTest.java   |   72 +-
 .../DeltaPropagationWithCQDUnitTest.java        |   66 +-
 ...ToRegionRelationCQRegistrationDUnitTest.java |   56 +-
 .../sockets/DurableClientCrashDUnitTest.java    |    8 +-
 .../sockets/DurableClientNetDownDUnitTest.java  |    4 +-
 .../sockets/DurableClientSimpleDUnitTest.java   |   76 +-
 .../tier/sockets/DurableClientTestCase.java     |   78 +-
 .../CacheServerManagementDUnitTest.java         |   38 +-
 .../cli/commands/ClientCommandsDUnitTest.java   |   72 +-
 .../DurableClientCommandsDUnitTest.java         |   50 +-
 .../internal/pulse/TestCQDUnitTest.java         |   30 +-
 .../internal/pulse/TestClientsDUnitTest.java    |   30 +-
 .../internal/pulse/TestServerDUnitTest.java     |   28 +-
 .../security/CQPDXPostProcessorDUnitTest.java   |   36 +-
 .../security/CQPostProcessorDunitTest.java      |   28 +-
 .../ClientAuthorizationTwoDUnitTest.java        |   12 +-
 .../security/ClientAuthzObjectModDUnitTest.java |   36 +-
 .../ClientCQPostAuthorizationDUnitTest.java     |   60 +-
 .../ClientPostAuthorizationDUnitTest.java       |   20 +-
 .../ClientQueryAuthDistributedTest.java         |   26 +-
 .../geode/security/MultiUserAPIDUnitTest.java   |   36 +-
 .../MultiUserDurableCQAuthzDUnitTest.java       |   52 +-
 .../geode/codeAnalysis/excludedClasses.txt      |    2 +-
 .../org/apache/geode/codeAnalysis/openBugs.txt  |    2 +-
 .../sanctionedDataSerializables.txt             |    2 +-
 .../codeAnalysis/sanctionedSerializables.txt    |    2 +-
 .../tier/sockets/durablecq-client-cache.xml     |    2 +-
 .../geode/examples/replicated/BaseClient.java   |    8 +-
 .../geode/examples/replicated/Consumer.java     |    2 +-
 .../geode/examples/replicated/Producer.java     |    2 +-
 .../geode/examples/replicated/ConsumerTest.java |    6 +-
 .../geode/examples/replicated/ProducerTest.java |    4 +-
 .../geode/test/junit/ConditionalIgnore.java     |    8 +-
 .../geode/test/junit/IgnoreCondition.java       |    2 +-
 .../apache/geode/test/junit/IgnoreUntil.java    |    8 +-
 .../org/apache/geode/test/junit/Repeat.java     |    2 +-
 .../java/org/apache/geode/test/junit/Retry.java |    2 +-
 .../test/junit/categories/ContainerTest.java    |    2 +-
 .../test/junit/categories/DistributedTest.java  |    2 +-
 .../categories/DistributedTransactionsTest.java |    2 +-
 .../geode/test/junit/categories/FlakyTest.java  |    2 +-
 .../geode/test/junit/categories/HydraTest.java  |    2 +-
 .../test/junit/categories/IntegrationTest.java  |    2 +-
 .../test/junit/categories/PerformanceTest.java  |    2 +-
 .../test/junit/categories/SecurityTest.java     |    2 +-
 .../geode/test/junit/categories/UITest.java     |    2 +-
 .../geode/test/junit/categories/UnitTest.java   |    2 +-
 .../geode/test/junit/categories/WanTest.java    |    2 +-
 .../test/junit/rules/ConditionalIgnoreRule.java |   12 +-
 .../junit/rules/DescribedExternalResource.java  |    2 +-
 .../geode/test/junit/rules/DiskDirRule.java     |    2 +-
 .../test/junit/rules/ExpectedTimeoutRule.java   |    2 +-
 .../geode/test/junit/rules/IgnoreUntilRule.java |   12 +-
 .../geode/test/junit/rules/RepeatRule.java      |    4 +-
 .../geode/test/junit/rules/RetryRule.java       |    4 +-
 .../apache/geode/test/junit/rules/RuleList.java |    2 +-
 .../serializable/FieldSerializationUtils.java   |    2 +-
 .../serializable/FieldsOfTemporaryFolder.java   |    2 +-
 .../rules/serializable/FieldsOfTestName.java    |    2 +-
 .../rules/serializable/FieldsOfTimeout.java     |    2 +-
 .../SerializableExternalResource.java           |    2 +-
 .../serializable/SerializableRuleList.java      |    4 +-
 .../SerializableTemporaryFolder.java            |    6 +-
 .../serializable/SerializableTestName.java      |    6 +-
 .../serializable/SerializableTestRule.java      |    2 +-
 .../serializable/SerializableTestWatcher.java   |    2 +-
 .../rules/serializable/SerializableTimeout.java |    6 +-
 .../test/junit/runner/SuiteBlockRunner.java     |    2 +-
 .../geode/test/junit/runner/SuiteRunner.java    |    2 +-
 .../CategoryWithParameterizedRunner.java        |    2 +-
 .../CategoryWithParameterizedRunnerFactory.java |    2 +-
 .../junit/runners/ExposedGetAnnotations.java    |    2 +-
 .../junit/support/DefaultIgnoreCondition.java   |    8 +-
 .../IgnoreConditionEvaluationException.java     |    2 +-
 .../test/junit/categories/CategoryOne.java      |    2 +-
 .../test/junit/categories/CategoryTest.java     |    4 +-
 .../test/junit/categories/CategoryTwo.java      |    2 +-
 .../geode/test/junit/rules/DiskDirRuleTest.java |    4 +-
 .../junit/rules/ExpectedTimeoutRuleTest.java    |    4 +-
 .../test/junit/rules/IgnoreUntilRuleTest.java   |    6 +-
 .../geode/test/junit/rules/RepeatRuleTest.java  |    6 +-
 .../rules/RetryRuleGlobalWithErrorTest.java     |    8 +-
 .../rules/RetryRuleGlobalWithExceptionTest.java |    8 +-
 .../rules/RetryRuleLocalWithErrorTest.java      |    6 +-
 .../rules/RetryRuleLocalWithExceptionTest.java  |   10 +-
 .../geode/test/junit/rules/RuleListTest.java    |    4 +-
 .../geode/test/junit/rules/TestRunner.java      |    2 +-
 .../examples/RepeatingTestCasesExampleTest.java |   12 +-
 .../rules/examples/RetryRuleExampleTest.java    |    6 +-
 .../rules/examples/RuleAndClassRuleTest.java    |    6 +-
 .../SerializableExternalResourceTest.java       |    4 +-
 .../serializable/SerializableRuleListTest.java  |    4 +-
 .../SerializableTemporaryFolderTest.java        |    8 +-
 .../serializable/SerializableTestNameTest.java  |    6 +-
 .../SerializableTestWatcherTest.java            |    4 +-
 .../serializable/SerializableTimeoutTest.java   |    8 +-
 ...egoryWithParameterizedRunnerFactoryTest.java |    4 +-
 .../apache/geode/cache/lucene/LuceneIndex.java  |    4 +-
 .../apache/geode/cache/lucene/LuceneQuery.java  |    4 +-
 .../cache/lucene/LuceneQueryException.java      |    4 +-
 .../geode/cache/lucene/LuceneQueryFactory.java  |    4 +-
 .../geode/cache/lucene/LuceneQueryProvider.java |    6 +-
 .../geode/cache/lucene/LuceneResultStruct.java  |    4 +-
 .../geode/cache/lucene/LuceneService.java       |    8 +-
 .../cache/lucene/LuceneServiceProvider.java     |   10 +-
 .../lucene/PageableLuceneQueryResults.java      |    4 +-
 .../AbstractPartitionedRepositoryManager.java   |   22 +-
 .../cache/lucene/internal/IndexListener.java    |    4 +-
 .../lucene/internal/IndexListenerAdapter.java   |    4 +-
 .../lucene/internal/IndexRepositoryFactory.java |   16 +-
 .../lucene/internal/InternalLuceneIndex.java    |    6 +-
 .../lucene/internal/InternalLuceneService.java  |   10 +-
 .../lucene/internal/LuceneEventListener.java    |   32 +-
 .../internal/LuceneIndexCreationProfile.java    |   12 +-
 .../lucene/internal/LuceneIndexFactory.java     |    4 +-
 .../LuceneIndexForPartitionedRegion.java        |   44 +-
 .../cache/lucene/internal/LuceneIndexImpl.java  |   38 +-
 .../cache/lucene/internal/LuceneIndexStats.java |   18 +-
 .../lucene/internal/LuceneQueryFactoryImpl.java |   12 +-
 .../cache/lucene/internal/LuceneQueryImpl.java  |   38 +-
 .../cache/lucene/internal/LuceneRawIndex.java   |   10 +-
 .../lucene/internal/LuceneRawIndexFactory.java  |    4 +-
 .../lucene/internal/LuceneResultStructImpl.java |    4 +-
 .../lucene/internal/LuceneServiceImpl.java      |   68 +-
 .../PageableLuceneQueryResultsImpl.java         |   10 +-
 .../internal/PartitionedRepositoryManager.java  |    8 +-
 .../internal/RawIndexRepositoryFactory.java     |   14 +-
 .../internal/RawLuceneRepositoryManager.java    |   10 +-
 .../lucene/internal/StringQueryProvider.java    |   22 +-
 .../lucene/internal/cli/LuceneCliStrings.java   |    2 +-
 .../internal/cli/LuceneIndexCommands.java       |   60 +-
 .../lucene/internal/cli/LuceneIndexDetails.java |    8 +-
 .../lucene/internal/cli/LuceneIndexInfo.java    |    4 +-
 .../lucene/internal/cli/LuceneQueryInfo.java    |    4 +-
 .../internal/cli/LuceneSearchResults.java       |    2 +-
 .../functions/LuceneCreateIndexFunction.java    |   34 +-
 .../functions/LuceneDescribeIndexFunction.java  |   30 +-
 .../cli/functions/LuceneListIndexFunction.java  |   28 +-
 .../functions/LuceneSearchIndexFunction.java    |   36 +-
 .../internal/directory/DumpDirectoryFiles.java  |   52 +-
 .../internal/directory/FileIndexInput.java      |    6 +-
 .../internal/directory/RegionDirectory.java     |   10 +-
 .../lucene/internal/directory/package-info.java |    4 +-
 .../internal/distributed/CollectorManager.java  |    8 +-
 .../lucene/internal/distributed/EntryScore.java |    8 +-
 .../internal/distributed/LuceneFunction.java    |   40 +-
 .../distributed/LuceneFunctionContext.java      |   16 +-
 .../lucene/internal/distributed/TopEntries.java |   10 +-
 .../distributed/TopEntriesCollector.java        |   12 +-
 .../distributed/TopEntriesCollectorManager.java |   16 +-
 .../TopEntriesFunctionCollector.java            |   14 +-
 .../internal/distributed/package-info.java      |    6 +-
 .../lucene/internal/filesystem/ChunkKey.java    |    6 +-
 .../cache/lucene/internal/filesystem/File.java  |   10 +-
 .../internal/filesystem/FileInputStream.java    |    2 +-
 .../internal/filesystem/FileOutputStream.java   |    2 +-
 .../lucene/internal/filesystem/FileSystem.java  |    2 +-
 .../internal/filesystem/FileSystemStats.java    |   14 +-
 .../filesystem/SeekableInputStream.java         |    2 +-
 .../internal/filesystem/package-info.java       |    4 +-
 .../internal/management/LuceneIndexMetrics.java |    2 +-
 .../management/LuceneIndexStatsMonitor.java     |   18 +-
 .../management/LuceneServiceBridge.java         |   12 +-
 .../internal/management/LuceneServiceMBean.java |    8 +-
 .../management/LuceneServiceMXBean.java         |   12 +-
 .../management/ManagementIndexListener.java     |    6 +-
 .../lucene/internal/management/StatsKey.java    |    2 +-
 .../cache/lucene/internal/package-info.java     |    2 +-
 .../internal/repository/IndexRepository.java    |    4 +-
 .../repository/IndexRepositoryImpl.java         |   16 +-
 .../repository/IndexResultCollector.java        |    4 +-
 .../internal/repository/RepositoryManager.java  |    8 +-
 .../internal/repository/package-info.java       |    4 +-
 .../HeterogeneousLuceneSerializer.java          |   12 +-
 .../repository/serializer/LuceneSerializer.java |    2 +-
 .../serializer/PdxLuceneSerializer.java         |    6 +-
 .../serializer/PrimitiveSerializer.java         |    4 +-
 .../serializer/ReflectionLuceneSerializer.java  |    4 +-
 .../repository/serializer/SerializerUtil.java   |    8 +-
 .../repository/serializer/package-info.java     |    2 +-
 .../internal/xml/LuceneIndexCreation.java       |   20 +-
 .../internal/xml/LuceneIndexXmlGenerator.java   |   14 +-
 .../internal/xml/LuceneServiceXmlGenerator.java |    8 +-
 .../lucene/internal/xml/LuceneXmlConstants.java |    2 +-
 .../lucene/internal/xml/LuceneXmlParser.java    |   18 +-
 .../cache/lucene/internal/xml/package-info.java |    2 +-
 .../apache/geode/cache/lucene/package-info.java |    6 +-
 ...org.apache.geode.internal.cache.CacheService |    2 +-
 ...ache.geode.internal.cache.xmlcache.XmlParser |    2 +-
 ...org.springframework.shell.core.CommandMarker |    2 +-
 .../geode/cache/lucene/LuceneDUnitTest.java     |   10 +-
 .../lucene/LuceneIndexCreationDUnitTest.java    |   14 +-
 .../LuceneIndexCreationIntegrationTest.java     |   44 +-
 ...ceneIndexCreationOffHeapIntegrationTest.java |   20 +-
 ...IndexCreationPersistenceIntegrationTest.java |   24 +-
 .../LuceneIndexMaintenanceIntegrationTest.java  |   24 +-
 .../cache/lucene/LuceneIntegrationTest.java     |   14 +-
 .../geode/cache/lucene/LuceneQueriesBase.java   |   16 +-
 .../lucene/LuceneQueriesClientDUnitTest.java    |   22 +-
 .../lucene/LuceneQueriesIntegrationTest.java    |   26 +-
 .../geode/cache/lucene/LuceneQueriesPRBase.java |   40 +-
 .../lucene/LuceneQueriesPeerPRDUnitTest.java    |   10 +-
 .../LuceneQueriesPeerPROverflowDUnitTest.java   |   14 +-
 .../LuceneQueriesPeerPRRedundancyDUnitTest.java |   32 +-
 ...LuceneQueriesPersistenceIntegrationTest.java |   26 +-
 .../internal/LuceneEventListenerJUnitTest.java  |   16 +-
 .../LuceneIndexCreationProfileJUnitTest.java    |   10 +-
 .../LuceneIndexForPartitionedRegionTest.java    |   46 +-
 .../internal/LuceneIndexImplJUnitTest.java      |   12 +-
 .../LuceneIndexRecoveryHAIntegrationTest.java   |   30 +-
 .../internal/LuceneIndexStatsJUnitTest.java     |   10 +-
 .../LuceneQueryFactoryImplJUnitTest.java        |   12 +-
 .../internal/LuceneQueryImplJUnitTest.java      |   28 +-
 .../LuceneResultStructImpJUnitTest.java         |    4 +-
 .../LuceneServiceImplIntegrationTest.java       |   26 +-
 .../internal/LuceneServiceImplJUnitTest.java    |    6 +-
 ...PageableLuceneQueryResultsImplJUnitTest.java |   12 +-
 .../PartitionedRepositoryManagerJUnitTest.java  |   32 +-
 .../RawLuceneRepositoryManagerJUnitTest.java    |   18 +-
 .../internal/StringQueryProviderJUnitTest.java  |   10 +-
 .../cli/LuceneIndexCommandsDUnitTest.java       |   46 +-
 .../cli/LuceneIndexCommandsJUnitTest.java       |   40 +-
 .../LuceneCreateIndexFunctionJUnitTest.java     |   22 +-
 .../LuceneDescribeIndexFunctionJUnitTest.java   |   24 +-
 .../LuceneListIndexFunctionJUnitTest.java       |   22 +-
 .../LuceneSearchIndexFunctionJUnitTest.java     |   34 +-
 .../LuceneClusterConfigurationDUnitTest.java    |   66 +-
 .../DumpDirectoryFilesIntegrationTest.java      |   18 +-
 .../directory/DumpDirectoryFilesJUnitTest.java  |   30 +-
 .../directory/RegionDirectoryJUnitTest.java     |   10 +-
 .../DistributedScoringJUnitTest.java            |   20 +-
 .../distributed/EntryScoreJUnitTest.java        |    8 +-
 .../LuceneFunctionContextJUnitTest.java         |   20 +-
 .../distributed/LuceneFunctionJUnitTest.java    |   36 +-
 .../TopEntriesCollectorJUnitTest.java           |   10 +-
 .../TopEntriesFunctionCollectorJUnitTest.java   |   10 +-
 .../distributed/TopEntriesJUnitTest.java        |   10 +-
 .../internal/filesystem/ChunkKeyJUnitTest.java  |    8 +-
 .../internal/filesystem/FileJUnitTest.java      |    8 +-
 .../filesystem/FileSystemJUnitTest.java         |    8 +-
 .../filesystem/FileSystemStatsJUnitTest.java    |   10 +-
 .../management/LuceneManagementDUnitTest.java   |   32 +-
 .../IndexRepositoryImplJUnitTest.java           |   20 +-
 .../IndexRepositoryImplPerformanceTest.java     |   34 +-
 .../HeterogeneousLuceneSerializerJUnitTest.java |    8 +-
 .../serializer/PdxFieldMapperJUnitTest.java     |    6 +-
 .../ReflectionFieldMapperJUnitTest.java         |    4 +-
 .../internal/repository/serializer/Type1.java   |    2 +-
 .../internal/repository/serializer/Type2.java   |    2 +-
 ...neIndexXmlGeneratorIntegrationJUnitTest.java |   20 +-
 .../xml/LuceneIndexXmlGeneratorJUnitTest.java   |    8 +-
 ...uceneIndexXmlParserIntegrationJUnitTest.java |   30 +-
 .../xml/LuceneIndexXmlParserJUnitTest.java      |   16 +-
 .../geode/cache/lucene/test/IndexRegionSpy.java |   18 +-
 .../cache/lucene/test/IndexRepositorySpy.java   |   22 +-
 .../cache/lucene/test/LuceneTestUtilities.java  |   32 +-
 .../geode/cache/lucene/test/TestObject.java     |    2 +-
 .../geode/cache/lucene/test/package-info.java   |    2 +-
 .../tools/pulse/internal/PulseAppListener.java  |   16 +-
 .../controllers/ExceptionHandlingAdvice.java    |    4 +-
 .../internal/controllers/PulseController.java   |   20 +-
 .../tools/pulse/internal/data/Cluster.java      |    6 +-
 .../tools/pulse/internal/data/DataBrowser.java  |    6 +-
 .../pulse/internal/data/IClusterUpdater.java    |    2 +-
 .../pulse/internal/data/JMXDataUpdater.java     |   10 +-
 .../pulse/internal/data/JmxManagerFinder.java   |    6 +-
 .../tools/pulse/internal/data/PulseConfig.java  |    2 +-
 .../pulse/internal/data/PulseConstants.java     |    2 +-
 .../tools/pulse/internal/data/PulseVersion.java |    2 +-
 .../tools/pulse/internal/data/Repository.java   |    4 +-
 .../gemfire/tools/pulse/internal/json/CDL.java  |    2 +-
 .../tools/pulse/internal/json/Cookie.java       |    2 +-
 .../tools/pulse/internal/json/CookieList.java   |    2 +-
 .../gemfire/tools/pulse/internal/json/HTTP.java |    2 +-
 .../tools/pulse/internal/json/HTTPTokener.java  |    2 +-
 .../tools/pulse/internal/json/JSONArray.java    |    2 +-
 .../pulse/internal/json/JSONException.java      |    2 +-
 .../tools/pulse/internal/json/JSONML.java       |    2 +-
 .../tools/pulse/internal/json/JSONObject.java   |    2 +-
 .../tools/pulse/internal/json/JSONString.java   |    2 +-
 .../tools/pulse/internal/json/JSONStringer.java |    2 +-
 .../tools/pulse/internal/json/JSONTokener.java  |    2 +-
 .../tools/pulse/internal/json/JSONWriter.java   |    2 +-
 .../gemfire/tools/pulse/internal/json/XML.java  |    2 +-
 .../tools/pulse/internal/json/XMLTokener.java   |    2 +-
 .../tools/pulse/internal/log/LogWriter.java     |    2 +-
 .../pulse/internal/log/MessageFormatter.java    |    6 +-
 .../pulse/internal/log/PulseLogWriter.java      |    6 +-
 .../tools/pulse/internal/log/PulseLogger.java   |    4 +-
 .../security/GemFireAuthentication.java         |    6 +-
 .../security/GemFireAuthenticationProvider.java |    6 +-
 .../pulse/internal/security/LogoutHandler.java  |    6 +-
 .../internal/service/ClusterDetailsService.java |    8 +-
 .../service/ClusterDiskThroughputService.java   |    6 +-
 .../service/ClusterGCPausesService.java         |    6 +-
 .../service/ClusterKeyStatisticsService.java    |    6 +-
 .../internal/service/ClusterMemberService.java  |   12 +-
 .../service/ClusterMembersRGraphService.java    |    8 +-
 .../service/ClusterMemoryUsageService.java      |    6 +-
 .../internal/service/ClusterRegionService.java  |   12 +-
 .../internal/service/ClusterRegionsService.java |   12 +-
 .../service/ClusterSelectedRegionService.java   |   16 +-
 .../ClusterSelectedRegionsMemberService.java    |   10 +-
 .../internal/service/ClusterWANInfoService.java |    6 +-
 .../service/MemberAsynchEventQueuesService.java |    8 +-
 .../internal/service/MemberClientsService.java  |   10 +-
 .../internal/service/MemberDetailsService.java  |   12 +-
 .../service/MemberDiskThroughputService.java    |    8 +-
 .../internal/service/MemberGCPausesService.java |    8 +-
 .../service/MemberGatewayHubService.java        |    8 +-
 .../service/MemberHeapUsageService.java         |    8 +-
 .../service/MemberKeyStatisticsService.java     |    8 +-
 .../internal/service/MemberRegionsService.java  |   12 +-
 .../internal/service/MembersListService.java    |    6 +-
 .../pulse/internal/service/PulseService.java    |    2 +-
 .../internal/service/PulseServiceFactory.java   |    2 +-
 .../internal/service/PulseVersionService.java   |    4 +-
 .../service/QueryStatisticsService.java         |    8 +-
 .../internal/service/SystemAlertsService.java   |    8 +-
 .../pulse/internal/util/ConnectionUtil.java     |    2 +-
 .../pulse/internal/util/IPAddressUtil.java      |    2 +-
 .../tools/pulse/internal/util/StringUtils.java  |    2 +-
 .../tools/pulse/internal/util/TimeUtils.java    |    2 +-
 .../controllers/PulseControllerJUnitTest.java   |   16 +-
 .../pulse/testbed/GemFireDistributedSystem.java |    4 +-
 .../tools/pulse/testbed/GemfireTopology.java    |    2 +-
 .../tools/pulse/testbed/PropFileHelper.java     |    2 +-
 .../pulse/testbed/PropMockDataUpdater.java      |   34 +-
 .../gemfire/tools/pulse/testbed/TestBed.java    |    2 +-
 .../tools/pulse/testbed/driver/PulseUITest.java |   20 +-
 .../tools/pulse/tests/AggregateStatement.java   |    2 +-
 .../pulse/tests/AggregateStatementMBean.java    |    2 +-
 .../pulse/tests/DataBrowserResultLoader.java    |    2 +-
 .../pulse/tests/GemFireXDAggregateTable.java    |    2 +-
 .../tests/GemFireXDAggregateTableMBean.java     |    2 +-
 .../tools/pulse/tests/GemFireXDCluster.java     |    2 +-
 .../pulse/tests/GemFireXDClusterMBean.java      |    2 +-
 .../tools/pulse/tests/GemFireXDMember.java      |    2 +-
 .../tools/pulse/tests/GemFireXDMemberMBean.java |    2 +-
 .../gemfire/tools/pulse/tests/JMXBaseBean.java  |    2 +-
 .../tools/pulse/tests/JMXProperties.java        |    2 +-
 .../gemfire/tools/pulse/tests/Member.java       |    2 +-
 .../gemfire/tools/pulse/tests/MemberMBean.java  |    2 +-
 .../tools/pulse/tests/PulseAbstractTest.java    |    6 +-
 .../tools/pulse/tests/PulseAuthTest.java        |    4 +-
 .../tools/pulse/tests/PulseAutomatedTest.java   |    4 +-
 .../tools/pulse/tests/PulseBaseTest.java        |    4 +-
 .../tools/pulse/tests/PulseNoAuthTest.java      |    4 +-
 .../tools/pulse/tests/PulseTestData.java        |    2 +-
 .../tools/pulse/tests/PulseTestLocators.java    |    2 +-
 .../gemfire/tools/pulse/tests/Region.java       |    2 +-
 .../gemfire/tools/pulse/tests/RegionMBean.java  |    2 +-
 .../tools/pulse/tests/RegionOnMember.java       |    2 +-
 .../tools/pulse/tests/RegionOnMemberMBean.java  |    2 +-
 .../gemfire/tools/pulse/tests/Server.java       |   14 +-
 .../gemfire/tools/pulse/tests/ServerObject.java |    2 +-
 .../tools/pulse/tests/ServerObjectMBean.java    |    2 +-
 .../pulse/tests/junit/BaseServiceTest.java      |    8 +-
 .../junit/ClusterSelectedRegionServiceTest.java |   12 +-
 ...ClusterSelectedRegionsMemberServiceTest.java |    4 +-
 .../junit/MemberGatewayHubServiceTest.java      |   16 +-
 geode-pulse/src/test/resources/test6.txt        |    6 +-
 geode-pulse/src/test/resources/test7.txt        |    6 +-
 .../resources/testNullObjectsAtRootLevel1.txt   |   20 +-
 .../resources/testNullObjectsAtRootLevel2.txt   |   16 +-
 .../src/test/resources/testQueryResult.txt      |  232 +-
 .../src/test/resources/testQueryResult1000.txt  | 2042 +++++++++---------
 .../resources/testQueryResultClusterSmall.txt   |   28 +-
 .../testQueryResultClusterWithStruct.txt        |   12 +-
 .../resources/testQueryResultHashMapSmall.txt   |   20 +-
 .../src/test/resources/testQueryResultSmall.txt |    8 +-
 .../resources/testQueryResultWithStruct.txt     |  326 +--
 .../testQueryResultWithStructSmall.txt          |   12 +-
 .../apache/geode/cache/util/AutoBalancer.java   |   30 +-
 .../util/AutoBalancerIntegrationJUnitTest.java  |   30 +-
 .../geode/cache/util/AutoBalancerJUnitTest.java |   38 +-
 .../website/content/schema/cache/cache-1.0.xsd  |    2 +-
 .../connector/internal/RegionMetadata.java      |    2 +-
 .../internal/geodefunctions/QueryFunction.java  |   18 +-
 .../geodefunctions/RetrieveRegionFunction.java  |   32 +-
 .../RetrieveRegionMetadataFunction.java         |   16 +-
 .../StructStreamingResultSender.java            |   20 +-
 .../spark/connector/JavaApiIntegrationTest.java |    4 +-
 .../geode/spark/connector/Portfolio.java        |    2 +-
 .../pivotal/geode/spark/connector/Position.java |    2 +-
 .../spark/connector/BasicIntegrationTest.scala  |    6 +-
 .../RDDJoinRegionIntegrationTest.scala          |    2 +-
 .../RetrieveRegionIntegrationTest.scala         |    2 +-
 .../geode/spark/connector/testkit/IOUtils.scala |    2 +-
 .../geode/spark/connector/GeodeConnection.scala |    6 +-
 .../spark/connector/GeodeKryoRegistrator.scala  |    2 +-
 .../internal/DefaultGeodeConnection.scala       |   10 +-
 .../connector/internal/LocatorHelper.scala      |    6 +-
 .../StructStreamingResultCollector.scala        |   14 +-
 .../internal/oql/QueryResultCollector.scala     |    8 +-
 .../connector/internal/oql/RowBuilder.scala     |    2 +-
 .../connector/internal/oql/SchemaBuilder.scala  |    2 +-
 .../internal/oql/UndefinedSerializer.scala      |    6 +-
 .../connector/internal/rdd/GeodeJoinRDD.scala   |    2 +-
 .../internal/rdd/GeodeOuterJoinRDD.scala        |    2 +-
 .../connector/internal/rdd/GeodeRDDWriter.scala |    2 +-
 ...tStreamingResultSenderAndCollectorTest.scala |   12 +-
 .../connector/GeodeDStreamFunctionsTest.scala   |    2 +-
 .../spark/connector/GeodeRDDFunctionsTest.scala |    2 +-
 .../connector/rdd/GeodeRDDPartitionerTest.scala |    2 +-
 .../connector/rdd/GeodeRegionRDDTest.scala      |    2 +-
 .../client/internal/GatewaySenderBatchOp.java   |   32 +-
 .../cache/client/internal/SenderProxy.java      |    6 +-
 .../internal/locator/wan/LocatorDiscovery.java  |   20 +-
 .../internal/locator/wan/LocatorHelper.java     |   12 +-
 .../locator/wan/LocatorJoinMessage.java         |   10 +-
 .../wan/LocatorMembershipListenerImpl.java      |   18 +-
 .../locator/wan/RemoteLocatorJoinRequest.java   |   12 +-
 .../locator/wan/RemoteLocatorJoinResponse.java  |   12 +-
 .../locator/wan/RemoteLocatorPingRequest.java   |    6 +-
 .../locator/wan/RemoteLocatorPingResponse.java  |    6 +-
 .../locator/wan/RemoteLocatorRequest.java       |    6 +-
 .../locator/wan/RemoteLocatorResponse.java      |    8 +-
 .../internal/locator/wan/WANFactoryImpl.java    |   20 +-
 .../locator/wan/WanLocatorDiscovererImpl.java   |   14 +-
 .../cache/wan/AbstractRemoteGatewaySender.java  |   30 +-
 .../cache/wan/GatewayReceiverFactoryImpl.java   |   22 +-
 .../internal/cache/wan/GatewayReceiverImpl.java |   28 +-
 .../wan/GatewaySenderEventRemoteDispatcher.java |   40 +-
 .../cache/wan/GatewaySenderFactoryImpl.java     |   40 +-
 .../wan/parallel/ParallelGatewaySenderImpl.java |   64 +-
 ...rentParallelGatewaySenderEventProcessor.java |   12 +-
 ...moteParallelGatewaySenderEventProcessor.java |   28 +-
 ...urrentSerialGatewaySenderEventProcessor.java |    6 +-
 ...RemoteSerialGatewaySenderEventProcessor.java |   12 +-
 .../wan/serial/SerialGatewaySenderImpl.java     |   50 +-
 ...ternal.locator.wan.LocatorMembershipListener |    2 +-
 ...ache.geode.internal.cache.wan.spi.WANFactory |    2 +-
 .../geode/cache/CacheXml70GatewayDUnitTest.java |   48 +-
 .../geode/cache/CacheXml80GatewayDUnitTest.java |   20 +-
 .../AnalyzeWANSerializablesJUnitTest.java       |    8 +-
 .../internal/cache/UpdateVersionDUnitTest.java  |   80 +-
 .../cache/wan/CacheClientNotifierDUnitTest.java |   60 +-
 .../cache/wan/Simple2CacheServerDUnitTest.java  |   50 +-
 .../geode/internal/cache/wan/WANTestBase.java   |  204 +-
 ...oncurrentParallelGatewaySenderDUnitTest.java |   34 +-
 ...ntParallelGatewaySenderOffHeapDUnitTest.java |    8 +-
 ...allelGatewaySenderOperation_1_DUnitTest.java |   22 +-
 ...allelGatewaySenderOperation_2_DUnitTest.java |   32 +-
 ...tSerialGatewaySenderOperationsDUnitTest.java |   20 +-
 ...GatewaySenderOperationsOffHeapDUnitTest.java |    8 +-
 .../ConcurrentWANPropagation_1_DUnitTest.java   |   32 +-
 .../ConcurrentWANPropagation_2_DUnitTest.java   |   20 +-
 .../cache/wan/disttx/DistTXWANDUnitTest.java    |   16 +-
 .../CommonParallelGatewaySenderDUnitTest.java   |   34 +-
 ...onParallelGatewaySenderOffHeapDUnitTest.java |    8 +-
 ...wWANConcurrencyCheckForDestroyDUnitTest.java |   36 +-
 .../wan/misc/NewWanAuthenticationDUnitTest.java |   34 +-
 .../cache/wan/misc/PDXNewWanDUnitTest.java      |   14 +-
 ...dRegion_ParallelWANPersistenceDUnitTest.java |   16 +-
 ...dRegion_ParallelWANPropagationDUnitTest.java |   28 +-
 .../SenderWithTransportFilterDUnitTest.java     |   32 +-
 ...downAllPersistentGatewaySenderDUnitTest.java |   36 +-
 .../wan/misc/WANConfigurationJUnitTest.java     |   32 +-
 .../wan/misc/WANLocatorServerDUnitTest.java     |   42 +-
 .../cache/wan/misc/WANSSLDUnitTest.java         |   20 +-
 .../wan/misc/WanAutoDiscoveryDUnitTest.java     |   26 +-
 .../cache/wan/misc/WanValidationsDUnitTest.java |   38 +-
 ...tewaySenderOperation_2_OffHeapDUnitTest.java |   10 +-
 ...tewaySenderOperation_2_OffHeapDUnitTest.java |   10 +-
 ...GatewaySenderOperationsOffHeapDUnitTest.java |   10 +-
 ...ewaySenderQueueOverflowOffHeapDUnitTest.java |   10 +-
 .../ParallelWANConflationOffHeapDUnitTest.java  |   10 +-
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   10 +-
 ...ropagationConcurrentOpsOffHeapDUnitTest.java |   10 +-
 .../ParallelWANPropagationOffHeapDUnitTest.java |   10 +-
 ...erialGatewaySenderQueueOffHeapDUnitTest.java |   10 +-
 ...nceEnabledGatewaySenderOffHeapDUnitTest.java |   10 +-
 .../SerialWANPropagationOffHeapDUnitTest.java   |    6 +-
 ...ation_PartitionedRegionOffHeapDUnitTest.java |    6 +-
 ...allelGatewaySenderOperation_2_DUnitTest.java |   12 +-
 ...arallelGatewaySenderOperationsDUnitTest.java |   32 +-
 ...llelGatewaySenderQueueOverflowDUnitTest.java |   48 +-
 .../ParallelWANConflationDUnitTest.java         |   12 +-
 ...ersistenceEnabledGatewaySenderDUnitTest.java |   30 +-
 ...llelWANPropagationClientServerDUnitTest.java |    8 +-
 ...lelWANPropagationConcurrentOpsDUnitTest.java |   14 +-
 .../ParallelWANPropagationDUnitTest.java        |   38 +-
 ...ParallelWANPropagationLoopBackDUnitTest.java |   12 +-
 .../wan/parallel/ParallelWANStatsDUnitTest.java |   20 +-
 ...tewaySenderDistributedDeadlockDUnitTest.java |   32 +-
 ...rialGatewaySenderEventListenerDUnitTest.java |   24 +-
 .../SerialGatewaySenderOperationsDUnitTest.java |   44 +-
 .../SerialGatewaySenderQueueDUnitTest.java      |   48 +-
 ...ersistenceEnabledGatewaySenderDUnitTest.java |   16 +-
 .../serial/SerialWANPropagationDUnitTest.java   |   30 +-
 .../SerialWANPropagationLoopBackDUnitTest.java  |   14 +-
 ...NPropagation_PartitionedRegionDUnitTest.java |   22 +-
 .../SerialWANPropagationsFeatureDUnitTest.java  |   10 +-
 .../wan/serial/SerialWANStatsDUnitTest.java     |   14 +-
 .../wan/wancommand/WANCommandTestBase.java      |   40 +-
 ...anCommandCreateGatewayReceiverDUnitTest.java |   40 +-
 .../WanCommandCreateGatewaySenderDUnitTest.java |   40 +-
 ...WanCommandGatewayReceiverStartDUnitTest.java |   30 +-
 .../WanCommandGatewayReceiverStopDUnitTest.java |   30 +-
 .../WanCommandGatewaySenderStartDUnitTest.java  |   26 +-
 .../WanCommandGatewaySenderStopDUnitTest.java   |   26 +-
 .../wan/wancommand/WanCommandListDUnitTest.java |   26 +-
 .../WanCommandPauseResumeDUnitTest.java         |   24 +-
 .../wancommand/WanCommandStatusDUnitTest.java   |   28 +-
 .../management/WANManagementDUnitTest.java      |   28 +-
 .../ClusterConfigurationDUnitTest.java          |  102 +-
 .../pulse/TestRemoteClusterDUnitTest.java       |   48 +-
 .../geode/codeAnalysis/excludedClasses.txt      |    2 +-
 .../org/apache/geode/codeAnalysis/openBugs.txt  |    2 +-
 .../sanctionedDataSerializables.txt             |   14 +-
 .../web/controllers/AbstractBaseController.java |   84 +-
 .../web/controllers/BaseControllerAdvice.java   |   14 +-
 .../web/controllers/CommonCrudController.java   |   26 +-
 .../controllers/FunctionAccessController.java   |   16 +-
 .../web/controllers/PdxBasedCrudController.java |   14 +-
 .../web/controllers/QueryAccessController.java  |   32 +-
 .../web/controllers/support/JSONTypes.java      |    2 +-
 .../controllers/support/QueryResultTypes.java   |    2 +-
 .../web/controllers/support/RegionData.java     |   14 +-
 .../controllers/support/RegionEntryData.java    |   14 +-
 .../support/RestServersResultCollector.java     |    8 +-
 .../web/controllers/support/UpdateOp.java       |    2 +-
 .../DataTypeNotSupportedException.java          |    4 +-
 .../web/exception/GemfireRestException.java     |    4 +-
 .../web/exception/MalformedJsonException.java   |    4 +-
 .../web/exception/RegionNotFoundException.java  |    2 +-
 .../exception/ResourceNotFoundException.java    |    2 +-
 ...stomMappingJackson2HttpMessageConverter.java |    2 +-
 .../web/swagger/config/RestApiPathProvider.java |   10 +-
 .../web/swagger/config/SwaggerConfig.java       |    4 +-
 .../rest/internal/web/util/ArrayUtils.java      |    2 +-
 .../rest/internal/web/util/DateTimeUtils.java   |    2 +-
 .../internal/web/util/IdentifiableUtils.java    |    2 +-
 .../geode/rest/internal/web/util/JSONUtils.java |   30 +-
 .../rest/internal/web/util/JsonWriter.java      |   16 +-
 .../rest/internal/web/util/NumberUtils.java     |    4 +-
 .../rest/internal/web/util/ValidationUtils.java |    2 +-
 .../src/main/webapp/WEB-INF/geode-servlet.xml   |    6 +-
 .../main/webapp/WEB-INF/geode-mgmt-servlet.xml  |    6 +-
 .../cli/commands/CommandOverHttpDUnitTest.java  |    8 +-
 .../ConnectCommandWithHttpAndSSLDUnitTest.java  |   20 +-
 .../DataCommandsOverHttpDistributedTest.java    |   32 +-
 .../GfshCommandsOverHttpSecurityTest.java       |    6 +-
 .../internal/web/AbstractWebTestCase.java       |   10 +-
 .../ShellCommandsControllerJUnitTest.java       |   22 +-
 .../LoginHandlerInterceptorJUnitTest.java       |    4 +-
 .../internal/web/domain/LinkIndexJUnitTest.java |   14 +-
 .../internal/web/domain/LinkJUnitTest.java      |   14 +-
 .../domain/QueryParameterSourceJUnitTest.java   |    8 +-
 .../web/http/ClientHttpRequestJUnitTest.java    |   12 +-
 ...ableObjectHttpMessageConverterJUnitTest.java |    8 +-
 .../RestHttpOperationInvokerJUnitTest.java      |   28 +-
 .../SimpleHttpOperationInvokerJUnitTest.java    |   20 +-
 .../web/util/ConvertUtilsJUnitTest.java         |   10 +-
 .../internal/web/util/UriUtilsJUnitTest.java    |   10 +-
 gradle/rat.gradle                               |   32 +-
 gradle/test.gradle                              |   34 +-
 5846 files changed, 55433 insertions(+), 55433 deletions(-)
----------------------------------------------------------------------



[79/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/DataBrowser.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/DataBrowser.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/DataBrowser.java
deleted file mode 100644
index 668b74c..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/DataBrowser.java
+++ /dev/null
@@ -1,248 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.FileNotFoundException;
-import java.io.FileOutputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.text.SimpleDateFormat;
-import java.util.Iterator;
-import java.util.ResourceBundle;
-import java.util.Scanner;
-
-/**
- * Class DataBrowser This class contains Data browser functionalities for
- * managing queries and histories.
- * 
- * @since GemFire version 7.5.Beta 2013-03-25
- */
-public class DataBrowser {
-
-  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-  private final ResourceBundle resourceBundle = Repository.get()
-      .getResourceBundle();
-
-  private SimpleDateFormat simpleDateFormat = new SimpleDateFormat(
-      PulseConstants.PULSE_QUERY_HISTORY_DATE_PATTERN);
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  /**
-   * addQueryInHistory method adds user's query into query history file
-   * 
-   * @param userId
-   *          Logged in User's Id
-   * @param queryText
-   *          Query text to execute
-   */
-  public boolean addQueryInHistory(String queryText, String userId) {
-    boolean operationStatus = false;
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryText)
-        && StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
-
-      // Fetch all queries from query log file
-      ObjectNode queries = fetchAllQueriesFromFile();
-
-      // Get user's query history list
-      ObjectNode userQueries = (ObjectNode) queries.get(userId);
-      if (userQueries == null) {
-        userQueries = mapper.createObjectNode();
-      }
-
-      // Add query in user's query history list
-      userQueries.put(Long.toString(System.currentTimeMillis()), queryText);
-      queries.put(userId, userQueries);
-
-      // Store queries in file back
-      operationStatus = storeQueriesInFile(queries);
-    }
-
-    return operationStatus;
-  }
-
-  /**
-   * deleteQueryById method deletes query from query history file
-   * 
-   * @param userId
-   *          Logged in user's Unique Id
-   * @param queryId
-   *          Unique Id of Query to be deleted
-   * @return boolean
-   */
-  public boolean deleteQueryById(String userId, String queryId) {
-
-    boolean operationStatus = false;
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryId)
-        && StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
-
-      // Fetch all queries from query log file
-      ObjectNode queries = fetchAllQueriesFromFile();
-
-      // Get user's query history list
-      ObjectNode userQueries = (ObjectNode) queries.get(userId);
-
-      if (userQueries != null) {
-        // Remove user's query
-        userQueries.remove(queryId);
-        queries.put(userId, userQueries);
-
-        // Store queries in file back
-        operationStatus = storeQueriesInFile(queries);
-      }
-    }
-    
-    return operationStatus;
-  }
-
-  /**
-   * getQueryHistoryByUserId method reads and lists out the queries from history
-   * file
-   * 
-   * @param userId
-   *          Logged in User's Id
-   */
-  public ArrayNode getQueryHistoryByUserId(String userId) {
-
-    ArrayNode queryList = mapper.createArrayNode();
-
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(userId)) {
-
-      // Fetch all queries from query log file
-      ObjectNode queries = fetchAllQueriesFromFile();
-      
-      // Get user's query history list
-      ObjectNode userQueries = (ObjectNode) queries.get(userId);
-
-      if (userQueries != null) {
-        Iterator<String> it = userQueries.fieldNames();
-        while (it.hasNext()) {
-          String key = it.next();
-          ObjectNode queryItem = mapper.createObjectNode();
-          queryItem.put("queryId", key);
-          queryItem.put("queryText", userQueries.get(key).toString());
-          queryItem.put("queryDateTime", simpleDateFormat.format(Long.valueOf(key)));
-          queryList.add(queryItem);
-        }
-      }
-    }
-
-    return queryList;
-  }
-
-  /**
-   * generateQueryKey method fetches queries from query history file
-   * 
-   * @return Properties A collection queries in form of key and values
-   */
-  private ObjectNode fetchAllQueriesFromFile() {
-    InputStream inputStream = null;
-    JsonNode queriesJSON = mapper.createObjectNode();
-
-    try {
-      inputStream = new FileInputStream(Repository.get().getPulseConfig().getQueryHistoryFileName());
-      String inputStreamString = new Scanner(inputStream, "UTF-8").useDelimiter("\\A").next();
-      queriesJSON = mapper.readTree(inputStreamString);
-    } catch (FileNotFoundException e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine(resourceBundle
-            .getString("LOG_MSG_DATA_BROWSER_QUERY_HISTORY_FILE_NOT_FOUND")
-            + " : " + e.getMessage());
-      }
-    } catch (Exception e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(e.getMessage());
-      }
-    } finally {
-      // Close input stream
-      if (inputStream != null) {
-        try {
-          inputStream.close();
-        } catch (IOException e) {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(e.getMessage());
-          }
-        }
-      }
-    }
-
-    return (ObjectNode) queriesJSON;
-  }
-
-  /**
-   * generateQueryKey method stores queries in query history file.
-   * 
-   * @return Boolean true is operation is successful, false otherwise
-   */
-  private boolean storeQueriesInFile(ObjectNode queries) {
-    boolean operationStatus = false;
-    FileOutputStream fileOut = null;
-
-    File file = new File(Repository.get().getPulseConfig().getQueryHistoryFileName());
-    try {
-      fileOut = new FileOutputStream(file);
-
-      // if file does not exists, then create it
-      if (!file.exists()) {
-        file.createNewFile();
-      }
-
-      // get the content in bytes
-      byte[] contentInBytes = queries.toString().getBytes();
-
-      fileOut.write(contentInBytes);
-      fileOut.flush();
-
-      operationStatus = true;
-    } catch (FileNotFoundException e) {
-
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine(resourceBundle
-            .getString("LOG_MSG_DATA_BROWSER_QUERY_HISTORY_FILE_NOT_FOUND")
-            + " : " + e.getMessage());
-      }
-    } catch (IOException e) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(e.getMessage());
-      }
-    } finally {
-      if (fileOut != null) {
-        try {
-          fileOut.close();
-        } catch (IOException e) {
-          if (LOGGER.infoEnabled()) {
-            LOGGER.info(e.getMessage());
-          }
-        }
-      }
-    }
-    return operationStatus;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/IClusterUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/IClusterUpdater.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/IClusterUpdater.java
deleted file mode 100644
index 106ea63..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/data/IClusterUpdater.java
+++ /dev/null
@@ -1,35 +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 com.vmware.geode.tools.pulse.internal.data;
-
-import com.fasterxml.jackson.databind.node.ObjectNode;
-
-/**
- * Interface having updateData() function which is getting Override by both
- * MockDataUpdater and JMXDataUpdater
- * 
- * @since GemFire  version 7.0.Beta 2012-09-23
- * 
- */
-public interface IClusterUpdater {
-  boolean updateData();
-
-  ObjectNode executeQuery(String queryText, String members, int limit);
-}


[68/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JMXDataUpdater.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JMXDataUpdater.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JMXDataUpdater.java
new file mode 100644
index 0000000..1dbfea0
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/data/JMXDataUpdater.java
@@ -0,0 +1,2392 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.data;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.JmxManagerFinder.JmxManagerInfo;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+
+import javax.management.Attribute;
+import javax.management.AttributeList;
+import javax.management.AttributeNotFoundException;
+import javax.management.InstanceNotFoundException;
+import javax.management.IntrospectionException;
+import javax.management.InvalidAttributeValueException;
+import javax.management.MBeanException;
+import javax.management.MBeanServerConnection;
+import javax.management.MalformedObjectNameException;
+import javax.management.Notification;
+import javax.management.NotificationListener;
+import javax.management.ObjectName;
+import javax.management.ReflectionException;
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.TabularData;
+import javax.management.remote.JMXConnector;
+import javax.management.remote.JMXConnectorFactory;
+import javax.management.remote.JMXServiceURL;
+import javax.rmi.ssl.SslRMIClientSocketFactory;
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.lang.management.ManagementFactory;
+import java.net.Inet4Address;
+import java.net.Inet6Address;
+import java.net.InetAddress;
+import java.net.UnknownHostException;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Collection;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Map.Entry;
+import java.util.ResourceBundle;
+import java.util.Set;
+
+/**
+ * Class JMXDataUpdater Class used for creating JMX connection and getting all
+ * the required MBeans
+ *
+ *
+ * @since GemFire version 7.0.Beta 2012-09-23
+ */
+public class JMXDataUpdater implements IClusterUpdater, NotificationListener {
+
+  private final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+  private final ResourceBundle resourceBundle = Repository.get()
+      .getResourceBundle();
+
+  private JMXConnector conn = null;
+  private MBeanServerConnection mbs;
+  private final String serverName;
+  private final String port;
+  private final String userName;
+  private final String userPassword;
+  private Boolean isAddedNotiListner = false;
+  private final Cluster cluster;
+
+  // MBean object names
+  private ObjectName MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED;
+  private ObjectName MBEAN_OBJECT_NAME_REGION_DISTRIBUTED;
+  private ObjectName MBEAN_OBJECT_NAME_MEMBER;
+  private ObjectName MBEAN_OBJECT_NAME_MEMBER_MANAGER;
+  private ObjectName MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED;
+  private ObjectName MBEAN_OBJECT_NAME_TABLE_AGGREGATE;
+
+  private Set<ObjectName> systemMBeans = null;
+
+  private final String opSignature[] = { String.class.getName(),
+      String.class.getName(), int.class.getName() };
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  /**
+   * constructor used for creating JMX connection
+   */
+  public JMXDataUpdater(String server, String port, Cluster cluster) {
+    this.serverName = server;
+    this.port = port;
+    this.userName = cluster.getJmxUserName();
+    this.userPassword = cluster.getJmxUserPassword();
+    this.cluster = cluster;
+
+    try {
+      // Initialize MBean object names
+      this.MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED = new ObjectName(
+          PulseConstants.OBJECT_NAME_SYSTEM_DISTRIBUTED);
+      this.MBEAN_OBJECT_NAME_REGION_DISTRIBUTED = new ObjectName(
+          PulseConstants.OBJECT_NAME_REGION_DISTRIBUTED);
+      this.MBEAN_OBJECT_NAME_MEMBER_MANAGER = new ObjectName(
+          PulseConstants.OBJECT_NAME_MEMBER_MANAGER);
+      this.MBEAN_OBJECT_NAME_MEMBER = new ObjectName(
+          PulseConstants.OBJECT_NAME_MEMBER);
+      this.MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED = new ObjectName(
+          PulseConstants.OBJECT_NAME_STATEMENT_DISTRIBUTED);
+
+      // For SQLFire
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
+          .getPulseProductSupport())) {
+        this.MBEAN_OBJECT_NAME_TABLE_AGGREGATE = new ObjectName(
+            PulseConstants.OBJECT_NAME_TABLE_AGGREGATE);
+      }
+
+    } catch (MalformedObjectNameException e) {
+      if (LOGGER.severeEnabled()) {
+        LOGGER.severe(e.getMessage(), e);
+      }
+    } catch (NullPointerException e) {
+      if (LOGGER.severeEnabled()) {
+        LOGGER.severe(e.getMessage(), e);
+      }
+    }
+
+  }
+
+  private JmxManagerInfo getManagerInfoFromLocator(Repository repository) {
+
+    try {
+      String locatorHost = repository.getJmxHost();
+      int locatorPort = Integer.parseInt(repository.getJmxPort());
+
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle.getString("LOG_MSG_HOST") + " : " + locatorHost + " & "
+            + resourceBundle.getString("LOG_MSG_PORT") + " : " + locatorPort);
+      }
+
+      InetAddress inetAddr = InetAddress.getByName(locatorHost);
+
+      if ((inetAddr instanceof Inet4Address) || (inetAddr instanceof Inet6Address)) {
+
+        if (inetAddr instanceof Inet4Address) {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_IPV4_ADDRESS") + " - " + inetAddr.toString());
+          }
+        } else {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_IPV6_ADDRESS") + " - " + inetAddr.toString());
+          }
+        }
+
+        JmxManagerInfo jmxManagerInfo = JmxManagerFinder.askLocatorForJmxManager(inetAddr, locatorPort, 15000,
+            repository.isUseSSLLocator());
+
+        if (jmxManagerInfo.port == 0) {
+          if (LOGGER.infoEnabled()) {
+            LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_COULD_NOT_FIND_MANAGER"));
+          }
+        }
+        return jmxManagerInfo;
+      } else {
+        // Locator has Invalid locator Address
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_BAD_ADDRESS"));
+        }
+        cluster.setConnectionErrorMsg(resourceBundle.getString("LOG_MSG_JMX_CONNECTION_BAD_ADDRESS"));
+        // update message to display on UI
+        cluster.setConnectionErrorMsg(resourceBundle
+            .getString("LOG_MSG_JMX_CONNECTION_BAD_ADDRESS"));
+        return null;
+      }
+    } catch (IOException e) {
+      StringWriter swBuffer = new StringWriter();
+      PrintWriter prtWriter = new PrintWriter(swBuffer);
+      e.printStackTrace(prtWriter);
+      LOGGER.severe("Exception Details : " + swBuffer.toString() + "\n");
+    }
+    return null;
+  }
+
+  /**
+   * Default connection is Pulse which uses configured userName and password
+   */
+  public JMXConnector getJMXConnection() {
+    return getJMXConnection(true);
+  }
+
+  /**
+   * Get connection for given userName and password. This is used for DataBrowser
+   * queries which has to be fired using credentials provided at pulse login page
+   */
+  public JMXConnector getJMXConnection(final boolean registerURL) {
+    JMXConnector connection = null;
+    // Reference to repository
+    Repository repository = Repository.get();
+    try {
+
+      String jmxSerURL = "";
+
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle.getString("LOG_MSG_USE_LOCATOR_VALUE") + ":"
+            + repository.getJmxUseLocator());
+      }
+
+      if (repository.getJmxUseLocator()) {
+        JmxManagerInfo jmxManagerInfo = getManagerInfoFromLocator(repository);
+
+          if (jmxManagerInfo.port == 0) {
+            if (LOGGER.infoEnabled()) {
+              LOGGER.info(resourceBundle
+                  .getString("LOG_MSG_LOCATOR_COULD_NOT_FIND_MANAGER"));
+            }
+          } else {
+            if (LOGGER.infoEnabled()) {
+              LOGGER.info(resourceBundle
+                  .getString("LOG_MSG_LOCATOR_FOUND_MANAGER")
+                  + " : "
+                  + resourceBundle.getString("LOG_MSG_HOST")
+                  + " : "
+                  + jmxManagerInfo.host
+                  + " & "
+                  + resourceBundle.getString("LOG_MSG_PORT")
+                  + " : "
+                  + jmxManagerInfo.port
+                  + (jmxManagerInfo.ssl ? resourceBundle
+                      .getString("LOG_MSG_WITH_SSL") : resourceBundle
+                      .getString("LOG_MSG_WITHOUT_SSL")));
+            }
+
+            jmxSerURL = formJMXServiceURLString(jmxManagerInfo.host,
+                String.valueOf(jmxManagerInfo.port));
+          }
+      } else {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle.getString("LOG_MSG_HOST") + " : "
+              + this.serverName + " & "
+              + resourceBundle.getString("LOG_MSG_PORT") + " : " + this.port);
+        }
+        jmxSerURL = formJMXServiceURLString(this.serverName, this.port);
+      }
+
+      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(jmxSerURL)) {
+        JMXServiceURL url = new JMXServiceURL(jmxSerURL);
+        String[] creds = { this.userName, this.userPassword };
+        Map<String, Object> env = new HashMap<String, Object>();
+        env.put(JMXConnector.CREDENTIALS, creds);
+
+        if (repository.isUseSSLManager()) {
+          // use ssl to connect
+          env.put("com.sun.jndi.rmi.factory.socket",
+              new SslRMIClientSocketFactory());
+        }
+        LOGGER.info("Connecting to jmxURL : " + jmxSerURL);
+        connection = JMXConnectorFactory.connect(url, env);
+
+        // Register Pulse URL if not already present in the JMX Manager
+        if(registerURL)
+          registerPulseUrlToManager(connection);
+      }
+    } catch (Exception e) {
+      if (e instanceof UnknownHostException) {
+        cluster.setConnectionErrorMsg(resourceBundle
+            .getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST"));
+      }
+
+      StringWriter swBuffer = new StringWriter();
+      PrintWriter prtWriter = new PrintWriter(swBuffer);
+      e.printStackTrace(prtWriter);
+      LOGGER.severe("Exception Details : " + swBuffer.toString() + "\n");
+      if (this.conn != null) {
+        try {
+          this.conn.close();
+        } catch (Exception e1) {
+          LOGGER.severe("Error closing JMX connection " + swBuffer.toString()
+              + "\n");
+        }
+        this.conn = null;
+      }
+    }
+    return connection;
+  }
+
+  private String formJMXServiceURLString(String host, String port)
+      throws UnknownHostException {
+    /*
+     * String jmxSerURL = "service:jmx:rmi://" + serverName + "/jndi/rmi://" +
+     * serverName + ":" + port + "/jmxrmi";
+     */
+    String jmxSerURL = "";
+    if (host.equalsIgnoreCase("localhost")) {
+      // Create jmx service url for 'localhost'
+      jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":"
+          + port + "/jmxrmi";
+    } else {
+      InetAddress inetAddr = InetAddress.getByName(host);
+      if (inetAddr instanceof Inet4Address) {
+        // Create jmx service url for IPv4 address
+        jmxSerURL = "service:jmx:rmi://" + host + "/jndi/rmi://" + host + ":"
+            + port + "/jmxrmi";
+      } else if (inetAddr instanceof Inet6Address) {
+        // Create jmx service url for IPv6 address
+        jmxSerURL = "service:jmx:rmi://[" + host + "]/jndi/rmi://[" + host + "]:"
+            + port + "/jmxrmi";
+      }
+    }
+
+    return jmxSerURL;
+  }
+
+  // Method registers Pulse URL if not already present in the JMX Manager
+  private void registerPulseUrlToManager(JMXConnector connection)
+      throws IOException, AttributeNotFoundException,
+      InstanceNotFoundException, MBeanException, ReflectionException,
+      MalformedObjectNameException, InvalidAttributeValueException {
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle
+          .getString("LOG_MSG_REGISTERING_APP_URL_TO_MANAGER"));
+    }
+
+    // Reference to repository
+    Repository repository = Repository.get();
+
+    // Register Pulse URL if not already present in the JMX Manager
+    if (connection != null) {
+      MBeanServerConnection mbsc = connection.getMBeanServerConnection();
+
+      Set<ObjectName> mbeans = mbsc.queryNames(
+          this.MBEAN_OBJECT_NAME_MEMBER_MANAGER, null);
+
+      for (ObjectName mbeanName : mbeans) {
+        String presentUrl = (String) mbsc.getAttribute(mbeanName,
+            PulseConstants.MBEAN_MANAGER_ATTRIBUTE_PULSEURL);
+        String pulseWebAppUrl = repository.getPulseWebAppUrl();
+        if (pulseWebAppUrl != null
+            && (presentUrl == null || !pulseWebAppUrl.equals(presentUrl))) {
+          if (LOGGER.fineEnabled()) {
+            LOGGER.fine(resourceBundle
+                .getString("LOG_MSG_SETTING_APP_URL_TO_MANAGER"));
+          }
+          Attribute pulseUrlAttr = new Attribute(
+              PulseConstants.MBEAN_MANAGER_ATTRIBUTE_PULSEURL, pulseWebAppUrl);
+          mbsc.setAttribute(mbeanName, pulseUrlAttr);
+        } else {
+          if (LOGGER.fineEnabled()) {
+            LOGGER.fine(resourceBundle
+                .getString("LOG_MSG_APP_URL_ALREADY_PRESENT_IN_MANAGER"));
+          }
+        }
+      }
+    }
+  }
+
+  private boolean isConnected() {
+    // Reference to repository
+    Repository repository = Repository.get();
+    if (repository.getIsEmbeddedMode()) {
+      if (this.mbs == null) {
+        this.mbs = ManagementFactory.getPlatformMBeanServer();
+        cluster.setConnectedFlag(true);
+      }
+    } else {
+      try {
+        if (this.conn == null) {
+          cluster.setConnectedFlag(false);
+          cluster.setConnectionErrorMsg(resourceBundle
+              .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND")
+              + " "
+              + resourceBundle.getString("LOG_MSG_JMX_GETTING_NEW_CONNECTION"));
+          if (LOGGER.fineEnabled()) {
+            LOGGER.fine(resourceBundle
+                .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND")
+                + " "
+                + resourceBundle.getString("LOG_MSG_JMX_GET_NEW_CONNECTION"));
+          }
+          this.conn = getJMXConnection();
+          if (this.conn != null) {
+            this.mbs = this.conn.getMBeanServerConnection();
+            cluster.setConnectedFlag(true);
+          } else {
+            if (LOGGER.infoEnabled()) {
+              LOGGER.info(resourceBundle
+                  .getString("LOG_MSG_JMX_CONNECTION_NOT_FOUND"));
+            }
+            return false;
+          }
+        } else {
+          if (LOGGER.fineEnabled()) {
+            LOGGER.fine(resourceBundle
+                .getString("LOG_MSG_JMX_CONNECTION_IS_AVAILABLE"));
+          }
+          cluster.setConnectedFlag(true);
+          if (this.mbs == null) {
+            this.mbs = this.conn.getMBeanServerConnection();
+          }
+        }
+      } catch (Exception e) {
+        this.mbs = null;
+        if (this.conn != null) {
+          try {
+            this.conn.close();
+          } catch (Exception e1) {
+            LOGGER.severe(e);
+          }
+        }
+        this.conn = null;
+        return false;
+      }
+    }
+
+    return true;
+  }
+
+  /**
+   * function used for updating Cluster Data.
+   */
+  @Override
+  public boolean updateData() {
+    try {
+      if (!this.isConnected()) {
+        return false;
+      }
+
+      // deleted Members
+      cluster.getDeletedMembers().clear();
+      for (Entry<String, Cluster.Member> memberSet : cluster.getMembersHMap()
+          .entrySet()) {
+        cluster.getDeletedMembers().add(memberSet.getKey());
+      }
+
+      // Deleted Regions
+      cluster.getDeletedRegions().clear();
+      for (Cluster.Region region : cluster.getClusterRegions().values()) {
+        cluster.getDeletedRegions().add(region.getFullPath());
+      }
+
+      // try {
+
+      // Cluster
+      this.systemMBeans = this.mbs.queryNames(
+          this.MBEAN_OBJECT_NAME_SYSTEM_DISTRIBUTED, null);
+      for (ObjectName sysMBean : this.systemMBeans) {
+        updateClusterSystem(sysMBean);
+      }
+
+      // Cluster Regions/Tables
+      Set<ObjectName> regionMBeans = this.mbs.queryNames(
+          this.MBEAN_OBJECT_NAME_REGION_DISTRIBUTED, null);
+
+      Set<ObjectName> tableMBeans = this.mbs.queryNames(
+          this.MBEAN_OBJECT_NAME_TABLE_AGGREGATE, null);
+
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
+          .getPulseProductSupport())) {
+        // For SQLfire
+        for (ObjectName tableMBean : tableMBeans) {
+          String regNameFromTable = StringUtils
+              .getRegionNameFromTableName(tableMBean.getKeyProperty("table"));
+          for (ObjectName regionMBean : regionMBeans) {
+            String regionName = regionMBean.getKeyProperty("name");
+            if (regNameFromTable.equals(regionName)) {
+              updateClusterRegion(regionMBean);
+              // Increment cluster region count
+              cluster.setTotalRegionCount(cluster.getTotalRegionCount() + 1);
+              break;
+            }
+          }
+        }
+      } else {
+        // For Gemfire
+        for (ObjectName regMBean : regionMBeans) {
+          updateClusterRegion(regMBean);
+        }
+      }
+
+      // Remove deleted regions from cluster's regions list
+      for (Iterator<String> it = cluster.getDeletedRegions().iterator(); it
+          .hasNext();) {
+        cluster.removeClusterRegion(it.next());
+      }
+
+      // Cluster Members
+      Set<ObjectName> memberMBeans = this.mbs.queryNames(
+          this.MBEAN_OBJECT_NAME_MEMBER, null);
+      for (ObjectName memMBean : memberMBeans) {
+        String service = memMBean.getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_SERVICE);
+        if(service==null){
+          // Cluster Member
+          updateClusterMember(memMBean);
+        }
+        else {
+          switch (service) {
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_REGION:
+            if (PulseConstants.PRODUCT_NAME_SQLFIRE
+                .equalsIgnoreCase(PulseController.getPulseProductSupport())) {
+              // For SQLfire
+              for (ObjectName tableMBean : tableMBeans) {
+                String regNameFromTable = StringUtils
+                    .getRegionNameFromTableName(tableMBean
+                        .getKeyProperty("table"));
+                String regionName = memMBean.getKeyProperty("name");
+                if (regNameFromTable.equals(regionName)) {
+                  updateMemberRegion(memMBean);
+                  break;
+                }
+              }
+            } else {
+              // For Gemfire
+              updateMemberRegion(memMBean);
+            }
+            break;
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_CACHESERVER:
+            updateMemberClient(memMBean);
+            break;
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYRECEIVER:
+            updateGatewayReceiver(memMBean);
+            break;
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_GATEWAYSENDER:
+            updateGatewaySender(memMBean);
+            break;
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_ASYNCEVENTQUEUE:
+            updateAsyncEventQueue(memMBean);
+            break;
+          case PulseConstants.MBEAN_KEY_PROPERTY_SERVICE_VALUE_LOCATOR:
+            updateClusterMember(memMBean);
+            break;
+          }
+        }
+      }
+
+      // Cluster Query Statistics
+      Set<ObjectName> statementObjectNames = this.mbs.queryNames(
+          this.MBEAN_OBJECT_NAME_STATEMENT_DISTRIBUTED, null);
+      //LOGGER.info("statementObjectNames = " + statementObjectNames);
+      for (ObjectName stmtObjectName : statementObjectNames) {
+        //LOGGER.info("stmtObjectName = " + stmtObjectName);
+        updateClusterStatement(stmtObjectName);
+      }
+    } catch (IOException ioe) {
+
+      // write errors
+      StringWriter swBuffer = new StringWriter();
+      PrintWriter prtWriter = new PrintWriter(swBuffer);
+      ioe.printStackTrace(prtWriter);
+      LOGGER.severe("IOException Details : " + swBuffer.toString() + "\n");
+      this.mbs = null;
+      if (this.conn != null) {
+        try {
+          this.conn.close();
+        } catch (IOException e1) {
+          LOGGER.severe("Error closing JMX connection " + swBuffer.toString()
+              + "\n");
+        }
+      }
+
+      return false;
+    }
+
+    // If there were members deleted, remove them from the membersList &
+    // physicalToMember.
+    Iterator<String> iterator = cluster.getDeletedMembers().iterator();
+    while (iterator.hasNext()) {
+      String memberKey = iterator.next();
+      if (cluster.getMembersHMap().containsKey(memberKey)) {
+        Cluster.Member member = cluster.getMembersHMap().get(memberKey);
+        List<Cluster.Member> memberArrList = cluster.getPhysicalToMember().get(
+            member.getHost());
+        if (memberArrList != null) {
+          if (memberArrList.contains(member)) {
+            String host = member.getHost();
+            cluster.getPhysicalToMember().get(member.getHost()).remove(member);
+
+            if (cluster.getPhysicalToMember().get(member.getHost()).size() == 0) {
+              cluster.getPhysicalToMember().remove(host);
+            }
+          }
+        }
+        cluster.getMembersHMap().remove(memberKey);
+      }
+
+    }
+
+    return true;
+  }
+
+  /**
+   * function used to get attribute values of Cluster System and map them to
+   * cluster vo
+   *
+   * @param mbeanName
+   *          Cluster System MBean
+   * @throws IOException
+   *
+   */
+  private void updateClusterSystem(ObjectName mbeanName) throws IOException {
+    try {
+      if (!this.isAddedNotiListner) {
+        this.mbs.addNotificationListener(mbeanName, this, null, new Object());
+        this.isAddedNotiListner = true;
+      }
+
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
+          .getPulseProductSupport())) {
+        // Reset to zero
+        cluster.setServerCount(0);
+        cluster.setTotalRegionCount(0);
+      } else {
+        String[] serverCnt = (String[]) (this.mbs.invoke(mbeanName,
+            PulseConstants.MBEAN_OPERATION_LISTSERVERS, null, null));
+        cluster.setServerCount(serverCnt.length);
+      }
+
+      TabularData table = (TabularData) (this.mbs.invoke(mbeanName,
+          PulseConstants.MBEAN_OPERATION_VIEWREMOTECLUSTERSTATUS, null, null));
+
+      Collection<CompositeData> rows = (Collection<CompositeData>) table
+          .values();
+      cluster.getWanInformationObject().clear();
+      for (CompositeData row : rows) {
+        final Object key = row.get("key");
+        final Object value = row.get("value");
+        cluster.getWanInformationObject().put((String) key, (Boolean) value);
+      }
+
+      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+          PulseConstants.CLUSTER_MBEAN_ATTRIBUTES);
+
+      for (int i = 0; i < attributeList.size(); i++) {
+
+        Attribute attribute = (Attribute) attributeList.get(i);
+        String name = attribute.getName();
+        switch (name){
+        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERCOUNT:
+          cluster.setMemberCount(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMCLIENTS:
+          cluster.setClientConnectionCount(getIntegerAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISTRIBUTEDSYSTEMID:
+          cluster.setClusterId(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_LOCATORCOUNT:
+          cluster.setLocatorCount(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMRUNNIGFUNCTION:
+          try {
+            cluster.setRunningFunctionCount(getIntegerAttribute(
+                attribute.getValue(), attribute.getName()));
+          } catch (Exception e) {
+            cluster.setRunningFunctionCount(0);
+            continue;
+          }
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_REGISTEREDCQCOUNT:
+          cluster.setRegisteredCQCount(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMSUBSCRIPTIONS:
+          cluster.setSubscriptionCount(getIntegerAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMTXNCOMMITTED:
+          cluster.setTxnCommittedCount(getIntegerAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMTXNROLLBACK:
+          cluster.setTxnRollbackCount(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALHEAPSIZE:
+          cluster.setTotalHeapSize(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_USEDHEAPSIZE:
+          try {
+            cluster.setUsedHeapSize(getLongAttribute(attribute.getValue(),
+                attribute.getName()));
+          } catch (Exception e) {
+            cluster.setUsedHeapSize((long) 0);
+            continue;
+          }
+          cluster.getMemoryUsageTrend().add(cluster.getUsedHeapSize());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONENTRYCOUNT:
+          cluster.setTotalRegionEntryCount(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_CURRENTENTRYCOUNT:
+          cluster.setCurrentQueryCount(getIntegerAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALDISKUSAGE:
+          try {
+            cluster.setTotalBytesOnDisk(getLongAttribute(attribute.getValue(),
+                attribute.getName()));
+          } catch (Exception e) {
+            cluster.setTotalBytesOnDisk((long) 0);
+            continue;
+          }
+          cluster.getTotalBytesOnDiskTrend().add(cluster.getTotalBytesOnDisk());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+          cluster.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          cluster.getThroughoutWritesTrend().add(cluster.getDiskWritesRate());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEWRITES:
+          try {
+            cluster.setWritePerSec(getDoubleAttribute(attribute.getValue(),
+                attribute.getName()));
+          } catch (Exception e) {
+            cluster.setWritePerSec(0);
+            continue;
+          }
+          cluster.getWritePerSecTrend().add(cluster.getWritePerSec());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEREADS:
+          try {
+            cluster.setReadPerSec(getDoubleAttribute(attribute.getValue(),
+                attribute.getName()));
+          } catch (Exception e) {
+            cluster.setReadPerSec(0);
+            continue;
+          }
+          cluster.getReadPerSecTrend().add(cluster.getReadPerSec());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_QUERYREQUESTRATE:
+          cluster.setQueriesPerSec(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          cluster.getQueriesPerSecTrend().add(cluster.getQueriesPerSec());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+          cluster.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          cluster.getThroughoutReadsTrend().add(cluster.getDiskReadsRate());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_JVMPAUSES:
+          long trendVal = determineCurrentJVMPauses(
+              PulseConstants.JVM_PAUSES_TYPE_CLUSTER, "",
+              getLongAttribute(attribute.getValue(), attribute.getName()));
+          cluster.setGarbageCollectionCount(trendVal);
+          cluster.getGarbageCollectionTrend().add(
+              cluster.getGarbageCollectionCount());
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONCOUNT:
+          if (!PulseConstants.PRODUCT_NAME_SQLFIRE
+              .equalsIgnoreCase(PulseController.getPulseProductSupport())){
+            // for Gemfire
+            cluster.setTotalRegionCount(getIntegerAttribute(
+                attribute.getValue(), attribute.getName()));
+          }
+          break;
+        }
+      }
+
+      // SQLFIRE attributes
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
+          .getPulseProductSupport())) {
+
+        try { // get sqlfire cluster mbean
+
+          ObjectName sfMemberMbeansObjectName = new ObjectName(
+              PulseConstants.OBJECT_NAME_SF_CLUSTER);
+
+          Set<ObjectName> sfCluserMBeans = this.mbs.queryNames(
+              sfMemberMbeansObjectName, null);
+
+          for (ObjectName sfCluserMBean : sfCluserMBeans) {
+
+            AttributeList attrList = this.mbs.getAttributes(sfCluserMBean,
+                PulseConstants.SF_CLUSTER_MBEAN_ATTRIBUTES);
+
+            for (int i = 0; i < attrList.size(); i++) {
+
+              Attribute attribute = (Attribute) attrList.get(i);
+
+              if (attribute.getName().equals(
+                  PulseConstants.MBEAN_ATTRIBUTE_PROCEDURECALLSINPROGRESS)) {
+                try {
+                  cluster.setRunningFunctionCount(getIntegerAttribute(
+                      attribute.getValue(), attribute.getName()));
+                } catch (Exception e) {
+                  cluster.setRunningFunctionCount(0);
+                  continue;
+                }
+              } else if (attribute
+                  .getName()
+                  .equals(
+                      PulseConstants.MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS)) {
+                // set number of cluster's clients
+                CompositeData nscConnStats = (CompositeData) attribute
+                    .getValue();
+
+                cluster.setClientConnectionCount(getLongAttribute(nscConnStats
+                    .get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE),
+                    PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE));
+              }
+            }
+            break;
+          }
+
+        } catch (MalformedObjectNameException e) {
+          LOGGER.warning(e);
+        } catch (NullPointerException e) {
+          LOGGER.warning(e);
+        }
+
+      }
+
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    } catch (MBeanException anfe) {
+      LOGGER.warning(anfe);
+    }
+  }
+
+  /**
+   * function used to get attribute values of Gateway Receiver and map them to
+   * GatewayReceiver inner class object
+   *
+   * @param mbeanName
+   * @return GatewayReceiver object
+   * @throws InstanceNotFoundException
+   * @throws IntrospectionException
+   * @throws ReflectionException
+   * @throws IOException
+   * @throws AttributeNotFoundException
+   * @throws MBeanException
+   *
+   *
+   */
+  private Cluster.GatewayReceiver initGatewayReceiver(ObjectName mbeanName)
+      throws InstanceNotFoundException, IntrospectionException,
+      ReflectionException, IOException, AttributeNotFoundException,
+      MBeanException {
+
+    Cluster.GatewayReceiver gatewayReceiver = new Cluster.GatewayReceiver();
+
+    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+        PulseConstants.GATEWAY_MBEAN_ATTRIBUTES);
+
+    for (int i = 0; i < attributeList.size(); i++) {
+      Attribute attribute = (Attribute) attributeList.get(i);
+
+      if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_PORT)) {
+        gatewayReceiver.setListeningPort(getIntegerAttribute(
+            attribute.getValue(), attribute.getName()));
+      } else if (attribute.getName().equals(
+          PulseConstants.MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE)) {
+        gatewayReceiver.setLinkThroughput(getDoubleAttribute(
+            attribute.getValue(), attribute.getName()));
+      } else if (attribute.getName().equals(
+          PulseConstants.MBEAN_ATTRIBUTE_AVEARGEBATCHPROCESSINGTIME)) {
+        gatewayReceiver.setAvgBatchProcessingTime(getLongAttribute(
+            attribute.getValue(), attribute.getName()));
+      } else if (attribute.getName().equals(
+          PulseConstants.MBEAN_ATTRIBUTE_RUNNING)) {
+        gatewayReceiver.setStatus(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+      }
+    }
+    return gatewayReceiver;
+  }
+
+  /**
+   * function used to get attribute values of Gateway Sender and map them to
+   * GatewaySender inner class object
+   *
+   * @param mbeanName
+   * @return
+   * @throws InstanceNotFoundException
+   * @throws IntrospectionException
+   * @throws ReflectionException
+   * @throws IOException
+   * @throws AttributeNotFoundException
+   * @throws MBeanException
+   */
+  private Cluster.GatewaySender initGatewaySender(ObjectName mbeanName)
+      throws InstanceNotFoundException, IntrospectionException,
+      ReflectionException, IOException, AttributeNotFoundException,
+      MBeanException {
+
+    Cluster.GatewaySender gatewaySender = new Cluster.GatewaySender();
+    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+        PulseConstants.GATEWAYSENDER_MBEAN_ATTRIBUTES);
+
+    for (int i = 0; i < attributeList.size(); i++) {
+      Attribute attribute = (Attribute) attributeList.get(i);
+      String name = attribute.getName();
+      switch (name){
+      case PulseConstants.MBEAN_ATTRIBUTE_EVENTRECEIVEDDATE:
+        gatewaySender.setLinkThroughput(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_BATCHSIZE:
+        gatewaySender.setBatchSize(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_SENDERID:
+        gatewaySender.setId(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_EVENTQUEUESIZE:
+        gatewaySender.setQueueSize(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_RUNNING:
+        gatewaySender.setStatus(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_PRIMARY:
+        gatewaySender.setPrimary(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_PERSISTENCEENABLED:
+        gatewaySender.setPersistenceEnabled(getBooleanAttribute(
+            attribute.getValue(), attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_PARALLEL:
+        gatewaySender.setSenderType(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_REMOTE_DS_ID:
+        gatewaySender.setRemoteDSId(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_EVENTS_EXCEEDING_ALERT_THRESHOLD:
+        gatewaySender.setEventsExceedingAlertThreshold(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      }
+    }
+    return gatewaySender;
+  }
+
+  /**
+   * function used for getting list of Gateway Senders from mBean for giving
+   * member and update the list of gateway senders for respective member object
+   */
+  private void updateGatewaySender(ObjectName mbeanName) throws IOException {
+
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      if (cluster.getMembersHMap().containsKey(memberName)) {
+        Cluster.Member existingMember = cluster.getMembersHMap()
+            .get(memberName);
+        Cluster.GatewaySender gatewaySender = initGatewaySender(mbeanName);
+        for (Iterator<Cluster.GatewaySender> it = existingMember
+            .getGatewaySenderList().iterator(); it.hasNext();) {
+          Cluster.GatewaySender exisGatewaySender = it.next();
+          if ((exisGatewaySender.getId()).equals(gatewaySender.getId())) {
+            it.remove();
+            break;
+          }
+        }
+
+        // Add gateway sender
+        existingMember.getGatewaySenderList().add(gatewaySender);
+
+      } else {
+        Cluster.Member member = new Cluster.Member();
+        member.setName(memberName);
+        member.setId(memberName);
+        Cluster.GatewaySender gatewaySender = initGatewaySender(mbeanName);
+        member.getGatewaySenderList().add(gatewaySender);
+        cluster.getMembersHMap().put(memberName, member);
+      }
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    } catch (MBeanException me) {
+      LOGGER.warning(me);
+    } catch (AttributeNotFoundException anfe) {
+      LOGGER.warning(anfe);
+    } catch (IntrospectionException ire) {
+      LOGGER.warning(ire);
+    }
+  }
+
+  /**
+   * function used to get attribute values of Async Event Queue and map them to
+   * Async Event Queue  inner class object
+   *
+   * @param mbeanName
+   * @return
+   * @throws InstanceNotFoundException
+   * @throws IntrospectionException
+   * @throws ReflectionException
+   * @throws IOException
+   * @throws AttributeNotFoundException
+   * @throws MBeanException
+   */
+  private Cluster.AsyncEventQueue initAsyncEventQueue(ObjectName mbeanName)
+      throws InstanceNotFoundException, IntrospectionException,
+      ReflectionException, IOException, AttributeNotFoundException,
+      MBeanException {
+
+    Cluster.AsyncEventQueue asyncEventQueue = new Cluster.AsyncEventQueue();
+    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+        PulseConstants.ASYNC_EVENT_QUEUE_MBEAN_ATTRIBUTES);
+
+    for (int i = 0; i < attributeList.size(); i++) {
+      Attribute attribute = (Attribute) attributeList.get(i);
+      String name = attribute.getName();
+      switch (name){
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_ASYNCEVENTID:
+        asyncEventQueue.setId(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_ASYNC_EVENT_LISTENER:
+        asyncEventQueue.setAsyncEventListener(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_CONFLATION_ENABLED:
+        asyncEventQueue.setBatchConflationEnabled(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_TIME_INTERVAL:
+        asyncEventQueue.setBatchTimeInterval(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_BATCH_SIZE:
+        asyncEventQueue.setBatchSize(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_EVENT_QUEUE_SIZE:
+        asyncEventQueue.setEventQueueSize(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_PARALLEL:
+        asyncEventQueue.setParallel(getBooleanAttribute(
+            attribute.getValue(), attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AEQ_PRIMARY:
+        asyncEventQueue.setPrimary(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      }
+    }
+    return asyncEventQueue;
+  }
+
+  /**
+   * function used for getting list of Gateway Senders from mBean for giving
+   * member and update the list of gateway senders for respective member object
+   */
+  private void updateAsyncEventQueue(ObjectName mbeanName) throws IOException {
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      if (cluster.getMembersHMap().containsKey(memberName)) {
+        Cluster.Member existingMember = cluster.getMembersHMap()
+            .get(memberName);
+        Cluster.AsyncEventQueue asyncQ = initAsyncEventQueue(mbeanName);
+        for (Iterator<Cluster.AsyncEventQueue> it = existingMember.getAsyncEventQueueList().iterator(); it.hasNext();) {
+          Cluster.AsyncEventQueue exisAsyncEventQueue = it.next();
+          if ((exisAsyncEventQueue.getId()).equals(asyncQ.getId())) {
+            it.remove();
+            break;
+          }
+        }
+
+        // Add async event queue
+        existingMember.getAsyncEventQueueList().add(asyncQ);
+      } else {
+        Cluster.Member member = new Cluster.Member();
+        member.setName(memberName);
+        member.setId(memberName);
+
+        Cluster.AsyncEventQueue asyncQ = initAsyncEventQueue(mbeanName);
+        member.getAsyncEventQueueList().add(asyncQ);
+
+        cluster.getMembersHMap().put(memberName, member);
+      }
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    } catch (MBeanException me) {
+      LOGGER.warning(me);
+    } catch (AttributeNotFoundException anfe) {
+      LOGGER.warning(anfe);
+    } catch (IntrospectionException ire) {
+      LOGGER.warning(ire);
+    }
+  }
+
+  /**
+   * function used for getting a Gateway Receiver from mBean for giving member
+   * and update the gateway receiver for respective member object
+   */
+  private void updateGatewayReceiver(ObjectName mbeanName) throws IOException {
+
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      if (cluster.getMembersHMap().containsKey(memberName)) {
+        Cluster.Member existingMember = cluster.getMembersHMap()
+            .get(memberName);
+        Cluster.GatewayReceiver gatewayReceiver = initGatewayReceiver(mbeanName);
+        existingMember.setGatewayReceiver(gatewayReceiver);
+      } else {
+        Cluster.Member member = new Cluster.Member();
+        member.setName(memberName);
+        member.setId(memberName);
+        Cluster.GatewayReceiver gatewayReceiver = initGatewayReceiver(mbeanName);
+        member.setGatewayReceiver(gatewayReceiver);
+        cluster.getMembersHMap().put(memberName, member);
+      }
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    } catch (MBeanException me) {
+      LOGGER.warning(me);
+    } catch (AttributeNotFoundException anfe) {
+      LOGGER.warning(anfe);
+    } catch (IntrospectionException ire) {
+      LOGGER.warning(ire);
+    }
+  }
+
+  /**
+   * function used for getting member clients from mbean and update the clients
+   * information in member object's client arraylist
+   */
+  private void updateMemberClient(ObjectName mbeanName) throws IOException {
+
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      if (cluster.getMembersHMap().containsKey(memberName)) {
+        Cluster.Member existingMember = cluster.getMembersHMap()
+            .get(memberName);
+        HashMap<String, Cluster.Client> memberClientsHM = new HashMap<String, Cluster.Client>();
+
+        existingMember.setMemberPort(""
+            + this.mbs.getAttribute(mbeanName,
+                PulseConstants.MBEAN_ATTRIBUTE_PORT));
+
+        this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT);
+        existingMember.setHostnameForClients((String)this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS_ALT));
+        existingMember.setBindAddress((String)this.mbs.getAttribute(mbeanName, PulseConstants.MBEAN_ATTRIBUTE_BINDADDRESS));
+
+        CompositeData[] compositeData = (CompositeData[]) (this.mbs.invoke(
+            mbeanName, PulseConstants.MBEAN_OPERATION_SHOWALLCLIENTS, null,
+            null));
+        for (CompositeData cmd : compositeData) {
+          Cluster.Client client = new Cluster.Client();
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CLIENTID)) {
+            client.setId((String) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_CLIENTID));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NAME)) {
+            client.setName((String) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_NAME));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_HOSTNAME)) {
+            client.setHost((String) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_HOSTNAME));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_QUEUESIZE)) {
+            client.setQueueSize((Integer) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_QUEUESIZE));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_PROCESSCPUTIME)) {
+            client.setProcessCpuTime((Long) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_PROCESSCPUTIME));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_UPTIME)) {
+            client.setUptime((Long) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_UPTIME));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFTHREADS)) {
+            client.setThreads((Integer) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFTHREADS));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFGETS)) {
+            client.setGets((Integer) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFGETS));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_NUMOFPUTS)) {
+            client.setPuts((Integer) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_NUMOFPUTS));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CPUS)) {
+            client.setCpus((Integer) cmd
+                .get(PulseConstants.COMPOSITE_DATA_KEY_CPUS));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CPUS)) {
+            client.setCpuUsage(0);
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CONNECTED)){
+            client.setConnected((Boolean) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTED));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_CLIENTCQCOUNT)){
+        	client.setClientCQCount((Integer) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_CLIENTCQCOUNT));
+          }
+          if (cmd.containsKey(PulseConstants.COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED)){
+            client.setSubscriptionEnabled((Boolean) cmd.get(PulseConstants.COMPOSITE_DATA_KEY_SUBSCRIPTIONENABLED));
+          }
+          memberClientsHM.put(client.getId(), client);
+        }
+        existingMember.updateMemberClientsHMap(memberClientsHM);
+      }
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    } catch (MBeanException me) {
+      LOGGER.warning(me);
+    } catch (AttributeNotFoundException anfe) {
+      LOGGER.warning(anfe);
+    }
+  }
+
+  /**
+   * Add member specific region information on the region
+   *
+   * @param regionObjectName: used to construct the jmx objectname. For region name that has special characters in, it will have double quotes around it.
+   * @param region
+   */
+  private void updateRegionOnMembers(String regionObjectName, String regionFullPath, Cluster.Region region) throws IOException {
+
+    try{
+        List<String> memberNamesTemp = region.getMemberName();
+        ArrayList<String> memberNames = new ArrayList<String>(memberNamesTemp);
+
+        List<Cluster.RegionOnMember> regionOnMemberList = new ArrayList<Cluster.RegionOnMember>();
+        List<Cluster.RegionOnMember> regionOnMemberListNew = new ArrayList<Cluster.RegionOnMember>();
+        Cluster.RegionOnMember[] regionOnMemberNames = region.getRegionOnMembers();
+
+        if ((regionOnMemberNames != null) && (regionOnMemberNames.length > 0)) {
+          regionOnMemberList = new ArrayList<Cluster.RegionOnMember>(Arrays.asList(regionOnMemberNames));
+        }
+        LOGGER.fine("updateRegionOnMembers : # regionOnMembers objects in region = " + regionOnMemberList.size());
+
+        for(Cluster.RegionOnMember anRom : regionOnMemberList) {
+
+          for(String memberName : memberNames){
+            if(anRom.getMemberName().equals(memberName)){
+              // Add regionOnMember object in new list
+              regionOnMemberListNew.add(anRom);
+
+              LOGGER.fine("updateRegionOnMembers : Processing existing Member name = " + anRom.getMemberName());
+              String objectNameROM = PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObjectName + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + anRom.getMemberName();
+              ObjectName regionOnMemberMBean = new ObjectName(objectNameROM);
+              LOGGER.fine("updateRegionOnMembers : Object name = " + regionOnMemberMBean.getCanonicalName());
+
+              AttributeList attributeList = this.mbs.getAttributes(regionOnMemberMBean, PulseConstants.REGION_ON_MEMBER_MBEAN_ATTRIBUTES);
+              for (int i = 0; i < attributeList.size(); i++) {
+                Attribute attribute = (Attribute) attributeList.get(i);
+                String name = attribute.getName();
+                switch(name){
+                case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
+                  anRom.setEntrySize(getLongAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getEntrySize() = " + anRom.getEntrySize());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_ENTRYCOUNT:
+                  anRom.setEntryCount(getLongAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getEntryCount() = " + anRom.getEntryCount());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
+                  anRom.setPutsRate(getDoubleAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getPutsRate() = " + anRom.getPutsRate());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
+                  anRom.setGetsRate(getDoubleAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getGetsRate() = " + anRom.getGetsRate());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+                  anRom.setDiskGetsRate(getDoubleAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getDiskGetsRate() = " + anRom.getDiskGetsRate());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+                  anRom.setDiskPutsRate(getDoubleAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getDiskPutsRate() = " + anRom.getDiskPutsRate());
+                  break;
+                case PulseConstants.MBEAN_ATTRIBUTE_LOCALMAXMEMORY:
+                  anRom.setLocalMaxMemory(getIntegerAttribute(attribute.getValue(),
+                      attribute.getName()));
+                  LOGGER.fine("updateRegionOnMembers : anRom.getLocalMaxMemory() = " + anRom.getLocalMaxMemory());
+                  break;
+                }
+              }
+
+              anRom.getGetsPerSecTrend().add(anRom.getGetsRate());
+              anRom.getPutsPerSecTrend().add(anRom.getPutsRate());
+              anRom.getDiskReadsPerSecTrend().add(anRom.getDiskGetsRate());
+              anRom.getDiskWritesPerSecTrend().add(anRom.getDiskPutsRate());
+              LOGGER.fine("updateRegionOnMembers : Existing member on region : getGetsRate() = " + anRom.getGetsPerSecTrend().size() + ", getPutsRate() = "
+                  + anRom.getPutsPerSecTrend().size() + ", getDiskGetsRate() = " + anRom.getDiskReadsPerSecTrend().size() + ", getDiskPutsRate() = "
+                  + anRom.getDiskWritesPerSecTrend().size());
+
+              //remove existing member names from list so only new ones will remain
+              memberNames.remove(anRom.getMemberName());
+
+              break;
+            }
+          }
+        }
+
+        LOGGER.fine("updateRegionOnMembers : Loop over remaining member names and adding new member in region. Existing count = " + regionOnMemberList.size());
+        LOGGER.fine("updateRegionOnMembers : Remaining new members in this region = " + memberNames.size());
+        //loop over the remaining regions members and add new members for this region
+        for(String memberName : memberNames) {
+          String objectNameROM = PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_REGION + regionObjectName + PulseConstants.OBJECT_NAME_REGION_ON_MEMBER_MEMBER + memberName;
+          ObjectName regionOnMemberMBean = new ObjectName(objectNameROM);
+          Cluster.RegionOnMember regionOnMember = new Cluster.RegionOnMember();
+          regionOnMember.setMemberName(memberName);
+          regionOnMember.setRegionFullPath(regionFullPath);
+          AttributeList attributeList = this.mbs.getAttributes(regionOnMemberMBean, PulseConstants.REGION_ON_MEMBER_MBEAN_ATTRIBUTES);
+          for (int i = 0; i < attributeList.size(); i++) {
+            Attribute attribute = (Attribute) attributeList.get(i);
+            String name=attribute.getName();
+            switch (name){
+            case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
+              regionOnMember.setEntrySize(getLongAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_ENTRYCOUNT:
+              regionOnMember.setEntryCount(getLongAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
+              regionOnMember.setPutsRate(getDoubleAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
+              regionOnMember.setGetsRate(getDoubleAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+              regionOnMember.setDiskGetsRate(getDoubleAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+              regionOnMember.setDiskPutsRate(getDoubleAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            case PulseConstants.MBEAN_ATTRIBUTE_LOCALMAXMEMORY:
+              regionOnMember.setLocalMaxMemory(getIntegerAttribute(attribute.getValue(),
+                  attribute.getName()));
+              break;
+            }
+          }
+
+          regionOnMember.getGetsPerSecTrend().add(regionOnMember.getGetsRate());
+          regionOnMember.getPutsPerSecTrend().add(regionOnMember.getPutsRate());
+          regionOnMember.getDiskReadsPerSecTrend().add(regionOnMember.getDiskGetsRate());
+          regionOnMember.getDiskWritesPerSecTrend().add(regionOnMember.getDiskPutsRate());
+
+          LOGGER.fine("updateRegionOnMembers : Adding New member on region : getGetsRate() = " + regionOnMember.getGetsRate() + ", getPutsRate() = "
+              + regionOnMember.getPutsRate() + ", getDiskGetsRate() = " + regionOnMember.getDiskGetsRate() + ", getDiskPutsRate() = "
+              + regionOnMember.getDiskPutsRate());
+
+          regionOnMemberListNew.add(regionOnMember);
+        }
+
+        //set region on member
+        region.setRegionOnMembers(regionOnMemberListNew);
+        LOGGER.fine("updateRegionOnMembers : Total regions on member in region " + region.getFullPath() + " after update = " + region.getRegionOnMembers().length);
+    } catch (MalformedObjectNameException e) {
+      LOGGER.warning(e);
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    }
+  }
+
+  /**
+   * function used to get attribute values of Cluster Region and map them to
+   * cluster region vo
+   *
+   * @param mbeanName
+   *          Cluster Region MBean
+   */
+  private void updateClusterRegion(ObjectName mbeanName) throws IOException {
+
+    try {
+
+      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+          PulseConstants.REGION_MBEAN_ATTRIBUTES);
+
+      // retrieve the full path of the region
+      String regionObjectName = mbeanName.getKeyProperty("name");
+      String regionFullPath = null;
+      for (int i = 0; i < attributeList.size(); i++) {
+        Attribute attribute = (Attribute) attributeList.get(i);
+
+        if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_FULLPATH)) {
+          regionFullPath = getStringAttribute(attribute.getValue(),
+              attribute.getName());
+          break;
+        }
+      }
+
+      Cluster.Region region = cluster.getClusterRegions().get(regionFullPath);
+
+      if (null == region) {
+        region = new Cluster.Region();
+      }
+
+      for (int i = 0; i < attributeList.size(); i++) {
+
+        Attribute attribute = (Attribute) attributeList.get(i);
+
+        String name = attribute.getName();
+        switch (name){
+        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERS:
+          String memName[] = (String[]) attribute.getValue();
+          region.getMemberName().clear();
+          for (int k = 0; k < memName.length; k++) {
+            region.getMemberName().add(memName[k]);
+          }
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_FULLPATH:
+          region.setFullPath(getStringAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+          region.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+          region.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_EMPTYNODES:
+          region.setEmptyNode(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
+          region.setGetsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_LRUEVICTIONRATE:
+          region.setLruEvictionRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_PUTSRATE:
+          region.setPutsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_REGIONTYPE:
+          region.setRegionType(getStringAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_ENTRYSIZE:
+          region.setEntrySize(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_SYSTEMREGIONENTRYCOUNT:
+          region.setSystemRegionEntryCount(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_MEMBERCOUNT:
+          region.setMemberCount(getIntegerAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_PERSISTENTENABLED:
+          region.setPersistentEnabled(getBooleanAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NAME:
+          region.setName(getStringAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_GATEWAYENABLED:
+          region.setWanEnabled(getBooleanAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKUSAGE:
+          region.setDiskUsage(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        }
+      }
+
+      //add for each member
+      updateRegionOnMembers(regionObjectName, regionFullPath, region);
+
+      cluster.addClusterRegion(regionFullPath, region);
+      cluster.getDeletedRegions().remove(region.getFullPath());
+      // Memory Reads and writes
+      region.getPutsPerSecTrend().add(region.getPutsRate());
+      region.getGetsPerSecTrend().add(region.getGetsRate());
+      // Disk Reads and Writes
+      region.getDiskReadsPerSecTrend().add(region.getDiskReadsRate());
+      region.getDiskWritesPerSecTrend().add(region.getDiskWritesRate());
+
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    }
+  }
+
+  private static boolean isQuoted(String value) {
+    final int len = value.length();
+    if (len < 2 || value.charAt(0) != '"' || value.charAt(len - 1) != '"') {
+      return false;
+    } else {
+      return true;
+    }
+  }
+
+  private void updateClusterStatement(ObjectName mbeanName) throws IOException {
+
+    try {
+
+      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+          PulseConstants.STATEMENT_MBEAN_ATTRIBUTES);
+      // retrieve the full path of the region
+      String statementDefinition = mbeanName.getKeyProperty("name");
+
+      if (isQuoted(statementDefinition)) {
+        statementDefinition = ObjectName.unquote(statementDefinition);
+      }
+
+      Cluster.Statement statement = cluster.getClusterStatements().get(
+          statementDefinition);
+
+      if (null == statement) {
+        statement = new Cluster.Statement();
+        statement.setQueryDefinition(statementDefinition);
+      }
+
+      for (int i = 0; i < attributeList.size(); i++) {
+        Attribute attribute = (Attribute) attributeList.get(i);
+        String name = attribute.getName();
+        switch (name){
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED:
+          statement.setNumTimesCompiled(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION:
+          statement.setNumExecution(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS:
+          statement.setNumExecutionsInProgress(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP:
+          statement.setNumTimesGlobalIndexLookup(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED:
+          statement.setNumRowsModified(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_PARSETIME:
+          statement.setParseTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_BINDTIME:
+          statement.setBindTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME:
+          statement.setOptimizeTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME:
+          statement.setRoutingInfoTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME:
+          statement.setGenerateTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME:
+          statement.setTotalCompilationTime(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME:
+          statement.setExecutionTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME:
+          statement.setProjectionTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME:
+          statement.setTotalExecutionTime(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME:
+          statement.setRowsModificationTime(getLongAttribute(
+              attribute.getValue(), attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN:
+          statement.setqNNumRowsSeen(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME:
+          statement.setqNMsgSendTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME:
+          statement.setqNMsgSerTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME:
+          statement.setqNRespDeSerTime(getLongAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        }
+      }
+
+      cluster.addClusterStatement(statementDefinition, statement);
+      // TODO : to store data for sparklines later
+      /*
+       * region.getPutsPerSecTrend().add(region.getPutsRate());
+       * region.getGetsPerSecTrend().add(region.getGetsRate());
+       */
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    }
+  }
+
+  /**
+   * function used to iterate through all member attributes and return the
+   * updated member
+   */
+  private Cluster.Member initializeMember(ObjectName mbeanName,
+      Cluster.Member member) throws InstanceNotFoundException,
+                                    ReflectionException, IOException {
+
+    AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+        PulseConstants.MEMBER_MBEAN_ATTRIBUTES);
+
+    for (int i = 0; i < attributeList.size(); i++) {
+
+      Attribute attribute = (Attribute) attributeList.get(i);
+      String name = attribute.getName();
+      switch (name) {
+      case PulseConstants.MBEAN_ATTRIBUTE_GEMFIREVERSION:
+        if (member.getGemfireVersion() == null) {
+          // Set Member's GemFire Version if not set already
+          String gemfireVersion = obtainGemfireVersion(getStringAttribute(
+              attribute.getValue(), attribute.getName()));
+          member.setGemfireVersion(gemfireVersion);
+        }
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_MANAGER:
+        member.setManager(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_TOTALREGIONCOUNT:
+        member.setTotalRegionCount(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_LOCATOR:
+        member.setLocator(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_TOTALDISKUSAGE:
+        member.setTotalDiskUsage(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_SERVER:
+        member.setServer(getBooleanAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_TOTALFILEDESCRIPTOROPEN:
+        member.setTotalFileDescriptorOpen(getLongAttribute(
+            attribute.getValue(), attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_LOADAVERAGE:
+        member.setLoadAverage(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+        member.setThroughputWrites(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getThroughputWritesTrend().add(member.getThroughputWrites());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+        member.setThroughputReads(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getThroughputReadsTrend().add(member.getThroughputReads());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_JVMPAUSES:
+        long trendVal = determineCurrentJVMPauses(
+            PulseConstants.JVM_PAUSES_TYPE_MEMBER, member.getName(),
+            getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.setGarbageCollectionCount(trendVal);
+        member.getGarbageCollectionSamples().add(
+            member.getGarbageCollectionCount());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_USEDMEMORY:
+        member.setCurrentHeapSize(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getHeapUsageSamples().add(member.getCurrentHeapSize());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_MAXMEMORY:
+        member.setMaxHeapSize(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_NUMTHREADS:
+        member.setNumThreads(getIntegerAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_MEMBERUPTIME:
+        member.setUptime(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_HOST:
+        member.setHost(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_HOSTNAMEFORCLIENTS:
+        member.setHostnameForClients(getStringAttribute(attribute.getValue(),
+                attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_BINDADDRESS:
+        member.setBindAddress(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_TOTALBYTESONDISK:
+        member.setTotalBytesOnDisk(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getTotalBytesOnDiskSamples().add(member.getTotalBytesOnDisk());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_CPUUSAGE:
+        member.setCpuUsage(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getCpuUsageSamples().add(member.getCpuUsage());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_HOSTCPUUSAGE:
+        // Float value is expected for host cpu usage.
+        // TODO Remove Float.valueOf() when float value is provided in mbean
+        member.setHostCpuUsage(Double.valueOf(getIntegerAttribute(
+            attribute.getValue(), attribute.getName())));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_MEMBER:
+        member.setName(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_ID:
+        member.setId(getStringAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEREADS:
+        member.setGetsRate(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getGetsPerSecond().add(member.getGetsRate());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_AVERAGEWRITES:
+        member.setPutsRate(getDoubleAttribute(attribute.getValue(),
+            attribute.getName()));
+        member.getPutsPerSecond().add(member.getPutsRate());
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_OFFHEAPFREESIZE:
+        member.setOffHeapFreeSize(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_OFFHEAPUSEDSIZE:
+        member.setOffHeapUsedSize(getLongAttribute(attribute.getValue(),
+            attribute.getName()));
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_SERVERGROUPS:
+        String sgValues[] = (String[]) attribute.getValue();
+        member.getServerGroups().clear();
+        for (int k = 0; k < sgValues.length; k++) {
+          member.getServerGroups().add(sgValues[k]);
+        }
+        break;
+      case PulseConstants.MBEAN_ATTRIBUTE_REDUNDANCYZONES:
+        String rzValue = "";
+        if(null != attribute.getValue()){
+          rzValue = getStringAttribute(attribute.getValue(),
+              attribute.getName());
+        }
+        member.getRedundancyZones().clear();
+        if(!rzValue.isEmpty()){
+          member.getRedundancyZones().add(rzValue);
+        }
+        break;
+      }
+    }
+
+    // SQLFire specific attributes
+    if (PulseController.getPulseProductSupport().equalsIgnoreCase(
+        PulseConstants.PRODUCT_NAME_SQLFIRE)) {
+
+      try {
+        // get sqlfire mbeans
+        String memberName = mbeanName
+            .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+        ObjectName sfMemberMbeansObjectName = new ObjectName(
+            PulseConstants.OBJECT_NAME_SF_MEMBER_PATTERN + memberName);
+
+        Set<ObjectName> sfMemberMBeans = this.mbs.queryNames(
+            sfMemberMbeansObjectName, null);
+        for (ObjectName sfMemberMBean : sfMemberMBeans) {
+
+          AttributeList attrList = this.mbs.getAttributes(sfMemberMBean,
+              PulseConstants.SF_MEMBER_MBEAN_ATTRIBUTES);
+          for (int i = 0; i < attrList.size(); i++) {
+
+            Attribute attribute = (Attribute) attrList.get(i);
+
+            if (attribute.getName().equals(
+                PulseConstants.MBEAN_ATTRIBUTE_DATASTORE)) {
+              member.setServer(getBooleanAttribute(attribute.getValue(),
+                  attribute.getName()));
+
+              // Update Server count
+              if (member.isServer()) {
+                cluster.setServerCount(cluster.getServerCount() + 1);
+              }
+            } else if (attribute.getName().equals(
+                    PulseConstants.MBEAN_ATTRIBUTE_NETWORKSERVERCLIENTCONNECTIONSTATS)) {
+
+              CompositeData nscConnStats = (CompositeData) attribute.getValue();
+
+              // Update sqlfire client count
+              member.setNumSqlfireClients(getLongAttribute(nscConnStats
+                  .get(PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE),
+                  PulseConstants.COMPOSITE_DATA_KEY_CONNECTIONSACTIVE));
+            }
+          }
+          break;
+        }
+
+      } catch (MalformedObjectNameException e) {
+        LOGGER.warning(e);
+      } catch (NullPointerException e) {
+        LOGGER.warning(e);
+      }
+
+    }
+
+    return member;
+  }
+
+  /**
+   * function used to get attribute values of Cluster Member and map them to
+   * cluster member vo
+   *
+   * @param mbeanName
+   *          Cluster Member MBean
+   */
+  private void updateClusterMember(ObjectName mbeanName) throws IOException {
+
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      Cluster.Member clusterMember = cluster.getMembersHMap().get(memberName);
+
+      if (clusterMember != null) // checking if member exists or not
+      {
+        cluster.getDeletedMembers().remove(memberName);
+      } else {
+        clusterMember = new Cluster.Member();
+        cluster.getMembersHMap().put(memberName, clusterMember);
+      }
+
+      // initialize member and add to cluster's member list
+      clusterMember = initializeMember(mbeanName, clusterMember);
+      ArrayList<Cluster.Member> memberArrList = (ArrayList<Cluster.Member>) cluster
+          .getPhysicalToMember().get(clusterMember.getHost());
+      if (memberArrList != null) {
+        if (!memberArrList.contains(clusterMember)) {
+          memberArrList.add(clusterMember);
+        }
+      } else {
+        ArrayList<Cluster.Member> memberList = new ArrayList<Cluster.Member>();
+        memberList.add(clusterMember);
+        cluster.getPhysicalToMember().put(clusterMember.getHost(), memberList);
+      }
+    } catch (InstanceNotFoundException infe) {
+      LOGGER.warning(infe);
+    } catch (ReflectionException re) {
+      LOGGER.warning(re);
+    }
+  }
+
+  /**
+   * function used to handle Float data type if the value for mbean for an
+   * attribute is null then return 0.0 as default value else return the
+   * attribute value
+   */
+  private Float getFloatAttribute(Object object, String name) {
+    if (object == null) {
+      return Float.valueOf(0.0f);
+    }
+
+    try {
+      if (!(object.getClass().equals(Float.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + Float.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return Float.valueOf(0.0f);
+      } else {
+        return (Float) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception occurred: " + e.getMessage());
+      }
+      return Float.valueOf(0.0f);
+    }
+  }
+
+  /**
+   * function used to handle Integer data type if the value for mbean for an
+   * attribute is null then return 0 as default value else return the attribute
+   * value
+   */
+  private Integer getIntegerAttribute(Object object, String name) {
+    if (object == null) {
+      return Integer.valueOf(0);
+    }
+
+    try {
+      if (!(object.getClass().equals(Integer.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + Integer.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return Integer.valueOf(0);
+      } else {
+        return (Integer) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception occurred: " + e.getMessage());
+      }
+      return Integer.valueOf(0);
+    }
+  }
+
+  /**
+   * function used to handle Long data type if the value for mbean for an
+   * attribute is null then return 0 as default value else return the attribute
+   * value
+   */
+  private Long getLongAttribute(Object object, String name) {
+    if (object == null) {
+      return Long.valueOf(0);
+    }
+
+    try {
+      if (!(object.getClass().equals(Long.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + Long.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return Long.valueOf(0);
+      } else {
+        return (Long) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception occurred: " + e.getMessage());
+      }
+      return Long.valueOf(0);
+    }
+
+  }
+
+  /**
+   * function used to handle String data type if the value for mbean for an
+   * attribute is null then return the empty string as default value else return
+   * the attribute value
+   */
+  private String getStringAttribute(Object object, String name) {
+    if (object == null) {
+      return "";
+    }
+
+    try {
+      if (!(object.getClass().equals(String.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + String.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return "";
+      } else {
+        return (String) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception occurred: " + e.getMessage());
+      }
+      return "";
+    }
+  }
+
+  /**
+   * function used to handle Boolean data type if the value for mbean for an
+   * attribute is null then return false as default value else return the
+   * attribute value
+   */
+  private Boolean getBooleanAttribute(Object object, String name) {
+    if (object == null) {
+      return Boolean.FALSE;
+    }
+
+    try {
+      if (!(object.getClass().equals(Boolean.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + Boolean.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return Boolean.FALSE;
+      } else {
+        return (Boolean) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception Occured: " + e.getMessage());
+      }
+      return Boolean.FALSE;
+    }
+  }
+
+  /**
+   * function used to handle Double data type if the value for mbean for an
+   * attribute is null then return 0.0 as default value else return the
+   * attribute value
+   */
+  private Double getDoubleAttribute(Object object, String name) {
+    if (object == null) {
+      return Double.valueOf(0);
+    }
+
+    try {
+      if (!(object.getClass().equals(Double.class))) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info("************************Unexpected type for attribute: "
+              + name + " Expected type: " + Double.class.getName()
+              + " Received type: " + object.getClass().getName()
+              + "************************");
+        }
+        return Double.valueOf(0);
+      } else {
+        return (Double) object;
+      }
+    } catch (Exception e) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info("Exception occurred: " + e.getMessage());
+      }
+      return Double.valueOf(0);
+    }
+  }
+
+  /**
+   * function used to get attribute values of Member Region and map them to
+   * Member vo
+   *
+   * @param mbeanName
+   *          Member Region MBean
+   */
+  private void updateMemberRegion(ObjectName mbeanName) throws IOException {
+
+    try {
+      String memberName = mbeanName
+          .getKeyProperty(PulseConstants.MBEAN_KEY_PROPERTY_MEMBER);
+
+      Cluster.Member member = cluster.getMembersHMap().get(memberName);
+
+      //Following attributes are not present in 9.0
+      //"Members"
+      //"EmptyNodes"
+      //"SystemRegionEntryCount"
+      //"MemberCount"
+      AttributeList attributeList = this.mbs.getAttributes(mbeanName,
+          PulseConstants.REGION_MBEAN_ATTRIBUTES);
+
+      // retrieve the full path of the region
+      String regionFullPathKey = null;
+      for (int i = 0; i < attributeList.size(); i++) {
+        Attribute attribute = (Attribute) attributeList.get(i);
+
+        if (attribute.getName().equals(PulseConstants.MBEAN_ATTRIBUTE_FULLPATH)) {
+          regionFullPathKey = getStringAttribute(attribute.getValue(),
+              attribute.getName());
+          break;
+        }
+      }
+
+      // if member does not exists defined for this region then create a member
+      if (null == member) {
+        member = new Cluster.Member();
+        member.setName(memberName);
+        cluster.getMembersHMap().put(memberName, member);
+      }
+
+      // if region with given path exists then update same else add new region
+      Cluster.Region region = member.getMemberRegions().get(regionFullPathKey);
+      if (null == region) {
+        region = new Cluster.Region();
+        member.getMemberRegions().put(regionFullPathKey, region);
+        member.setTotalRegionCount(member.getTotalRegionCount() + 1);
+      }
+      region.setFullPath(regionFullPathKey); // use already retrieved values
+
+      // update the existing or new region
+      for (int i = 0; i < attributeList.size(); i++) {
+        Attribute attribute = (Attribute) attributeList.get(i);
+        String name = attribute.getName();
+        switch (name){
+        case PulseConstants.MBEAN_ATTRIBUTE_FULLPATH:
+          region.setFullPath(getStringAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKREADSRATE:
+          region.setDiskReadsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_DISKWRITESRATE:
+          region.setDiskWritesRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN_ATTRIBUTE_GETSRATE:
+          region.setGetsRate(getDoubleAttribute(attribute.getValue(),
+              attribute.getName()));
+          break;
+        case PulseConstants.MBEAN

<TRUNCATED>


[81/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/PulseAppListener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/PulseAppListener.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/PulseAppListener.java
deleted file mode 100644
index 408eed3..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/PulseAppListener.java
+++ /dev/null
@@ -1,742 +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 com.vmware.geode.tools.pulse.internal;
-
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.PulseConfig;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.web.context.WebApplicationContext;
-import org.springframework.web.context.support.WebApplicationContextUtils;
-
-import javax.servlet.ServletContextEvent;
-import javax.servlet.ServletContextListener;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.net.InetAddress;
-import java.net.UnknownHostException;
-import java.text.DateFormat;
-import java.text.SimpleDateFormat;
-import java.util.Date;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Map.Entry;
-import java.util.Properties;
-import java.util.ResourceBundle;
-import java.util.Set;
-import java.util.logging.Level;
-
-/**
- * This class is used for checking the application running mode i.e. Embedded or
- * not
- * 
- * @since GemFire version 7.0.Beta 2012-09-23
- * 
- */
-// @WebListener
-public class PulseAppListener implements ServletContextListener {
-  private PulseLogWriter LOGGER;
-  private final ResourceBundle resourceBundle = Repository.get()
-      .getResourceBundle();
-
-  // String object to store all messages which needs to be logged into the log
-  // file before logger gets initialized
-  private String messagesToBeLogged = "";
-
-  private Properties pulseProperties;
-  private Properties pulseSecurityProperties;
-  private Boolean sysPulseUseLocator;
-  private String sysPulseHost;
-  private String sysPulsePort;
-  private String jmxUserName;
-  private String jmxUserPassword;
-  
-  private boolean sysPulseUseSSLLocator;
-  private boolean sysPulseUseSSLManager;
-  
-  //This property determines if pulse webApp login is authenticated against
-  //GemFire integrated security or custom spring-security config provided 
-  //in pulse-authentication-custom.xml 
-  private boolean useGemFireCredentials;
-
-  @Override
-  public void contextDestroyed(ServletContextEvent event) {
-
-    // Stop all running threads those are created in Pulse
-    // Stop cluster threads
-    Repository.get().removeAllClusters();
-
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_CONTEXT_DESTROYED")
-          + event.getServletContext().getContextPath());
-    }
-  }
-
-  @Override
-  public void contextInitialized(ServletContextEvent event) {
-    
-    messagesToBeLogged = messagesToBeLogged
-        .concat(formatLogString(resourceBundle
-            .getString("LOG_MSG_CONTEXT_INITIALIZED")));
-
-    // Load Pulse version details
-    loadPulseVersionDetails();
-
-    // Load Pulse Properties
-    pulseProperties = loadProperties(PulseConstants.PULSE_PROPERTIES_FILE);
-
-    if (pulseProperties.isEmpty()) {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_PROPERTIES_NOT_FOUND")));
-    } else {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_PROPERTIES_FOUND")));
-
-      // set Pulse product support into the Pulse controller for access from
-      // client side
-      // to display the appropriate ui depending on which product is supported
-      // in present deployment
-      String pulseProduct = pulseProperties.getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_PRODUCTSUPPORT);
-      // default is gemfire
-
-      if ((pulseProduct != null) && (pulseProduct.trim().equalsIgnoreCase(PulseConstants.PRODUCT_NAME_SQLFIRE))) {
-        PulseController.setPulseProductSupport(PulseConstants.PRODUCT_NAME_SQLFIRE);
-      }
-    }
-    
-    pulseSecurityProperties = loadProperties(PulseConstants.PULSE_SECURITY_PROPERTIES_FILE);
-
-    // Initialize logger
-    initializeLogger();
-
-    // Reference to repository
-    Repository repository = Repository.get();
-
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_CHECK_APP_RUNNING_MODE"));
-    }
-
-    boolean sysIsEmbedded = Boolean
-        .getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_EMBEDDED);
-
-    if (sysIsEmbedded) {
-      // Application Pulse is running in Embedded Mode
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle
-            .getString("LOG_MSG_APP_RUNNING_EMBEDDED_MODE"));
-      }
-      repository.setIsEmbeddedMode(true);
-
-      sysPulseUseLocator = Boolean.FALSE;
-	  try{
-				// Get host name of machine running pulse in embedded mode
-		   sysPulseHost = InetAddress.getLocalHost().getCanonicalHostName();
-		} catch (UnknownHostException e) {
-			if (LOGGER.fineEnabled()) {
-				LOGGER.fine(resourceBundle
-							.getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST")
-							+ e.getMessage());
-		    }
-				// Set default host name
-		    sysPulseHost = PulseConstants.GEMFIRE_DEFAULT_HOST;
-		} catch (Exception e) {
-			if (LOGGER.fineEnabled()) {
-					LOGGER.fine(resourceBundle
-							.getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST")
-							+ e.getMessage());
-			}
-				// Set default host name
-			sysPulseHost = PulseConstants.GEMFIRE_DEFAULT_HOST;
-		}
-      sysPulsePort = PulseConstants.GEMFIRE_DEFAULT_PORT;
-      
-      boolean pulseEmbededSqlf = Boolean.getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_EMBEDDED_SQLF);
-      if(pulseEmbededSqlf){
-        PulseController.setPulseProductSupport(PulseConstants.PRODUCT_NAME_SQLFIRE);
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle
-              .getString("LOG_MSG_APP_RUNNING_EMBEDDED_SQLF_MODE"));
-        }
-      }
-
-    } else {
-      // Application Pulse is running in Non-Embedded Mode
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle
-            .getString("LOG_MSG_APP_RUNNING_NONEMBEDDED_MODE"));
-      }
-      repository.setIsEmbeddedMode(false);
-
-      // Load JMX User Details
-      loadJMXUserDetails();
-      // Load locator and/or manager details
-      loadLocatorManagerDetails();
-       
-      useGemFireCredentials = areWeUsingGemFireSecurityProfile(event); 
-    }
-
-    // Set user details in repository    
-    repository.setJmxUserName(jmxUserName);
-    repository.setJmxUserPassword(jmxUserPassword);
-
-    // Set locator/Manager details in repository
-    repository.setJmxUseLocator(sysPulseUseLocator);
-    repository.setJmxHost(sysPulseHost);
-    repository.setJmxPort(sysPulsePort);
-    
-    //set SSL info
-    initializeSSL();
-    repository.setUseSSLLocator(sysPulseUseSSLLocator);
-    repository.setUseSSLManager(sysPulseUseSSLManager);
-    
-    repository.setUseGemFireCredentials(useGemFireCredentials);
-
-  }
-
-  /**
-   * Return true if pulse is configure to authenticate using gemfire
-   * integrated security
-   * 
-   * @param event
-   * @return
-   */
-  private boolean areWeUsingGemFireSecurityProfile(ServletContextEvent event) {
-    String profile = null;
-    WebApplicationContext ctx = WebApplicationContextUtils.getWebApplicationContext(event.getServletContext());
-    if (ctx.getEnvironment() != null) {
-      String[] profiles = ctx.getEnvironment().getActiveProfiles();
-      if (profiles != null && profiles.length > 0) {
-        StringBuilder sb = new StringBuilder();
-        for (String p : profiles)
-          sb.append(p).append(",");
-        LOGGER.info("#SpringProfilesConfigured : " + sb.toString());
-        profile = ctx.getEnvironment().getActiveProfiles()[0];
-        LOGGER.info("#First Profile : " + profile);
-      } else {
-        LOGGER.info("No SpringProfileConfigured using default spring profile");
-        return false;
-      }
-    }
-    if (PulseConstants.APPLICATION_PROPERTY_PULSE_SEC_PROFILE_GEMFIRE.equals(profile)) {
-      LOGGER.info("Using gemfire integrated security profile");
-      return true;
-    }      
-    return false;
-  }
-
-  // Function to load pulse version details from properties file
-  private void loadPulseVersionDetails() {
-
-    // Read version details from version property file
-    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-    InputStream inputStream = classLoader
-        .getResourceAsStream(PulseConstants.PULSE_VERSION_PROPERTIES_FILE);
-
-    if (inputStream != null) {
-      Properties properties = new Properties();
-      try {
-        properties.load(inputStream);
-      } catch (IOException e) {
-        messagesToBeLogged = messagesToBeLogged
-            .concat(formatLogString(resourceBundle
-                .getString("LOG_MSG_EXCEPTION_LOADING_PROPERTIES_FILE")));
-      } finally {
-        try {
-          inputStream.close();
-        } catch (IOException e) {
-          messagesToBeLogged = messagesToBeLogged
-              .concat(formatLogString(resourceBundle
-                  .getString("LOG_MSG_EXCEPTION_CLOSING_INPUT_STREAM")));
-        }
-      }
-      // Set pulse version details in common object
-      PulseController.pulseVersion.setPulseVersion(properties.getProperty(
-          PulseConstants.PROPERTY_PULSE_VERSION, ""));
-      PulseController.pulseVersion.setPulseBuildId(properties.getProperty(
-          PulseConstants.PROPERTY_BUILD_ID, ""));
-      PulseController.pulseVersion.setPulseBuildDate(properties.getProperty(
-          PulseConstants.PROPERTY_BUILD_DATE, ""));
-      PulseController.pulseVersion.setPulseSourceDate(properties.getProperty(
-          PulseConstants.PROPERTY_SOURCE_DATE, ""));
-      PulseController.pulseVersion.setPulseSourceRevision(properties
-          .getProperty(PulseConstants.PROPERTY_SOURCE_REVISION, ""));
-      PulseController.pulseVersion.setPulseSourceRepository(properties
-          .getProperty(PulseConstants.PROPERTY_SOURCE_REPOSITORY, ""));
-    }
-
-    // Log Pulse Version details into log file
-    messagesToBeLogged = messagesToBeLogged
-        .concat(formatLogString(PulseController.pulseVersion
-            .getPulseVersionLogMessage()));
-  }
-
-  private void initializeLogger() {
-
-    // Override default log configuration by properties which are provided in
-    // properties file.
-    loadLogDetailsFromPropertyFile();
-
-    // Override log configuration by properties which are provided in
-    // through system properties.
-    loadLogDetailsFromSystemProperties();
-
-    // Initialize logger object
-    LOGGER = PulseLogWriter.getLogger();
-
-    // Log messages stored in messagesToBeLogged
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(messagesToBeLogged);
-      messagesToBeLogged = "";
-    }
-  }
-
-  // Function to load pulse properties from pulse.properties file
-  private Properties loadProperties(String propertyFile) {
-
-    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-    InputStream inputStream = classLoader.getResourceAsStream(propertyFile);
-    Properties properties = new Properties();
-
-    if (inputStream != null) {
-      messagesToBeLogged = messagesToBeLogged.concat(formatLogString(propertyFile + " "
-          + resourceBundle.getString("LOG_MSG_FILE_FOUND")));
-
-      try {
-        // Load properties from input stream
-        properties.load(inputStream);
-      } catch (IOException e1) {
-        messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
-            .getString("LOG_MSG_EXCEPTION_LOADING_PROPERTIES_FILE")
-            + " " + propertyFile));
-      } finally {
-        // Close input stream
-        try {
-          inputStream.close();
-        } catch (IOException e) {
-          messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_EXCEPTION_CLOSING_INPUT_STREAM")
-              + " " + propertyFile));
-        }
-      }
-
-    } else {
-      messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
-          .getString("LOG_MSG_COULD_NOT_READ_FILE")
-          + " " + propertyFile));
-    }
-    return properties;
-  }
-
-  // Function to load Logging details from properties file
-  private void loadLogDetailsFromPropertyFile() {
-
-    // return, if Pulse Properties are not provided
-    if (pulseProperties.size() == 0) {
-      return;
-    }
-
-    messagesToBeLogged = messagesToBeLogged
-        .concat(formatLogString(resourceBundle
-            .getString("LOG_MSG_CHECK_LOG_PROPERTIES_IN_FILE")));
-
-    HashMap<String, String> logPropertiesHM = new HashMap<String, String>();
-
-    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME, ""));
-
-    logPropertiesHM.put(
-        PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION, ""));
-
-    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE, ""));
-
-    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT, ""));
-
-    logPropertiesHM.put(
-        PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN, ""));
-
-    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL, ""));
-
-    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
-        pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND, ""));
-
-    if (logPropertiesHM.size() == 0) {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_LOG_PROPERTIES_NOT_FOUND_IN_FILE")));
-    } else {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_LOG_PROPERTIES_FOUND_IN_FILE")));
-    }
-
-    setLogConfigurations(logPropertiesHM);
-  }
-
-  // Function to load Logging details from system properties
-  private void loadLogDetailsFromSystemProperties() {
-
-    messagesToBeLogged = messagesToBeLogged
-        .concat(formatLogString(resourceBundle
-            .getString("LOG_MSG_CHECK_LOG_PROPERTIES_IN_SYSTEM_PROPERTIES")));
-
-    HashMap<String, String> logPropertiesHM = new HashMap<String, String>();
-
-    String sysLogFileName = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME);
-    String sysLogFileLocation = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION);
-    String sysLogFileSize = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE);
-    String sysLogFileCount = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT);
-    String sysLogDatePattern = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN);
-    String sysLogLevel = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL);
-    String sysLogAppend = System
-        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND);
-
-    if (sysLogFileName == null || sysLogFileName.isEmpty()) {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME, "");
-    } else {
-      logPropertiesHM
-          .put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME,
-              sysLogFileName);
-    }
-
-    if (sysLogFileLocation == null || sysLogFileLocation.isEmpty()) {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION, "");
-    } else {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION,
-          sysLogFileLocation);
-    }
-
-    if (sysLogFileSize == null || sysLogFileSize.isEmpty()) {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE, "");
-    } else {
-      logPropertiesHM
-          .put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE,
-              sysLogFileSize);
-    }
-
-    if (sysLogFileCount == null || sysLogFileCount.isEmpty()) {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT, "");
-    } else {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT,
-          sysLogFileCount);
-    }
-
-    if (sysLogDatePattern == null || sysLogDatePattern.isEmpty()) {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN, "");
-    } else {
-      logPropertiesHM.put(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN,
-          sysLogDatePattern);
-    }
-
-    if (sysLogLevel == null || sysLogLevel.isEmpty()) {
-      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
-          "");
-    } else {
-      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
-          sysLogLevel);
-    }
-
-    if (sysLogAppend == null || sysLogAppend.isEmpty()) {
-      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
-          "");
-    } else {
-      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
-          sysLogAppend);
-    }
-
-    if (logPropertiesHM.size() == 0) {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_LOG_PROPERTIES_NOT_FOUND_IN_SYSTEM_PROPERTIES")));
-    } else {
-      messagesToBeLogged = messagesToBeLogged
-          .concat(formatLogString(resourceBundle
-              .getString("LOG_MSG_LOG_PROPERTIES_FOUND_IN_SYSTEM_PROPERTIES")));
-    }
-
-    setLogConfigurations(logPropertiesHM);
-  }
-
-  private void setLogConfigurations(HashMap<String, String> logPropertiesHM) {
-
-    PulseConfig pulseConfig = Repository.get().getPulseConfig();
-
-    // log file name
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME))) {
-      pulseConfig.setLogFileName(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME));
-    }
-
-    // log file location
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION))) {
-      pulseConfig.setLogFileLocation(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION));
-    }
-
-    // log file size
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE))) {
-      pulseConfig.setLogFileSize(Integer.parseInt(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE)));
-    }
-
-    // log file count
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT))) {
-      pulseConfig.setLogFileCount(Integer.parseInt(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT)));
-    }
-
-    // log message date pattern
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN))) {
-      pulseConfig.setLogDatePattern(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN));
-    }
-
-    // log level
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL))) {
-      pulseConfig.setLogLevel(Level.parse(logPropertiesHM.get(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL).toUpperCase()));
-    }
-
-    // log append
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
-        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND))) {
-      pulseConfig.setLogAppend(Boolean.valueOf(logPropertiesHM
-          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND)));
-    }
-
-  }
-
-  // Function to load JMX User details from properties
-  private void loadJMXUserDetails() {
-
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_JMX_USER_DETAILS"));
-    }
-
-    if (pulseProperties.isEmpty()) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER
-            .info(resourceBundle
-                .getString("LOG_MSG_JMX_USER_DETAILS_NOT_FOUND")
-                + resourceBundle
-                    .getString("LOG_MSG_REASON_USER_DETAILS_NOT_FOUND"));
-      }
-    } else {
-      jmxUserName = pulseProperties.getProperty(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_JMXUSERNAME, "");
-      jmxUserPassword = pulseProperties.getProperty(
-          PulseConstants.APPLICATION_PROPERTY_PULSE_JMXPASSWORD, "");
-
-      if (jmxUserName.isEmpty() || jmxUserPassword.isEmpty()) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle
-              .getString("LOG_MSG_JMX_USER_DETAILS_NOT_FOUND")
-              + resourceBundle
-                  .getString("LOG_MSG_REASON_USER_DETAILS_NOT_FOUND"));
-        }
-      } else {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle
-              .getString("LOG_MSG_JMX_USER_DETAILS_FOUND"));
-        }
-      }
-    }
-  }
-  
-//Function to set SSL VM arguments
-  private void initializeSSL() {
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_SSL_DETAILS"));
-    }
-
-     
-    this.sysPulseUseSSLLocator = Boolean.valueOf(pulseProperties.getProperty(
-        PulseConstants.SYSTEM_PROPERTY_PULSE_USESSL_LOCATOR, "false"));
-
-    this.sysPulseUseSSLManager = Boolean.valueOf(pulseProperties.getProperty(
-        PulseConstants.SYSTEM_PROPERTY_PULSE_USESSL_MANAGER, "false"));
-
-
-    if ((sysPulseUseSSLLocator || sysPulseUseSSLManager)) {
-      Properties sslProperties = new Properties();
-      if (!pulseSecurityProperties.isEmpty()) {
-        Set entrySet = pulseSecurityProperties.entrySet();
-        for (Iterator it = entrySet.iterator(); it.hasNext();) {
-          Entry<String, String> entry = (Entry<String, String>) it.next();
-          String key = entry.getKey();
-          if (key.startsWith("javax.net.ssl.")) {
-
-            String val = entry.getValue();
-            System.setProperty(key, val);
-            sslProperties.setProperty(key, val);
-          }
-        }
-      }
-      if (sslProperties.isEmpty()) {
-        if (LOGGER.warningEnabled()) {
-          LOGGER.warning(resourceBundle.getString("LOG_MSG_SSL_NOT_SET"));
-        }
-      }
-    }
-
-  }
-
-  // Function to load locator and/or manager details
-  private void loadLocatorManagerDetails() {
-
-    // Get locator details through System Properties
-    if (LOGGER.infoEnabled()) {
-      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_LOCATOR_DETAILS_1"));
-    }
-
-    // Required System properties are
-    // -Dpulse.embedded="false" -Dpulse.useLocator="false"
-    // -Dpulse.host="192.168.2.11" -Dpulse.port="2099"
-    sysPulseUseLocator = Boolean
-        .getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_USELOCATOR);
-    sysPulseHost = System
-        .getProperty(PulseConstants.SYSTEM_PROPERTY_PULSE_HOST);
-    sysPulsePort = System
-        .getProperty(PulseConstants.SYSTEM_PROPERTY_PULSE_PORT);
-
-    if (sysPulseHost == null || sysPulseHost.isEmpty() || sysPulsePort == null
-        || sysPulsePort.isEmpty()) {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle
-            .getString("LOG_MSG_LOCATOR_DETAILS_NOT_FOUND")
-            + resourceBundle
-                .getString("LOG_MSG_REASON_LOCATOR_DETAILS_NOT_FOUND_1"));
-        LOGGER.info(resourceBundle.getString("LOG_MSG_GET_LOCATOR_DETAILS_2"));
-      }
-
-      if (pulseProperties.isEmpty()) {
-        if (LOGGER.infoEnabled()) {
-          LOGGER.info(resourceBundle
-              .getString("LOG_MSG_LOCATOR_DETAILS_NOT_FOUND")
-              + resourceBundle
-                  .getString("LOG_MSG_REASON_LOCATOR_DETAILS_NOT_FOUND_2"));
-        }
-
-        sysPulseHost = "";
-        sysPulsePort = "";
-      } else {
-        if (LOGGER.infoEnabled()) {
-          LOGGER
-              .info(resourceBundle.getString("LOG_MSG_LOCATOR_DETAILS_FOUND"));
-        }
-
-        sysPulseUseLocator = Boolean.valueOf(pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_USELOCATOR, ""));
-        sysPulseHost = pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_HOST, "");
-        sysPulsePort = pulseProperties.getProperty(
-            PulseConstants.APPLICATION_PROPERTY_PULSE_PORT, "");
-      }
-    } else {
-      if (LOGGER.infoEnabled()) {
-        LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_DETAILS_FOUND"));
-      }
-    }
-  }
-
-  private String formatLogString(String logMessage) {
-
-    DateFormat df = new SimpleDateFormat(
-        PulseConstants.LOG_MESSAGE_DATE_PATTERN);
-    // DateFormat df = new
-    // SimpleDateFormat(Repository.get().getPulseConfig().getLogDatePattern());
-    StringWriter sw = new StringWriter();
-    PrintWriter pw = new PrintWriter(sw);
-
-    pw.println();
-    pw.print("[");
-    pw.print("INFO");
-    pw.print(" ");
-    pw.print(df.format(new Date(System.currentTimeMillis())));
-    String threadName = Thread.currentThread().getName();
-    if (threadName != null) {
-      pw.print(" ");
-      pw.print(threadName);
-    }
-    pw.print(" tid=0x");
-    pw.print(Long.toHexString(Thread.currentThread().getId()));
-    pw.print("] ");
-    pw.print("(msgTID=");
-    pw.print("");
-
-    pw.print(" msgSN=");
-    pw.print("");
-
-    pw.print(") ");
-
-    pw.println("[" + PulseConstants.APP_NAME + "]");
-
-    pw.println(PulseLogWriter.class.getName());
-
-    pw.println(logMessage);
-
-    pw.close();
-    try {
-      sw.close();
-    } catch (IOException ignore) {
-    }
-    String result = sw.toString();
-    return result;
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
deleted file mode 100644
index 9e86637..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
+++ /dev/null
@@ -1,51 +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 com.vmware.geode.tools.pulse.internal.controllers;
-
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-
-import org.springframework.http.HttpStatus;
-import org.springframework.web.bind.annotation.ControllerAdvice;
-import org.springframework.web.bind.annotation.ExceptionHandler;
-import org.springframework.web.bind.annotation.ResponseStatus;
-
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-
-/**
- * For handling IO exception in our controllers
- * 
- * 
- */
-@ControllerAdvice
-public class ExceptionHandlingAdvice {
-
-  @ExceptionHandler(IOException.class)
-  @ResponseStatus(HttpStatus.INTERNAL_SERVER_ERROR)
-  public void handleExc(IOException ext) {
-    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-    // write errors
-    StringWriter swBuffer = new StringWriter();
-    PrintWriter prtWriter = new PrintWriter(swBuffer);
-    ext.printStackTrace(prtWriter);
-    LOGGER.severe("IOException Details : " + swBuffer.toString() + "\n");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/PulseController.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/PulseController.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/PulseController.java
deleted file mode 100644
index 32fd810..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/controllers/PulseController.java
+++ /dev/null
@@ -1,524 +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 com.vmware.geode.tools.pulse.internal.controllers;
-
-import java.io.IOException;
-import java.util.Collection;
-import java.util.Iterator;
-import java.util.List;
-import javax.servlet.http.HttpServletRequest;
-import javax.servlet.http.HttpServletResponse;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.PulseVersion;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-import com.vmware.geode.tools.pulse.internal.service.PulseService;
-import com.vmware.geode.tools.pulse.internal.service.PulseServiceFactory;
-import com.vmware.geode.tools.pulse.internal.service.SystemAlertsService;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-
-import org.apache.commons.lang.StringEscapeUtils;
-import org.springframework.beans.factory.annotation.Autowired;
-import org.springframework.stereotype.Controller;
-import org.springframework.web.bind.annotation.RequestMapping;
-import org.springframework.web.bind.annotation.RequestMethod;
-
-/**
- * Class PulseController
- * 
- * This class contains the implementations for all http Ajax requests needs to
- * be served in Pulse.
- * 
- * @since GemFire version 7.5
- */
-@Controller
-public class PulseController {
-
-  private static final PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-
-  // CONSTANTS
-  private final String DEFAULT_EXPORT_FILENAME = "DataBrowserQueryResult.json";
-  private final String QUERYSTRING_PARAM_ACTION = "action";
-  private final String QUERYSTRING_PARAM_QUERYID = "queryId";
-  private final String ACTION_VIEW = "view";
-  private final String ACTION_DELETE = "delete";
-
-  private String STATUS_REPSONSE_SUCCESS = "success";
-  private String STATUS_REPSONSE_FAIL = "fail";
-
-  private String ERROR_REPSONSE_QUERYNOTFOUND = "No queries found";
-  private String ERROR_REPSONSE_QUERYIDMISSING = "Query id is missing";
-
-  private static final String EMPTY_JSON = "{}";
-
-  // Shared object to hold pulse version details
-  public static PulseVersion pulseVersion = new PulseVersion();
-
-  //default is gemfire
-  private static String pulseProductSupport = PulseConstants.PRODUCT_NAME_GEMFIRE;
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  @Autowired
-  PulseServiceFactory pulseServiceFactory;
-
-  @RequestMapping(value = "/pulseUpdate", method = RequestMethod.POST)
-  public void getPulseUpdate(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    String pulseData = request.getParameter("pulseData");
-
-    ObjectNode responseMap = mapper.createObjectNode();
-
-    JsonNode requestMap = null;
-
-    try {
-      requestMap = mapper.readTree(pulseData);
-      Iterator<?> keys = requestMap.fieldNames();
-
-      // Execute Services
-      while (keys.hasNext()) {
-        String serviceName = keys.next().toString();
-        try {
-          PulseService pulseService = pulseServiceFactory
-              .getPulseServiceInstance(serviceName);
-          responseMap.put(serviceName, pulseService.execute(request));
-        } catch (Exception serviceException) {
-          LOGGER.warning("serviceException [for service "+serviceName+"] = " + serviceException.getMessage());
-          responseMap.put(serviceName, EMPTY_JSON);
-        }
-      }
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occurred : " + e.getMessage());
-      }
-    }
-
-    // Create Response
-    response.getOutputStream().write(responseMap.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/authenticateUser", method = RequestMethod.GET)
-  public void authenticateUser(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    try {
-      responseJSON.put("isUserLoggedIn", this.isUserLoggedIn(request));
-      // Send json response
-      response.getOutputStream().write(responseJSON.toString().getBytes());
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occurred : " + e.getMessage());
-      }
-    }
-  }
-
-  /**
-   * Method isUserLoggedIn Check whether user is logged in or not.
-   * 
-   * @param request
-   * @return boolean
-   */
-  protected boolean isUserLoggedIn(HttpServletRequest request) {
-    return null != request.getUserPrincipal();
-  }
-
-  @RequestMapping(value = "/pulseVersion", method = RequestMethod.GET)
-  public void pulseVersion(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    try {
-      // Reference to repository
-      Repository repository = Repository.get();
-      // set pulse web app url
-      String pulseWebAppUrl = request.getScheme() + "://"
-          + request.getServerName() + ":" + request.getServerPort()
-          + request.getContextPath();
-
-      repository.setPulseWebAppUrl(pulseWebAppUrl);
-
-      // Response
-      responseJSON.put("pulseVersion", PulseController.pulseVersion.getPulseVersion());
-      responseJSON.put("buildId", PulseController.pulseVersion.getPulseBuildId());
-      responseJSON.put("buildDate", PulseController.pulseVersion.getPulseBuildDate());
-      responseJSON.put("sourceDate", PulseController.pulseVersion.getPulseSourceDate());
-      responseJSON.put("sourceRevision", PulseController.pulseVersion.getPulseSourceRevision());
-      responseJSON.put("sourceRepository", PulseController.pulseVersion.getPulseSourceRepository());
-
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-
-    // Send json response
-    response.getOutputStream().write(responseJSON.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/clearAlerts", method = RequestMethod.GET)
-  public void clearAlerts(HttpServletRequest request, HttpServletResponse response) throws IOException {
-    int alertType;
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    try {
-      alertType = Integer.valueOf(request.getParameter("alertType"));
-    } catch (NumberFormatException e) {
-      // Empty json response
-      response.getOutputStream().write(responseJSON.toString().getBytes());
-      if (LOGGER.finerEnabled()) {
-        LOGGER.finer(e.getMessage());
-      }
-      return;
-    }
-
-    try {
-      boolean isClearAll = Boolean.valueOf(request.getParameter("clearAll"));
-      // get cluster object
-      Cluster cluster = Repository.get().getCluster();
-      cluster.clearAlerts(alertType, isClearAll);
-      responseJSON.put("status", "deleted");
-      responseJSON.put(
-          "systemAlerts", SystemAlertsService.getAlertsJson(cluster,
-              cluster.getNotificationPageNumber()));
-      responseJSON.put("pageNumber", cluster.getNotificationPageNumber());
-
-      boolean isGFConnected = cluster.isConnectedFlag();
-      if(isGFConnected){
-        responseJSON.put("connectedFlag", isGFConnected);
-      }else{
-        responseJSON.put("connectedFlag", isGFConnected);
-        responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
-      }
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occurred : " + e.getMessage());
-      }
-    }
-
-    // Send json response
-    response.getOutputStream().write(responseJSON.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/acknowledgeAlert", method = RequestMethod.GET)
-  public void acknowledgeAlert(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    int alertId;
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    try {
-      alertId = Integer.valueOf(request.getParameter("alertId"));
-    } catch (NumberFormatException e) {
-      // Empty json response
-      response.getOutputStream().write(responseJSON.toString().getBytes());
-      if (LOGGER.finerEnabled()) {
-        LOGGER.finer(e.getMessage());
-      }
-      return;
-    }
-
-    try {
-      // get cluster object
-      Cluster cluster = Repository.get().getCluster();
-
-      // set alert is acknowledged
-      cluster.acknowledgeAlert(alertId);
-      responseJSON.put("status", "deleted");
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-
-    // Send json response
-    response.getOutputStream().write(responseJSON.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/dataBrowserRegions", method = RequestMethod.GET)
-  public void dataBrowserRegions(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-    ArrayNode regionsData = mapper.createArrayNode();
-
-    try {
-      // getting cluster's Regions
-      responseJSON.put("clusterName", cluster.getServerName());
-      regionsData = getRegionsJson(cluster);
-      responseJSON.put("clusterRegions", regionsData);
-      responseJSON.put("connectedFlag", cluster.isConnectedFlag());
-      responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-
-    // Send json response
-    response.getOutputStream().write(responseJSON.toString().getBytes());
-  }
-
-  /**
-   * This method creates json for list of cluster regions
-   * 
-   * @param cluster
-   * @return ArrayNode JSON array
-   */
-  private ArrayNode getRegionsJson(Cluster cluster) {
-
-    Collection<Cluster.Region> clusterRegions = cluster.getClusterRegions().values();
-    ArrayNode regionsListJson = mapper.createArrayNode();
-
-    if (!clusterRegions.isEmpty()) {
-      for (Cluster.Region region : clusterRegions) {
-        ObjectNode regionJSON = mapper.createObjectNode();
-        regionJSON.put("name", region.getName());
-        regionJSON.put("fullPath", region.getFullPath());
-        regionJSON.put("regionType", region.getRegionType());
-
-        if (region.getRegionType().contains("PARTITION")) {
-          regionJSON.put("isPartition", true);
-        } else {
-          regionJSON.put("isPartition", false);
-        }
-
-        regionJSON.put("memberCount", region.getMemberCount());
-        List<String> regionsMembers = region.getMemberName();
-        ArrayNode jsonRegionMembers = mapper.createArrayNode();
-
-        for (int i = 0; i < regionsMembers.size(); i++) {
-          Cluster.Member member = cluster.getMembersHMap().get(
-              regionsMembers.get(i));
-          ObjectNode jsonMember = mapper.createObjectNode();
-          jsonMember.put("key", regionsMembers.get(i));
-          jsonMember.put("id", member.getId());
-          jsonMember.put("name", member.getName());
-
-          jsonRegionMembers.add(jsonMember);
-        }
-
-        regionJSON.put("members", jsonRegionMembers);
-        regionsListJson.add(regionJSON);
-      }
-    }
-    return regionsListJson;
-  }
-
-  @RequestMapping(value = "/dataBrowserQuery", method = RequestMethod.GET)
-  public void dataBrowserQuery(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    // get query string
-    String query = request.getParameter("query");
-    String members = request.getParameter("members");
-    int limit = 0;
-
-    try {
-      limit = Integer.valueOf(request.getParameter("limit"));
-    } catch (NumberFormatException e) {
-      limit = 0;
-      if (LOGGER.finerEnabled()) {
-        LOGGER.finer(e.getMessage());
-      }
-    }
-
-    ObjectNode queryResult = mapper.createObjectNode();
-    try {
-
-      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(query)) {
-        // get cluster object
-        Cluster cluster = Repository.get().getCluster();
-        String userName = request.getUserPrincipal().getName();
-
-        // Call execute query method
-        queryResult = cluster.executeQuery(query, members, limit);
-
-        // Add query in history if query is executed successfully
-        if (!queryResult.has("error")) {
-          // Add html escaped query to history
-          String escapedQuery = StringEscapeUtils.escapeHtml(query);
-          cluster.addQueryInHistory(escapedQuery, userName);
-        }
-      }
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-
-    response.getOutputStream().write(queryResult.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/dataBrowserQueryHistory", method = RequestMethod.GET)
-  public void dataBrowserQueryHistory(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-    ObjectNode responseJSON = mapper.createObjectNode();
-    ArrayNode queryResult = null;
-    String action = "";
-
-    try {
-      // get cluster object
-      Cluster cluster = Repository.get().getCluster();
-      String userName = request.getUserPrincipal().getName();
-
-      // get query string
-      action = request.getParameter(QUERYSTRING_PARAM_ACTION);
-      if (!StringUtils.isNotNullNotEmptyNotWhiteSpace(action)) {
-        action = ACTION_VIEW;
-      }
-
-      if (action.toLowerCase().equalsIgnoreCase(ACTION_DELETE)) {
-        String queryId = request.getParameter(QUERYSTRING_PARAM_QUERYID);
-        if (StringUtils.isNotNullNotEmptyNotWhiteSpace(queryId)) {
-
-          boolean deleteStatus = cluster.deleteQueryById(userName, queryId);
-          if (deleteStatus) {
-            responseJSON.put("status", STATUS_REPSONSE_SUCCESS);
-          } else {
-            responseJSON.put("status", STATUS_REPSONSE_FAIL);
-            responseJSON.put("error", ERROR_REPSONSE_QUERYNOTFOUND);
-          }
-        } else {
-          responseJSON.put("status", STATUS_REPSONSE_FAIL);
-          responseJSON.put("error", ERROR_REPSONSE_QUERYIDMISSING);
-        }
-      }
-
-      // Get list of past executed queries
-      queryResult = cluster.getQueryHistoryByUserId(userName);
-      responseJSON.put("queryHistory", queryResult);
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-    response.getOutputStream().write(responseJSON.toString().getBytes());
-  }
-
-  @RequestMapping(value = "/dataBrowserExport", method = RequestMethod.POST)
-  public void dataBrowserExport(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-
-    // get query string
-    String filename = request.getParameter("filename");
-    String resultContent = request.getParameter("content");
-
-    response.setHeader("Cache-Control", "");
-    response.setHeader("Content-type", "text/plain");
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(filename)) {
-      response.setHeader("Content-Disposition", "attachment; filename=" + filename);
-    } else {
-      response.setHeader("Content-Disposition", "attachment; filename=" + DEFAULT_EXPORT_FILENAME);
-    }
-
-    if (!StringUtils.isNotNullNotEmptyNotWhiteSpace(resultContent)) {
-      resultContent = "";
-    }
-
-    response.getOutputStream().write(resultContent.getBytes());
-  }
-
-  @RequestMapping(value = "/pulseProductSupport", method = RequestMethod.GET)
-  public void getConfiguredPulseProduct(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-      ObjectNode responseJSON = mapper.createObjectNode();
-
-    try {
-      responseJSON.put("product", pulseProductSupport);
-
-      // Send json response
-      response.getOutputStream().write(responseJSON.toString().getBytes());
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occurred : " + e.getMessage());
-      }
-    }
-  }
-
-  @RequestMapping(value = "/getQueryStatisticsGridModel", method = RequestMethod.GET)
-  public void getQueryStatisticsGridModel(HttpServletRequest request,
-      HttpServletResponse response) throws IOException {
-
-    ObjectNode responseJSON = mapper.createObjectNode();
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-    String userName = request.getUserPrincipal().getName();
-
-    try {
-      String[] arrColNames = Cluster.Statement.getGridColumnNames();
-      String[] arrColAttribs = Cluster.Statement.getGridColumnAttributes();
-      int[] arrColWidths = Cluster.Statement.getGridColumnWidths();
-
-      ArrayNode colNamesList = mapper.createArrayNode();
-      for (int i = 0; i < arrColNames.length; ++i) {
-        colNamesList.add(arrColNames[i]);
-      }
-
-      ArrayNode colModelList = mapper.createArrayNode();
-      for (int i = 0; i < arrColAttribs.length; ++i) {
-        ObjectNode columnJSON = mapper.createObjectNode();
-        columnJSON.put("name", arrColAttribs[i]);
-        columnJSON.put("index", arrColAttribs[i]);
-        columnJSON.put("width", arrColWidths[i]);
-        columnJSON.put("sortable", "true");
-        columnJSON.put("sorttype", ((i == 0) ? "String" : "integer"));
-        colModelList.add(columnJSON);
-      }
-
-      responseJSON.put("columnNames", colNamesList);
-      responseJSON.put("columnModels", colModelList);
-      responseJSON.put("clusterName", cluster.getServerName());
-      responseJSON.put("userName", userName);
-
-      // Send json response
-      response.getOutputStream().write(responseJSON.toString().getBytes());
-    } catch (Exception e) {
-      if (LOGGER.fineEnabled()) {
-        LOGGER.fine("Exception Occured : " + e.getMessage());
-      }
-    }
-  }
-
-  /**
-   * @return the pulseProductSupport
-   */
-  public static String getPulseProductSupport() {
-    return pulseProductSupport;
-  }
-
-  /**
-   * @param pulseProductSupport
-   *          the pulseProductSupport to set
-   */
-  public static void setPulseProductSupport(String pulseProductSupport) {
-    PulseController.pulseProductSupport = pulseProductSupport;
-  }
-}
\ No newline at end of file


[28/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DSClock.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DSClock.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DSClock.java
index d96e7c3..b759b2e 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DSClock.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DSClock.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.SystemTimer.SystemTimerTask;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.DateFormatter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.SystemTimer.SystemTimerTask;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.DateFormatter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.util.Date;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DefaultServerLauncherCacheProvider.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DefaultServerLauncherCacheProvider.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DefaultServerLauncherCacheProvider.java
index 6f155ad..7b4ca94 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DefaultServerLauncherCacheProvider.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DefaultServerLauncherCacheProvider.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.distributed.ServerLauncher;
-import com.gemstone.gemfire.distributed.ServerLauncherCacheProvider;
-import com.gemstone.gemfire.internal.cache.CacheConfig;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.distributed.ServerLauncher;
+import org.apache.geode.distributed.ServerLauncherCacheProvider;
+import org.apache.geode.internal.cache.CacheConfig;
 
 public class DefaultServerLauncherCacheProvider
     implements ServerLauncherCacheProvider {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DirectReplyProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DirectReplyProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DirectReplyProcessor.java
index fa06c4e..6fcb080 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DirectReplyProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DirectReplyProcessor.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.Collection;
 import java.util.Collections;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * A reply processor optimized for direct ack responses (It skips synchronization,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisee.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisee.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisee.java
index 655b9d1..3b137b7 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisee.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisee.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
 
 /**
  * Resource which uses a {@link DistributionAdvisor}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisor.java
index c93eeb3..843c478 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionAdvisor.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-import com.gemstone.gemfire.internal.cache.UpdateAttributesProcessor;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.ArrayUtils;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.UpdateAttributesProcessor;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.ArrayUtils;
 import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionChannel.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionChannel.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionChannel.java
index e96753f..c8f7b05 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionChannel.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionChannel.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.NotSerializableException;
 import java.util.HashSet;
@@ -22,13 +22,13 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * To change this generated comment edit the template variable "typecomment":

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
index e122189..0a4a72b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.io.File;
 import java.lang.reflect.Field;
@@ -30,14 +30,14 @@ import java.util.List;
 import java.util.Map;
 import java.util.Properties;
 
-import com.gemstone.gemfire.distributed.ConfigurationProperties;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.internal.Config;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogConfig;
-import com.gemstone.gemfire.internal.tcp.Connection;
-import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
+import org.apache.geode.distributed.ConfigurationProperties;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.internal.Config;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogConfig;
+import org.apache.geode.internal.tcp.Connection;
+import org.apache.geode.memcached.GemFireMemcachedServer;
 
 /**
  * Provides accessor (and in some cases mutator) methods for the
@@ -49,7 +49,7 @@ import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
  * <p>
  * Descriptions of these properties can be found {@link ConfigurationProperties}.
  *
- * @see com.gemstone.gemfire.internal.Config
+ * @see org.apache.geode.internal.Config
  * @since GemFire 2.1
  */
 public interface DistributionConfig extends Config, LogConfig {
@@ -77,8 +77,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * <p> The name can not be changed while the system is running.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    */
   @ConfigAttributeSetter(name = NAME)
@@ -300,8 +300,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * @param value must be of the form <code>hostName[portNum]</code>.
    *              Multiple elements are allowed and must be seperated by a comma.
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    */
   @ConfigAttributeSetter(name = LOCATORS)
@@ -370,8 +370,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * Sets the system's deploy working directory.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    */
   @ConfigAttributeSetter(name = DEPLOY_WORKING_DIR)
@@ -399,8 +399,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * Sets the system's user command path.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    */
   @ConfigAttributeSetter(name = USER_COMMAND_PACKAGES)
@@ -432,8 +432,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * <p> The system log file can not be changed while the system is running.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    */
 
@@ -456,7 +456,7 @@ public interface DistributionConfig extends Config, LogConfig {
   /**
    * Returns the value of the {@link ConfigurationProperties#LOG_LEVEL} property
    *
-   * @see com.gemstone.gemfire.internal.logging.LogWriterImpl
+   * @see org.apache.geode.internal.logging.LogWriterImpl
    */
   @ConfigAttributeGetter(name = LOG_LEVEL)
   int getLogLevel();
@@ -464,7 +464,7 @@ public interface DistributionConfig extends Config, LogConfig {
   /**
    * Sets the value of the {@link ConfigurationProperties#LOG_LEVEL} property
    *
-   * @see com.gemstone.gemfire.internal.logging.LogWriterImpl
+   * @see org.apache.geode.internal.logging.LogWriterImpl
    */
   @ConfigAttributeSetter(name = LOG_LEVEL)
   void setLogLevel(int value);
@@ -1187,7 +1187,7 @@ public interface DistributionConfig extends Config, LogConfig {
 
   /**
    * The name of an internal property that specifies a {@link
-   * com.gemstone.gemfire.i18n.LogWriterI18n} instance to log to.
+   * org.apache.geode.i18n.LogWriterI18n} instance to log to.
    * Set this property with put(), not with setProperty()
    *
    * @since GemFire 4.0
@@ -1223,7 +1223,7 @@ public interface DistributionConfig extends Config, LogConfig {
 
   /**
    * The name of an internal property that specifies a {@link
-   * com.gemstone.gemfire.LogWriter} instance to log security messages to. Set
+   * org.apache.geode.LogWriter} instance to log security messages to. Set
    * this property with put(), not with setProperty()
    *
    * @since GemFire 5.5
@@ -2351,8 +2351,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * The security log file can not be changed while the system is running.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error when writing to
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error when writing to
    *                                                    the system's configuration file.
    */
   @ConfigAttributeSetter(name = SECURITY_LOG_FILE)
@@ -2598,8 +2598,8 @@ public interface DistributionConfig extends Config, LogConfig {
    * <p> The groups can not be changed while the system is running.
    *
    * @throws IllegalArgumentException                   if the specified value is not acceptable.
-   * @throws com.gemstone.gemfire.UnmodifiableException if this attribute can not be modified.
-   * @throws com.gemstone.gemfire.GemFireIOException    if the set failure is caused by an error
+   * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
+   * @throws org.apache.geode.GemFireIOException    if the set failure is caused by an error
    *                                                    when writing to the system's configuration file.
    * @since GemFire 7.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigImpl.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigImpl.java
index 2ebb7d0..40bf089 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigImpl.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.io.File;
 import java.io.IOException;
@@ -37,15 +37,15 @@ import java.util.Set;
 import org.apache.commons.lang.StringUtils;
 import org.apache.geode.redis.GeodeRedisServer;
 
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.distributed.DistributedSystem;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.distributed.DistributedSystem;
 import org.apache.geode.security.SecurableComponents;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.process.ProcessLauncherContext;
-import com.gemstone.gemfire.memcached.GemFireMemcachedServer;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.process.ProcessLauncherContext;
+import org.apache.geode.memcached.GemFireMemcachedServer;
 
 /**
  * Provides an implementation of <code>DistributionConfig</code> that
@@ -109,7 +109,7 @@ public class DistributionConfigImpl
   
   /** The level at which log messages are logged
    *
-   * @see com.gemstone.gemfire.internal.logging.LogWriterImpl#levelNameToCode(String)
+   * @see org.apache.geode.internal.logging.LogWriterImpl#levelNameToCode(String)
    */
   protected int logLevel = DEFAULT_LOG_LEVEL;
 
@@ -244,7 +244,7 @@ public class DistributionConfigImpl
   /**
    * The level at which security related log messages are logged
    *
-   * @see com.gemstone.gemfire.internal.logging.LogWriterImpl#levelNameToCode(String)
+   * @see org.apache.geode.internal.logging.LogWriterImpl#levelNameToCode(String)
    */
   protected int securityLogLevel = DEFAULT_LOG_LEVEL;
 
@@ -623,7 +623,7 @@ public class DistributionConfigImpl
   /**
    * Creates a new <code>DistributionConfigImpl</code> with the given
    * non-default configuration properties.  See {@link
-   * com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
+   * org.apache.geode.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
    *
    * @param nonDefault
@@ -636,7 +636,7 @@ public class DistributionConfigImpl
   /**
    * Creates a new <code>DistributionConfigImpl</code> with the given
    * non-default configuration properties. See
-   * {@link com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
+   * {@link org.apache.geode.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
    * 
    * @param nonDefault
@@ -656,7 +656,7 @@ public class DistributionConfigImpl
   /**
    * Creates a new <code>DistributionConfigImpl</code> with the given
    * non-default configuration properties. See
-   * {@link com.gemstone.gemfire.distributed.DistributedSystem#connect} for a
+   * {@link org.apache.geode.distributed.DistributedSystem#connect} for a
    * list of exceptions that may be thrown.
    * 
    * @param nonDefault
@@ -3194,14 +3194,14 @@ public class DistributionConfigImpl
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DistributionConfig#getMembershipPortRange()
+   * @see org.apache.geode.distributed.internal.DistributionConfig#getMembershipPortRange()
    */
   public int[] getMembershipPortRange() {
     return membershipPortRange;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DistributionConfig#setMembershipPortRange(int[])
+   * @see org.apache.geode.distributed.internal.DistributionConfig#setMembershipPortRange(int[])
    */
   public void setMembershipPortRange(int[] range) {
     membershipPortRange = (int[])checkAttribute(MEMBERSHIP_PORT_RANGE, range);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigSnapshot.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigSnapshot.java
index d50ff74..9d55437 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfigSnapshot.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.HashSet;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Provides an implementation of the {@link DistributionConfig} interface

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionException.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionException.java
index 7254504..6bfa55b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * This exception is thrown when a problem occurs when accessing the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionManager.java
index 259f7c2..ef69b7b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionManager.java
@@ -14,33 +14,33 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.locks.ElderState;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.remote.AdminConsoleDisconnectMessage;
-import com.gemstone.gemfire.internal.admin.remote.RemoteGfManagerAgent;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.sequencelog.MembershipLogger;
-import com.gemstone.gemfire.internal.tcp.Connection;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-import com.gemstone.gemfire.internal.tcp.ReenteredConnectException;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantLock;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.locks.ElderState;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.remote.AdminConsoleDisconnectMessage;
+import org.apache.geode.internal.admin.remote.RemoteGfManagerAgent;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.cache.InitialImageOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.sequencelog.MembershipLogger;
+import org.apache.geode.internal.tcp.Connection;
+import org.apache.geode.internal.tcp.ConnectionTable;
+import org.apache.geode.internal.tcp.ReenteredConnectException;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantLock;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
@@ -88,7 +88,7 @@ public class DistributionManager
 
   /**
    * WARNING: setting this to true may break dunit tests.
-   * <p>see com.gemstone.gemfire.cache30.ClearMultiVmCallBkDUnitTest
+   * <p>see org.apache.geode.cache30.ClearMultiVmCallBkDUnitTest
    */
   public static final boolean INLINE_PROCESS = 
     !Boolean.getBoolean("DistributionManager.enqueueOrderedMessages");
@@ -176,7 +176,7 @@ public class DistributionManager
 
   /**
    * an NIO priority type
-   * @see com.gemstone.gemfire.distributed.internal.PooledDistributionMessage
+   * @see org.apache.geode.distributed.internal.PooledDistributionMessage
    * @see #SERIAL_EXECUTOR
    * @see #HIGH_PRIORITY_EXECUTOR
    * @see #WAITING_POOL_EXECUTOR
@@ -186,7 +186,7 @@ public class DistributionManager
   /**
    * an NIO priority type
    * 
-   * @see com.gemstone.gemfire.distributed.internal.SerialDistributionMessage
+   * @see org.apache.geode.distributed.internal.SerialDistributionMessage
    * @see #STANDARD_EXECUTOR
    */
   public static final int SERIAL_EXECUTOR = 74;
@@ -194,7 +194,7 @@ public class DistributionManager
   /**
    * an NIO priority type
 
-   * @see com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage
+   * @see org.apache.geode.distributed.internal.HighPriorityDistributionMessage
    * @see #STANDARD_EXECUTOR
    */
   public static final int HIGH_PRIORITY_EXECUTOR = 75;
@@ -204,7 +204,7 @@ public class DistributionManager
   /**
    * an NIO priority type
    * 
-   * @see com.gemstone.gemfire.internal.cache.InitialImageOperation
+   * @see org.apache.geode.internal.cache.InitialImageOperation
    * @see #STANDARD_EXECUTOR
    */
   public static final int WAITING_POOL_EXECUTOR = 77;
@@ -212,7 +212,7 @@ public class DistributionManager
   /**
    * an NIO priority type
    * 
-   * @see com.gemstone.gemfire.internal.cache.InitialImageOperation
+   * @see org.apache.geode.internal.cache.InitialImageOperation
    * @see #STANDARD_EXECUTOR
    */
   public static final int PARTITIONED_REGION_EXECUTOR = 78;
@@ -221,7 +221,7 @@ public class DistributionManager
   /**
    * Executor for view related messages
    * 
-   * @see com.gemstone.gemfire.distributed.internal.membership.gms.messages.ViewAckMessage
+   * @see org.apache.geode.distributed.internal.membership.gms.messages.ViewAckMessage
    * @see #STANDARD_EXECUTOR
    */
   public static final int VIEW_EXECUTOR = 79;
@@ -389,8 +389,8 @@ public class DistributionManager
   private ThreadPoolExecutor prMetaDataCleanupThreadPool;
   
   /**
-   * Thread used to decouple {@link com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage}s from 
-   * {@link com.gemstone.gemfire.internal.cache.DistributedCacheOperation}s </b>
+   * Thread used to decouple {@link org.apache.geode.internal.cache.partitioned.PartitionMessage}s from 
+   * {@link org.apache.geode.internal.cache.DistributedCacheOperation}s </b>
    * @see #SERIAL_EXECUTOR
    */
   private ThreadPoolExecutor partitionedRegionThread;
@@ -402,7 +402,7 @@ public class DistributionManager
   private ThreadPoolExecutor serialThread;
   
   /** Message processing executor for view messages
-   * @see com.gemstone.gemfire.distributed.internal.membership.gms.messages.ViewAckMessage 
+   * @see org.apache.geode.distributed.internal.membership.gms.messages.ViewAckMessage 
    */
   private ThreadPoolExecutor viewThread;
   
@@ -2364,9 +2364,9 @@ public class DistributionManager
   /**
    * This thread processes member events as they occur.
    * 
-   * @see com.gemstone.gemfire.distributed.internal.DistributionManager.MemberCrashedEvent
-   * @see com.gemstone.gemfire.distributed.internal.DistributionManager.MemberJoinedEvent
-   * @see com.gemstone.gemfire.distributed.internal.DistributionManager.MemberDepartedEvent
+   * @see org.apache.geode.distributed.internal.DistributionManager.MemberCrashedEvent
+   * @see org.apache.geode.distributed.internal.DistributionManager.MemberJoinedEvent
+   * @see org.apache.geode.distributed.internal.DistributionManager.MemberDepartedEvent
    *
    */
   protected class MemberEventInvoker implements Runnable {
@@ -2556,10 +2556,10 @@ public class DistributionManager
   public Set addAllMembershipListenerAndGetAllIds(MembershipListener l) {
     // TO fix this deadlock:
     // "View Message Processor":
-    //  waiting to lock monitor 0x080f691c (object 0xe3ba7680, a com.gemstone.gemfire.distributed.internal.DistributionManager$MembersLock),
+    //  waiting to lock monitor 0x080f691c (object 0xe3ba7680, a org.apache.geode.distributed.internal.DistributionManager$MembersLock),
     //  which is held by "RMI TCP Connection(259)-10.80.10.55"
     // "RMI TCP Connection(259)-10.80.10.55":
-    //  waiting to lock monitor 0x080f6598 (object 0xe3bacd90, a com.gemstone.gemfire.distributed.internal.membership.jgroup.JGroupMembershipManager$ViewLock),
+    //  waiting to lock monitor 0x080f6598 (object 0xe3bacd90, a org.apache.geode.distributed.internal.membership.jgroup.JGroupMembershipManager$ViewLock),
     //  which is held by "View Message Processor"
     // NEED to prevent view changes while installing a listener.
     DistributionChannel ch = this.channel;
@@ -3469,7 +3469,7 @@ public class DistributionManager
       for (int i = 0; i < message.getRecipients().length; i ++)
         result.add(message.getRecipients()[i]);
       return result;
-   /*   if (ex instanceof com.gemstone.gemfire.GemFireIpcResourceException) {
+   /*   if (ex instanceof org.apache.geode.GemFireIpcResourceException) {
         return;
       }*/
     }
@@ -4545,21 +4545,21 @@ public class DistributionManager
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#getRootCause()
+   * @see org.apache.geode.distributed.internal.DM#getRootCause()
    */
   public Throwable getRootCause() {
     return this.rootCause;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#setRootCause(java.lang.Throwable)
+   * @see org.apache.geode.distributed.internal.DM#setRootCause(java.lang.Throwable)
    */
   public void setRootCause(Throwable t) {
     this.rootCause = t;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#getMembersOnThisHost()
+   * @see org.apache.geode.distributed.internal.DM#getMembersOnThisHost()
    * @since GemFire 5.9
    */
   public Set<InternalDistributedMember> getMembersInThisZone() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessage.java
index f93e652..f07dca4 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,32 +28,32 @@ import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.deadlock.MessageDependencyMonitor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.sequencelog.MessageLogger;
-import com.gemstone.gemfire.internal.tcp.Connection;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.deadlock.MessageDependencyMonitor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.sequencelog.MessageLogger;
+import org.apache.geode.internal.tcp.Connection;
+import org.apache.geode.internal.util.Breadcrumbs;
 
 /**
  * <P>A <code>DistributionMessage</code> carries some piece of
  * information to a distribution manager.  </P>
  *
  * <P>Messages that don't have strict ordering requirements should extend
- * {@link com.gemstone.gemfire.distributed.internal.PooledDistributionMessage}.
+ * {@link org.apache.geode.distributed.internal.PooledDistributionMessage}.
  * Messages that must be processed serially in the order they were received
  * can extend
- * {@link com.gemstone.gemfire.distributed.internal.SerialDistributionMessage}.
+ * {@link org.apache.geode.distributed.internal.SerialDistributionMessage}.
  * To customize the sequentialness/thread requirements of a message, extend
  * DistributionMessage and implement getExecutor().</P>
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessageObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessageObserver.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessageObserver.java
index 3b4161c..d5afe6d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessageObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionMessageObserver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionStats.java
index fbfd0c6..ca2a8c1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionStats.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.logging.LogService;
 //import java.io.*;
-import com.gemstone.gemfire.internal.tcp.Buffers;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
+import org.apache.geode.internal.tcp.Buffers;
+import org.apache.geode.internal.util.Breadcrumbs;
 
 /**
  * This class maintains statistics in GemFire about the distribution

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/FlowControlParams.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/FlowControlParams.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/FlowControlParams.java
index b656805..c4c7b83 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/FlowControlParams.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/FlowControlParams.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /** FlowControlParams are used to represent mcast-flow-control parameters for a
     DistributedSystem.  Instances of this class are used in DistributionConfig to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/FunctionExecutionPooledExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/FunctionExecutionPooledExecutor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/FunctionExecutionPooledExecutor.java
index 1ac6f30..6a05591 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/FunctionExecutionPooledExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/FunctionExecutionPooledExecutor.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.List;
 import java.util.concurrent.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitor.java
index 92cafe8..46da196 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitor.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealth;
 
 /**
  * Represents a thread that monitor the health of the vm it lives in.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitorImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitorImpl.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitorImpl.java
index 7862390..5773583 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/HealthMonitorImpl.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.internal.GemFireHealthEvaluator;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.HealthListenerMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.internal.GemFireHealthEvaluator;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.HealthListenerMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Implements a thread that monitors the health of the vm it lives in.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityAckedMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityAckedMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityAckedMessage.java
index ffae0fe..2733c39 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityAckedMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityAckedMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,14 +26,14 @@ import java.util.concurrent.ThreadPoolExecutor;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * A message that is sent to a given collection of managers and then

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityDistributionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityDistributionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityDistributionMessage.java
index d13927a..5b9b01c 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityDistributionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/HighPriorityDistributionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/IgnoredByManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/IgnoredByManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/IgnoredByManager.java
index 4090d3a..001087f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/IgnoredByManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/IgnoredByManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * This marker indicates messages (usually {@link

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalDistributedSystem.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalDistributedSystem.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalDistributedSystem.java
index b9566df..44960c8 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalDistributedSystem.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalDistributedSystem.java
@@ -15,59 +15,59 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.AlertLevel;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.execute.internal.FunctionServiceManager;
-import com.gemstone.gemfire.cache.server.CacheServer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
-import com.gemstone.gemfire.distributed.internal.locks.GrantorRequestProcessor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.cache.CacheConfig;
-import com.gemstone.gemfire.internal.cache.CacheServerImpl;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.execute.FunctionServiceStats;
-import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheServerCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
-import com.gemstone.gemfire.internal.offheap.MemoryAllocator;
-import com.gemstone.gemfire.internal.offheap.OffHeapStorage;
-import com.gemstone.gemfire.internal.statistics.DummyStatisticsImpl;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
-import com.gemstone.gemfire.internal.statistics.platform.LinuxProcFsStatistics;
-import com.gemstone.gemfire.internal.statistics.LocalStatisticsImpl;
-import com.gemstone.gemfire.internal.statistics.platform.OsStatisticsFactory;
-import com.gemstone.gemfire.internal.statistics.StatisticsImpl;
-import com.gemstone.gemfire.internal.statistics.StatisticsManager;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.tcp.ConnectionTable;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCondition;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantLock;
-import com.gemstone.gemfire.management.ManagementException;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.*;
+import org.apache.geode.admin.AlertLevel;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.execute.internal.FunctionServiceManager;
+import org.apache.geode.cache.server.CacheServer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.internal.locks.GrantorRequestProcessor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.mgr.GMSMembershipManager;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.internal.cache.CacheConfig;
+import org.apache.geode.internal.cache.CacheServerImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.execute.FunctionServiceStats;
+import org.apache.geode.internal.cache.execute.FunctionStats;
+import org.apache.geode.internal.cache.tier.sockets.HandShake;
+import org.apache.geode.internal.cache.xmlcache.CacheServerCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterFactory;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogWriterAppender;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.internal.offheap.MemoryAllocator;
+import org.apache.geode.internal.offheap.OffHeapStorage;
+import org.apache.geode.internal.statistics.DummyStatisticsImpl;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
+import org.apache.geode.internal.statistics.platform.LinuxProcFsStatistics;
+import org.apache.geode.internal.statistics.LocalStatisticsImpl;
+import org.apache.geode.internal.statistics.platform.OsStatisticsFactory;
+import org.apache.geode.internal.statistics.StatisticsImpl;
+import org.apache.geode.internal.statistics.StatisticsManager;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.tcp.ConnectionTable;
+import org.apache.geode.internal.util.concurrent.StoppableCondition;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantLock;
+import org.apache.geode.management.ManagementException;
+import org.apache.geode.security.GemFireSecurityException;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
@@ -81,8 +81,8 @@ import java.util.concurrent.CopyOnWriteArrayList;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicReference;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_PORT;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
 
 /**
  * The concrete implementation of {@link DistributedSystem} that
@@ -430,7 +430,7 @@ public class InternalDistributedSystem
 //    if (DistributionConfigImpl.forceDisableTcp) {
 //      this.logger.warning("Use of UDP has been forced");
 //    }
-//    if (com.gemstone.gemfire.distributed.internal.membership.jgroup.JGroupMembershipManager.multicastTest) {
+//    if (org.apache.geode.distributed.internal.membership.jgroup.JGroupMembershipManager.multicastTest) {
 //      this.logger.warning("Use of multicast for all distributed cache operations has been forced");
 //    }
 
@@ -1513,7 +1513,7 @@ public class InternalDistributedSystem
    * This is actually the port of the distribution manager's
    * distribution channel.
    *
-   * @see com.gemstone.gemfire.distributed.internal.DistributionChannel#getId
+   * @see org.apache.geode.distributed.internal.DistributionChannel#getId
    */
   @Override
   public long getId() {
@@ -2879,7 +2879,7 @@ public class InternalDistributedSystem
   }
 
   /**
-   * see {@link com.gemstone.gemfire.admin.AdminDistributedSystemFactory}
+   * see {@link org.apache.geode.admin.AdminDistributedSystemFactory}
    * @since GemFire 5.7
    */
   public static void setEnableAdministrationOnly(boolean adminOnly) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalLocator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalLocator.java
index 026efb9..a44e336 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/InternalLocator.java
@@ -14,49 +14,49 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.client.internal.locator.*;
-import com.gemstone.gemfire.cache.client.internal.locator.wan.LocatorMembershipListener;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.ConnectListener;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DisconnectListener;
-import com.gemstone.gemfire.distributed.internal.membership.MemberFactory;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
-import com.gemstone.gemfire.distributed.internal.membership.gms.NetLocator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.PeerLocatorRequest;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpClient;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpHandler;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpServer;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.wan.WANServiceProvider;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LogWriterFactory;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterLogger;
-import com.gemstone.gemfire.management.internal.JmxManagerLocator;
-import com.gemstone.gemfire.management.internal.JmxManagerLocatorRequest;
-import com.gemstone.gemfire.management.internal.JmxManagerLocatorResponse;
-import com.gemstone.gemfire.management.internal.cli.CliUtil;
-import com.gemstone.gemfire.management.internal.configuration.domain.SharedConfigurationStatus;
-import com.gemstone.gemfire.management.internal.configuration.handlers.ConfigurationRequestHandler;
-import com.gemstone.gemfire.management.internal.configuration.handlers.SharedConfigurationStatusRequestHandler;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationRequest;
-import com.gemstone.gemfire.management.internal.configuration.messages.SharedConfigurationStatusRequest;
-import com.gemstone.gemfire.management.internal.configuration.messages.SharedConfigurationStatusResponse;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.client.internal.locator.*;
+import org.apache.geode.cache.client.internal.locator.wan.LocatorMembershipListener;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.ConnectListener;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.DisconnectListener;
+import org.apache.geode.distributed.internal.membership.MemberFactory;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.distributed.internal.membership.gms.NetLocator;
+import org.apache.geode.distributed.internal.membership.gms.locator.PeerLocatorRequest;
+import org.apache.geode.distributed.internal.tcpserver.TcpClient;
+import org.apache.geode.distributed.internal.tcpserver.TcpHandler;
+import org.apache.geode.distributed.internal.tcpserver.TcpServer;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.admin.remote.DistributionLocatorId;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.wan.WANServiceProvider;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LogWriterFactory;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.internal.logging.log4j.LogWriterLogger;
+import org.apache.geode.management.internal.JmxManagerLocator;
+import org.apache.geode.management.internal.JmxManagerLocatorRequest;
+import org.apache.geode.management.internal.JmxManagerLocatorResponse;
+import org.apache.geode.management.internal.cli.CliUtil;
+import org.apache.geode.management.internal.configuration.domain.SharedConfigurationStatus;
+import org.apache.geode.management.internal.configuration.handlers.ConfigurationRequestHandler;
+import org.apache.geode.management.internal.configuration.handlers.SharedConfigurationStatusRequestHandler;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationRequest;
+import org.apache.geode.management.internal.configuration.messages.SharedConfigurationStatusRequest;
+import org.apache.geode.management.internal.configuration.messages.SharedConfigurationStatusResponse;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
@@ -71,7 +71,7 @@ import java.util.concurrent.Future;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicBoolean;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Provides the implementation of a distribution <code>Locator</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorLoadSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorLoadSnapshot.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorLoadSnapshot.java
index 4933e25..67373f9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorLoadSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorLoadSnapshot.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -35,9 +35,9 @@ import java.util.concurrent.ScheduledThreadPoolExecutor;
 import java.util.concurrent.ThreadFactory;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.cache.wan.GatewayReceiver;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.cache.wan.GatewayReceiver;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 /**
  * A data structure used to hold load information for a locator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorStats.java
index 897b8c3..6f9c42d 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/LocatorStats.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicLong;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
 
 /**
  * This class maintains statistics for the locator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/LonerDistributionManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/LonerDistributionManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/LonerDistributionManager.java
index c4621ce..6ea471a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/LonerDistributionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/LonerDistributionManager.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.locks.ElderState;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MemberAttributes;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.locks.ElderState;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MemberAttributes;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 import java.io.Serializable;
 import java.net.InetAddress;
@@ -88,7 +88,7 @@ public class LonerDistributionManager implements DM {
     try {
       host = InetAddress.getLocalHost().getCanonicalHostName();
       MemberAttributes.setDefaults(65535,
-              com.gemstone.gemfire.internal.OSProcess.getId(),
+              org.apache.geode.internal.OSProcess.getId(),
               DistributionManager.LONER_DM_TYPE,
               MemberAttributes.parseRoles(system.getConfig().getRoles()));
       id = new InternalDistributedMember(host, 65535); // noise value for port number
@@ -895,7 +895,7 @@ public class LonerDistributionManager implements DM {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#getMembershipManager()
+   * @see org.apache.geode.distributed.internal.DM#getMembershipManager()
    */
   public MembershipManager getMembershipManager() {
     // no membership manager
@@ -903,20 +903,20 @@ public class LonerDistributionManager implements DM {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#getRootCause()
+   * @see org.apache.geode.distributed.internal.DM#getRootCause()
    */
   public Throwable getRootCause() {
     return null;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#setRootCause(java.lang.Throwable)
+   * @see org.apache.geode.distributed.internal.DM#setRootCause(java.lang.Throwable)
    */
   public void setRootCause(Throwable t) {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DM#getMembersOnThisHost()
+   * @see org.apache.geode.distributed.internal.DM#getMembersOnThisHost()
    * @since GemFire 5.9
    */
   public Set<InternalDistributedMember> getMembersInThisZone() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/MQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/MQueue.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/MQueue.java
index 304a7fa..b9e169e 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/MQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/MQueue.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.concurrent.BlockingQueue;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/MembershipListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/MembershipListener.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/MembershipListener.java
index 8fe2d67..4255bab 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/MembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/MembershipListener.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * This interface specifies callback methods that are invoked when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageFactory.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageFactory.java
index ec09bd7..5b62a0f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageFactory.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This class is a factory that creates instances

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageWithReply.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageWithReply.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageWithReply.java
index a5c028c..219d7da 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageWithReply.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/MessageWithReply.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A marker interface that denotes {@link DistributionMessage}s that
@@ -30,7 +30,7 @@ public interface MessageWithReply {
 
   /**
    * Returns the id of the {@link 
-   * com.gemstone.gemfire.distributed.internal.ReplyProcessor21} that is used to
+   * org.apache.geode.distributed.internal.ReplyProcessor21} that is used to
    * handle the reply to this message.
    */
   public int getProcessorId();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/OverflowQueueWithDMStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/OverflowQueueWithDMStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/OverflowQueueWithDMStats.java
index 03b7f64..54f5d8f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/OverflowQueueWithDMStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/OverflowQueueWithDMStats.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.concurrent.LinkedBlockingQueue;
 import java.util.concurrent.TimeUnit;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/PoolStatHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/PoolStatHelper.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/PoolStatHelper.java
index f4b8f83..ba03294 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/PoolStatHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/PoolStatHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Used to implement statistics on a pool.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledDistributionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledDistributionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledDistributionMessage.java
index 2f22918..ea1a2a1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledDistributionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledDistributionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * A PooledDistributionMessage passes processing off to a thread that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledExecutorWithDMStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledExecutorWithDMStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledExecutorWithDMStats.java
index 5bb82f0..31760c8 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledExecutorWithDMStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/PooledExecutorWithDMStats.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.List;
 import java.util.concurrent.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ProcessorKeeper21.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProcessorKeeper21.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProcessorKeeper21.java
index 650a02c..bb7df56 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProcessorKeeper21.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProcessorKeeper21.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.internal.*;
+import org.apache.geode.internal.*;
 import java.lang.ref.WeakReference;
 import java.util.concurrent.atomic.AtomicInteger;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ProductUseLog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProductUseLog.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProductUseLog.java
index c8e066d..18b51b9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProductUseLog.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProductUseLog.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.File;
 import java.io.FileNotFoundException;
@@ -23,12 +23,12 @@ import java.io.PrintStream;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.PureLogWriter;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.logging.PureLogWriter;
 
 /**
  * A log intended for recording product-use.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ProfileListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProfileListener.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProfileListener.java
index 5797f84..8619a05 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ProfileListener.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ProfileListener.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
 
 /**
  * Callback for changes to profiles in a DistributionAdvisor. A ProfileListener



[27/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/QueueStatHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/QueueStatHelper.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/QueueStatHelper.java
index dd1837f..e347c62 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/QueueStatHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/QueueStatHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Used to implement statistics on a queue.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyException.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyException.java
index 272dbe8..fc6fa5a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyException.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * thrown by {@linkplain ReliableReplyProcessor21} when a message has not been delivered

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyProcessor21.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyProcessor21.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyProcessor21.java
index 93f89a3..f8ad122 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyProcessor21.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReliableReplyProcessor21.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This is a reply processor which tracks departed members in order for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyException.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyException.java
index 646243a..656ab64 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyException.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.SerializationException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.GemFireException;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.SerializationException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Exception thrown when a DistributionMessage is processed to be propagated

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyMessage.java
index 20c75b0..2d8c5c1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,13 +23,13 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A message that acknowledges that an operation completed

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyProcessor21.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyProcessor21.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyProcessor21.java
index ced0f49..84f63d2 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyProcessor21.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplyProcessor21.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.cache.UnsupportedVersionException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.deadlock.MessageDependencyMonitor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DSFIDNotFoundException;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
+package org.apache.geode.distributed.internal;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.cache.UnsupportedVersionException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.deadlock.MessageDependencyMonitor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DSFIDNotFoundException;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.Breadcrumbs;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplySender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplySender.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplySender.java
index c177a4b..708da50 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplySender.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ReplySender.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.cache.DirectReplyMessage;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.cache.DirectReplyMessage;
 
 /**
  * This interface is used by direct ack messages to send a reply

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEvent.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEvent.java
index 584975e..9dfb1c8 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEvent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * GemFire Resource Events

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEventsListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEventsListener.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEventsListener.java
index bd2895b..f8f2008 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEventsListener.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ResourceEventsListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Internal interface to be implemented to catch various resource events

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/RuntimeDistributionConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/RuntimeDistributionConfigImpl.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/RuntimeDistributionConfigImpl.java
index c1384c3..a625ecc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/RuntimeDistributionConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/RuntimeDistributionConfigImpl.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.internal.ConfigSource;
-import com.gemstone.gemfire.internal.logging.log4j.LogWriterAppenders;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.internal.ConfigSource;
+import org.apache.geode.internal.logging.log4j.LogWriterAppenders;
 
 import java.io.File;
 import java.util.Arrays;
 import java.util.List;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Provides an implementation of <code>DistributionConfig</code> that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialAckedMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialAckedMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialAckedMessage.java
index f7e1c19..a09df7d 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialAckedMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialAckedMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,11 +25,11 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A message that is sent to a given collection of managers and then

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialDistributionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialDistributionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialDistributionMessage.java
index 4fe5140..96c8c48 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialDistributionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialDistributionMessage.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * A SerialDistributionMessage is processed in the order

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialQueuedExecutorWithDMStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialQueuedExecutorWithDMStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialQueuedExecutorWithDMStats.java
index 26c0feb..4c194f1 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialQueuedExecutorWithDMStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/SerialQueuedExecutorWithDMStats.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.concurrent.BlockingQueue;
 import java.util.concurrent.ThreadFactory;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocation.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocation.java
index 0e7430c..b8795d5 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocation.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocation.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,9 +22,9 @@ import java.io.IOException;
 import java.net.UnknownHostException;
 import java.util.concurrent.atomic.AtomicInteger;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.SocketCreator;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.SocketCreator;
 
 /**
  * Represents the location of a bridge server. This class is 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocator.java
index f5b774f..feef18a 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ServerLocator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.File;
 import java.io.IOException;
@@ -29,38 +29,38 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.atomic.AtomicInteger;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
+import org.apache.geode.internal.DataSerializableFixedID;
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientReplacementRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorStatusResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.ServerLocationRequest;
-import com.gemstone.gemfire.cache.server.ServerLoad;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpHandler;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpServer;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.CacheServerAdvisor.CacheServerProfile;
-import com.gemstone.gemfire.internal.cache.ControllerAdvisor;
-import com.gemstone.gemfire.internal.cache.ControllerAdvisor.ControllerProfile;
-import com.gemstone.gemfire.internal.cache.FindDurableQueueProcessor;
-import com.gemstone.gemfire.internal.cache.GridAdvisor.GridProfile;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionResponse;
+import org.apache.geode.cache.client.internal.locator.ClientReplacementRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersResponse;
+import org.apache.geode.cache.client.internal.locator.LocatorListRequest;
+import org.apache.geode.cache.client.internal.locator.LocatorListResponse;
+import org.apache.geode.cache.client.internal.locator.LocatorStatusResponse;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionResponse;
+import org.apache.geode.cache.client.internal.locator.ServerLocationRequest;
+import org.apache.geode.cache.server.ServerLoad;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.tcpserver.TcpHandler;
+import org.apache.geode.distributed.internal.tcpserver.TcpServer;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.CacheServerAdvisor.CacheServerProfile;
+import org.apache.geode.internal.cache.ControllerAdvisor;
+import org.apache.geode.internal.cache.ControllerAdvisor.ControllerProfile;
+import org.apache.geode.internal.cache.FindDurableQueueProcessor;
+import org.apache.geode.internal.cache.GridAdvisor.GridProfile;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/SharedConfiguration.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/SharedConfiguration.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/SharedConfiguration.java
index 1c32050..2e6677f 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/SharedConfiguration.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/SharedConfiguration.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.BufferedWriter;
 import java.io.File;
@@ -48,42 +48,42 @@ import org.apache.logging.log4j.Logger;
 import org.w3c.dom.Document;
 import org.xml.sax.SAXException;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.DiskStore;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberManager;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberPattern;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.management.internal.cli.CliUtil;
-import com.gemstone.gemfire.management.internal.cli.functions.ImportSharedConfigurationArtifactsFunction;
-import com.gemstone.gemfire.management.internal.cli.i18n.CliStrings;
-import com.gemstone.gemfire.management.internal.configuration.callbacks.ConfigurationChangeListener;
-import com.gemstone.gemfire.management.internal.configuration.domain.Configuration;
-import com.gemstone.gemfire.management.internal.configuration.domain.SharedConfigurationStatus;
-import com.gemstone.gemfire.management.internal.configuration.domain.XmlEntity;
-import com.gemstone.gemfire.management.internal.configuration.functions.GetAllJarsFunction;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationRequest;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationResponse;
-import com.gemstone.gemfire.management.internal.configuration.messages.SharedConfigurationStatusResponse;
-import com.gemstone.gemfire.management.internal.configuration.utils.XmlUtils;
-import com.gemstone.gemfire.management.internal.configuration.utils.ZipUtils;
-
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.DiskStore;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.InternalRegionArguments;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.persistence.PersistentMemberManager;
+import org.apache.geode.internal.cache.persistence.PersistentMemberPattern;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.cache.xmlcache.CacheXmlGenerator;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.management.internal.cli.CliUtil;
+import org.apache.geode.management.internal.cli.functions.ImportSharedConfigurationArtifactsFunction;
+import org.apache.geode.management.internal.cli.i18n.CliStrings;
+import org.apache.geode.management.internal.configuration.callbacks.ConfigurationChangeListener;
+import org.apache.geode.management.internal.configuration.domain.Configuration;
+import org.apache.geode.management.internal.configuration.domain.SharedConfigurationStatus;
+import org.apache.geode.management.internal.configuration.domain.XmlEntity;
+import org.apache.geode.management.internal.configuration.functions.GetAllJarsFunction;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationRequest;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationResponse;
+import org.apache.geode.management.internal.configuration.messages.SharedConfigurationStatusResponse;
+import org.apache.geode.management.internal.configuration.utils.XmlUtils;
+import org.apache.geode.management.internal.configuration.utils.ZipUtils;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 @SuppressWarnings({ "deprecation", "unchecked" })
 public class SharedConfiguration {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ShutdownMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ShutdownMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ShutdownMessage.java
index b96850e..9cfc129 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ShutdownMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ShutdownMessage.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * A message that is sent to all other distribution manager when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/Sizeable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/Sizeable.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/Sizeable.java
index 76deee0..df486d4 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/Sizeable.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/Sizeable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /** Sizeable objects have a getSize() method that returns the approximate size of the object.
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/SizeableRunnable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/SizeableRunnable.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/SizeableRunnable.java
index e6896e4..d53a759 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/SizeableRunnable.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/SizeableRunnable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 
 /** SizeableRunnable is a Runnable with a size.  It implements the Sizeable interface

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessage.java
index 7b6d853..2b03b5e 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessage.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.InternalDataSerializer.SerializerAttributesHolder;
-import com.gemstone.gemfire.internal.InternalInstantiator.InstantiatorAttributesHolder;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.internal.*;
+import org.apache.geode.internal.InternalDataSerializer.SerializerAttributesHolder;
+import org.apache.geode.internal.InternalInstantiator.InstantiatorAttributesHolder;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 import org.apache.commons.lang.StringUtils;
 import org.apache.logging.log4j.Logger;
@@ -223,7 +223,7 @@ public final class StartupMessage extends HighPriorityDistributionMessage implem
 
     if (rejectionMessage == null) { // change state only if there's no rejectionMessage yet
       if (this.interfaces == null || this.interfaces.size() == 0) {
-        final com.gemstone.gemfire.i18n.StringId msg = 
+        final org.apache.geode.i18n.StringId msg = 
           LocalizedStrings.StartupMessage_REJECTED_NEW_SYSTEM_NODE_0_BECAUSE_PEER_HAS_NO_NETWORK_INTERFACES;
         rejectionMessage = msg.toLocalizedString(getSender());
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageData.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageData.java
index ad61b88..22dc1c4 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageData.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageData.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,8 +26,8 @@ import java.util.Collection;
 import java.util.Properties;
 import java.util.StringTokenizer;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.GemFireVersion;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.GemFireVersion;
 
 /**
  * Provides optional data fields as properties for StartupMessage and 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageReplyProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageReplyProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageReplyProcessor.java
index d248d2a..e7115ce 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageReplyProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupMessageReplyProcessor.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.util.Set;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.LogWriterI18n;
 
 public class StartupMessageReplyProcessor extends ReplyProcessor21
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupOperation.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupOperation.java
index 721f95b..46d1390 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupOperation.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.IOException;
 import java.util.HashSet;
@@ -23,11 +23,11 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class StartupOperation {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseMessage.java
index 3fbf7c7..7d2b2a2 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,17 +24,17 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.InternalDataSerializer.SerializerAttributesHolder;
-import com.gemstone.gemfire.internal.InternalInstantiator;
-import com.gemstone.gemfire.internal.InternalInstantiator.InstantiatorAttributesHolder;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.InternalDataSerializer.SerializerAttributesHolder;
+import org.apache.geode.internal.InternalInstantiator;
+import org.apache.geode.internal.InternalInstantiator.InstantiatorAttributesHolder;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message that is sent to all other distribution manager when

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseWithVersionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseWithVersionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseWithVersionMessage.java
index 3027486..9aa03c9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseWithVersionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/StartupResponseWithVersionMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,12 +23,12 @@ import java.util.Collection;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * @since GemFire 6.6.2

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledMemQueueStatHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledMemQueueStatHelper.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledMemQueueStatHelper.java
index ee4cd91..ec45032 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledMemQueueStatHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledMemQueueStatHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Used to implement statistics on a throttled queue.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledQueueStatHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledQueueStatHelper.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledQueueStatHelper.java
index e7244c7..511d1c0 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledQueueStatHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottledQueueStatHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 /**
  * Used to implement statistics on a throttled queue.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottlingMemLinkedQueueWithDMStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottlingMemLinkedQueueWithDMStats.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottlingMemLinkedQueueWithDMStats.java
index 0c1c988..ca3c4be 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottlingMemLinkedQueueWithDMStats.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/ThrottlingMemLinkedQueueWithDMStats.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.DistributionStats;
 import java.util.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/WaitForViewInstallation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/WaitForViewInstallation.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/WaitForViewInstallation.java
index 5b0bc61..e3f2351 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/WaitForViewInstallation.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/WaitForViewInstallation.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,8 +25,8 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  *
@@ -85,7 +85,7 @@ public class WaitForViewInstallation extends HighPriorityDistributionMessage
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return WAIT_FOR_VIEW_INSTALLATION;
@@ -106,7 +106,7 @@ public class WaitForViewInstallation extends HighPriorityDistributionMessage
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.distributed.internal.DistributionMessage#process(com.gemstone.gemfire.distributed.internal.DistributionManager)
+   * @see org.apache.geode.distributed.internal.DistributionMessage#process(org.apache.geode.distributed.internal.DistributionManager)
    */
   @Override
   protected void process(DistributionManager dm) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/WanLocatorDiscoverer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/WanLocatorDiscoverer.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/WanLocatorDiscoverer.java
index 05e04e0..3b4f692 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/WanLocatorDiscoverer.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/WanLocatorDiscoverer.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal;
+package org.apache.geode.distributed.internal;
 
-import com.gemstone.gemfire.cache.client.internal.locator.wan.LocatorMembershipListener;
+import org.apache.geode.cache.client.internal.locator.wan.LocatorMembershipListener;
 
 public interface WanLocatorDiscoverer {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DLockDependencyMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DLockDependencyMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DLockDependencyMonitor.java
index 02e5b6a..5421dd7 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DLockDependencyMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DLockDependencyMonitor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.Collections;
@@ -22,9 +22,9 @@ import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DLockToken;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.locks.DLockToken;
 
 /**
  * Report dependencies on dlocks that exist in theis VM.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DeadlockDetector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DeadlockDetector.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DeadlockDetector.java
index 23513d6..2c70418 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DeadlockDetector.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DeadlockDetector.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.BufferedInputStream;
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/Dependency.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/Dependency.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/Dependency.java
index 362300f..c470a97 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/Dependency.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/Dependency.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
index 0c67bb8..a6c8dd7 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.Collection;
@@ -27,8 +27,8 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.deadlock.MessageDependencyMonitor.MessageKey;
-import com.gemstone.gemfire.internal.util.PluckStacks;
+import org.apache.geode.distributed.internal.deadlock.MessageDependencyMonitor.MessageKey;
+import org.apache.geode.internal.util.PluckStacks;
 
 /**
  * This class holds a graph of dependencies between objects

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitor.java
index 6a40596..ee72bd3 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitorManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitorManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitorManager.java
index cbd3a8c..95c5eca 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitorManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyMonitorManager.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.CopyOnWriteHashSet;
+import org.apache.geode.internal.CopyOnWriteHashSet;
 
 /**
  * A singleton which keeps track of all of the dependency monitors registered in

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/GemFireDeadlockDetector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/GemFireDeadlockDetector.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/GemFireDeadlockDetector.java
index a972ed6..dfbe0dc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/GemFireDeadlockDetector.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/GemFireDeadlockDetector.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.HashSet;
@@ -22,17 +22,17 @@ import java.util.LinkedList;
 import java.util.Set;
 import java.util.concurrent.TimeUnit;
 
-import com.gemstone.gemfire.cache.execute.Execution;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionContext;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.execute.AbstractExecution;
+import org.apache.geode.cache.execute.Execution;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionContext;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.execute.AbstractExecution;
 
 /**
  * This class uses gemfire function execution to get the dependencies between

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalLockInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalLockInfo.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalLockInfo.java
index 67c02f9..fb5c4ea 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalLockInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalLockInfo.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.lang.management.LockInfo;
 import java.lang.management.MonitorInfo;
 
-import com.gemstone.gemfire.internal.concurrent.LI;
+import org.apache.geode.internal.concurrent.LI;
 
 /**
  * This class is serializable version of the java 1.6 lock info

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalThread.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalThread.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalThread.java
index 6280346..32eb6bc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalThread.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/LocalThread.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.lang.management.LockInfo;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/MessageDependencyMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/MessageDependencyMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/MessageDependencyMonitor.java
index fe590aa..c041dc6 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/MessageDependencyMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/MessageDependencyMonitor.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 import java.util.Collections;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/ThreadReference.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/ThreadReference.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/ThreadReference.java
index 815834d..8c201d0 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/ThreadReference.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/ThreadReference.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.io.Serializable;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/UnsafeThreadLocal.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/UnsafeThreadLocal.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/UnsafeThreadLocal.java
index 9d99aa8..1a69aec 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/UnsafeThreadLocal.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/UnsafeThreadLocal.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.deadlock;
+package org.apache.geode.distributed.internal.deadlock;
 
 import java.lang.reflect.Field;
 import java.lang.reflect.InvocationTargetException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannel.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannel.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannel.java
index 9f18e62..f6582ba 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannel.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannel.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.direct;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.DirectReplyMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.tcp.*;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
-import com.gemstone.gemfire.internal.util.concurrent.ReentrantSemaphore;
+package org.apache.geode.distributed.internal.direct;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.cache.DirectReplyMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.tcp.*;
+import org.apache.geode.internal.util.Breadcrumbs;
+import org.apache.geode.internal.util.concurrent.ReentrantSemaphore;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;
@@ -47,7 +47,7 @@ import java.util.concurrent.Semaphore;
 /**
  * DirectChannel is used to interact directly with other Direct servers to
  * distribute GemFire messages to other nodes.  It is held by a
- * com.gemstone.gemfire.internal.cache.distribution.DistributionChannel,
+ * org.apache.geode.internal.cache.distribution.DistributionChannel,
  * which is used by the DistributionManager to send and receive asynchronous
  * messages.
  */
@@ -176,7 +176,7 @@ public class DirectChannel {
   }
   private void acquireGroupSendPermission(boolean ordered) {
     if (this.disconnected) {
-      throw new com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException(LocalizedStrings.DirectChannel_DIRECT_CHANNEL_HAS_BEEN_STOPPED.toLocalizedString());
+      throw new org.apache.geode.distributed.DistributedSystemDisconnectedException(LocalizedStrings.DirectChannel_DIRECT_CHANNEL_HAS_BEEN_STOPPED.toLocalizedString());
     }
     // @todo darrel: add some stats
     final Semaphore s = getGroupSem(ordered);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannelListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannelListener.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannelListener.java
index a97676d..df414db 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannelListener.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/DirectChannelListener.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.direct;
+package org.apache.geode.distributed.internal.direct;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
 
 public interface DirectChannelListener {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/ShunnedMemberException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/ShunnedMemberException.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/ShunnedMemberException.java
index 59db762..c439d4a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/ShunnedMemberException.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/direct/ShunnedMemberException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.direct;
+package org.apache.geode.distributed.internal.direct;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * Exception thrown when a member is no longer in the distributed system

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/distribution-overview.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/distribution-overview.html b/geode-core/src/main/java/org/apache/geode/distributed/internal/distribution-overview.html
index 9e07ead..d151c1c 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/distribution-overview.html
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/distribution-overview.html
@@ -21,10 +21,10 @@ limitations under the License.
 
 Distributed GemFire moves information between physical machines in a
 number of different ways.  The JCache implementation uses {@link
-com.gemstone.gemfire.distributed.internal.DistributionMessage}s
+org.apache.geode.distributed.internal.DistributionMessage}s
 to send information back and forth between VMs.  The distributed
 collections use the remote method invocation built on top of a {@link
-com.gemstone.gemfire.tcp.TCPConuit} to access elements in remote
+org.apache.geode.tcp.TCPConuit} to access elements in remote
 collections.  GemFire distirbution uses underlying technologies such
 as JavaGroups, and sockets to implement data transfer.
 
@@ -35,7 +35,7 @@ exposed to concepts such as the "distribution manager" and the fact
 that multicast networking or "locators" are used to discover the other
 members of the distributed group.  The user-level configuration is
 grouped together in the {@link
-com.gemstone.gemfire.distributed.DistributedSystem} class which
+org.apache.geode.distributed.DistributedSystem} class which
 provides a "connection" or entry point to the distributed system.
 
 </BODY>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/Collaboration.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/Collaboration.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/Collaboration.java
index 061154a..ef33f2a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/Collaboration.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/Collaboration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.util.ArrayList;
 import java.util.HashMap;
@@ -25,10 +25,10 @@ import java.util.concurrent.TimeUnit;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Synchronization structure which allows multiple threads to lock the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatch.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatch.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatch.java
index 832f949..6690893 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatch.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatch.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Collection of distributed locks to be processed as a batch. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatchId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatchId.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatchId.java
index e3a7892..94f2cf3 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatchId.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockBatchId.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.distributed.internal.locks.LockGrantorId;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.distributed.internal.locks.LockGrantorId;
 
 /** 
  * Identifies a {@link DLockBatch}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockGrantor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockGrantor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockGrantor.java
index 3fcc720..5ef7647 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockGrantor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockGrantor.java
@@ -15,28 +15,28 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.MembershipListener;
-import com.gemstone.gemfire.distributed.internal.locks.DLockQueryProcessor.DLockQueryMessage;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.IdentityArrayList;
-import com.gemstone.gemfire.internal.cache.TXReservationMgr;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
+package org.apache.geode.distributed.internal.locks;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.MembershipListener;
+import org.apache.geode.distributed.internal.locks.DLockQueryProcessor.DLockQueryMessage;
+import org.apache.geode.distributed.internal.locks.DLockRequestProcessor.DLockRequestMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.IdentityArrayList;
+import org.apache.geode.internal.cache.TXReservationMgr;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;
@@ -585,12 +585,12 @@ public class DLockGrantor {
    * <p>
    * Acquires acquireDestroyReadLock. Synchronizes on batchLocks.
    * <p>
-   * see com.gemstone.gemfire.internal.cache.TXCommitMessage#updateLockMembers()
+   * see org.apache.geode.internal.cache.TXCommitMessage#updateLockMembers()
    *  
    * @param batchId the identifier for the batch to retrieve
    * @return the transaction lock batch identified by the given batchId
-   * @see com.gemstone.gemfire.internal.cache.locks.TXLockUpdateParticipantsMessage
-   * @see com.gemstone.gemfire.internal.cache.locks.TXLockBatch#getBatchId()
+   * @see org.apache.geode.internal.cache.locks.TXLockUpdateParticipantsMessage
+   * @see org.apache.geode.internal.cache.locks.TXLockBatch#getBatchId()
    */
   public DLockBatch getLockBatch(Object batchId) throws InterruptedException {
     DLockBatch ret = null;
@@ -624,12 +624,12 @@ public class DLockGrantor {
    * <p>
    * Acquires acquireDestroyReadLock. Synchronizes on batchLocks.
    * <p>
-   * see com.gemstone.gemfire.internal.cache.locks.TXCommitMessage#updateLockMembers()
+   * see org.apache.geode.internal.cache.locks.TXCommitMessage#updateLockMembers()
    * 
    * @param batchId the identify of the transaction lock batch
    * @param newBatch the new lock batch to be used
-   * @see com.gemstone.gemfire.internal.cache.locks.TXLockUpdateParticipantsMessage
-   * @see com.gemstone.gemfire.internal.cache.locks.TXLockBatch#getBatchId()
+   * @see org.apache.geode.internal.cache.locks.TXLockUpdateParticipantsMessage
+   * @see org.apache.geode.internal.cache.locks.TXLockBatch#getBatchId()
    */
   public void updateLockBatch(Object batchId, DLockBatch newBatch) throws InterruptedException {
     final boolean isDebugEnabled_DLS = logger.isTraceEnabled(LogMarker.DLS);
@@ -1115,7 +1115,7 @@ public class DLockGrantor {
       throws InterruptedException {
     // bug 32657 has another cause in this method... interrupted thread from
     // connection/channel layer caused acquireDestroyReadLock to fail... 
-    // fixed by Darrel in com.gemstone.gemfire.internal.tcp.Connection
+    // fixed by Darrel in org.apache.geode.internal.tcp.Connection
     final boolean isDebugEnabled_DLS = logger.isTraceEnabled(LogMarker.DLS);
     if (acquireDestroyReadLock(0)) {
       try {
@@ -3112,7 +3112,7 @@ public class DLockGrantor {
      * Returns true if this lock represents suspend locking.
      * 
      * @return true if this lock represents suspend locking
-     * @see com.gemstone.gemfire.distributed.DistributedLockService#suspendLocking(long)
+     * @see org.apache.geode.distributed.DistributedLockService#suspendLocking(long)
      */
     boolean isSuspendLockingToken() {
       return DLockService.SUSPEND_LOCKING_TOKEN.equals(this.lockName);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockLessorDepartureHandler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockLessorDepartureHandler.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockLessorDepartureHandler.java
index 5909e24..8b38665 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockLessorDepartureHandler.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockLessorDepartureHandler.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Provides hook for handling departure of a lease holder (lessor).

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockQueryProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockQueryProcessor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockQueryProcessor.java
index 7ac74b4..760e15e 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockQueryProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/locks/DLockQueryProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.distributed.internal.locks;
+package org.apache.geode.distributed.internal.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,22 +23,22 @@ import java.io.IOException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor.DLockGrantToken;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.locks.DLockGrantor.DLockGrantToken;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Queries the grantor for current leasing information of a lock.


[25/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/auth/GMSAuthenticator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/auth/GMSAuthenticator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/auth/GMSAuthenticator.java
index 7fc212c..a205d93 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/auth/GMSAuthenticator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/auth/GMSAuthenticator.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.auth;
+package org.apache.geode.distributed.internal.membership.gms.auth;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-import static com.gemstone.gemfire.internal.i18n.LocalizedStrings.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+import static org.apache.geode.internal.i18n.LocalizedStrings.*;
 
 import java.security.Principal;
 import java.util.Properties;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Authenticator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
-import com.gemstone.gemfire.internal.security.IntegratedSecurityService;
-import com.gemstone.gemfire.internal.security.SecurityService;
-import com.gemstone.gemfire.security.AuthInitialize;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
-import com.gemstone.gemfire.security.AuthenticationRequiredException;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.LogWriter;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.Authenticator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.InternalLogWriter;
+import org.apache.geode.internal.security.IntegratedSecurityService;
+import org.apache.geode.internal.security.SecurityService;
+import org.apache.geode.security.AuthInitialize;
+import org.apache.geode.security.AuthenticationFailedException;
+import org.apache.geode.security.AuthenticationRequiredException;
+import org.apache.geode.security.GemFireSecurityException;
 
 public class GMSAuthenticator implements Authenticator {
 
@@ -143,9 +143,9 @@ public class GMSAuthenticator implements Authenticator {
    */
   Principal invokeAuthenticator(Properties securityProps, DistributedMember member, Properties credentials) throws AuthenticationFailedException {
       String authMethod = securityProps.getProperty(SECURITY_PEER_AUTHENTICATOR);
-    com.gemstone.gemfire.security.Authenticator auth = null;
+    org.apache.geode.security.Authenticator auth = null;
     try {
-      auth = SecurityService.getObjectOfTypeFromFactoryMethod(authMethod, com.gemstone.gemfire.security.Authenticator.class);
+      auth = SecurityService.getObjectOfTypeFromFactoryMethod(authMethod, org.apache.geode.security.Authenticator.class);
 
       LogWriter logWriter = this.services.getLogWriter();
       LogWriter securityLogWriter = this.services.getSecurityLogWriter();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/fd/GMSHealthMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/fd/GMSHealthMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/fd/GMSHealthMonitor.java
index 9fdbb64..f3d8281 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/fd/GMSHealthMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/fd/GMSHealthMonitor.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.fd;
+package org.apache.geode.distributed.internal.membership.gms.fd;
 
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.HEARTBEAT_REQUEST;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.HEARTBEAT_RESPONSE;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.SUSPECT_MEMBERS_MESSAGE;
+import static org.apache.geode.internal.DataSerializableFixedID.HEARTBEAT_REQUEST;
+import static org.apache.geode.internal.DataSerializableFixedID.HEARTBEAT_RESPONSE;
+import static org.apache.geode.internal.DataSerializableFixedID.SUSPECT_MEMBERS_MESSAGE;
 
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
@@ -45,25 +45,25 @@ import java.util.stream.*;
 import org.apache.logging.log4j.Logger;
 import org.jgroups.util.UUID;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.HealthMonitor;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.MessageHandler;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.HeartbeatMessage;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.HeartbeatRequestMessage;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.SuspectMembersMessage;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.SuspectRequest;
-import com.gemstone.gemfire.internal.ConnectionWatcher;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.CancelException;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.HealthMonitor;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.MessageHandler;
+import org.apache.geode.distributed.internal.membership.gms.messages.HeartbeatMessage;
+import org.apache.geode.distributed.internal.membership.gms.messages.HeartbeatRequestMessage;
+import org.apache.geode.distributed.internal.membership.gms.messages.SuspectMembersMessage;
+import org.apache.geode.distributed.internal.membership.gms.messages.SuspectRequest;
+import org.apache.geode.internal.ConnectionWatcher;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.Version;
 
 /**
  * Failure Detection

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Authenticator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Authenticator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Authenticator.java
index 9660267..fe15ace 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Authenticator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Authenticator.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.security.AuthenticationFailedException;
 
 public interface Authenticator extends Service {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/HealthMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/HealthMonitor.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/HealthMonitor.java
index 3541f80..5058aed 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/HealthMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/HealthMonitor.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
 import java.net.InetSocketAddress;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetMember;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetMember;
 
 public interface HealthMonitor extends Service {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/JoinLeave.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/JoinLeave.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/JoinLeave.java
index 202a125..addfec3 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/JoinLeave.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/JoinLeave.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetMember;
+import org.apache.geode.distributed.internal.membership.NetView;
 
 public interface JoinLeave extends Service {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Locator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Locator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Locator.java
index c36f6ea..68390ee 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Locator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Locator.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.NetView;
 
 /**
  * The Locator interface allows member services to interact with the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Manager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Manager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Manager.java
index 8353af6..233aa3a 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Manager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Manager.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
 import java.io.NotSerializableException;
 import java.util.Collection;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.SuspectMember;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.SuspectMember;
 
 /**
  * Manager presents the GMS services to the outside world and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/MessageHandler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/MessageHandler.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/MessageHandler.java
index 8e2073b..fcd944c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/MessageHandler.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/MessageHandler.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionMessage;
 
 /**
  * MessageHandler processes a message received by Messenger.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Messenger.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Messenger.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Messenger.java
index 51c74da..470fd1f 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Messenger.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Messenger.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
 
 public interface Messenger extends Service {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Service.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Service.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Service.java
index 9eac344..4fc68b9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Service.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/interfaces/Service.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.interfaces;
+package org.apache.geode.distributed.internal.membership.gms.interfaces;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.Services;
 
 /**
  * Services in GMS all implement this interface

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorRequest.java
index d9d5dc9..3e346a5 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,13 +22,13 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.Collection;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 public class FindCoordinatorRequest extends HighPriorityDistributionMessage
   implements PeerLocatorRequest {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorResponse.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorResponse.java
index 66e5982..b81cf4a 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/FindCoordinatorResponse.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,14 +23,14 @@ import java.util.Arrays;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 public class FindCoordinatorResponse  extends HighPriorityDistributionMessage
     implements DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GMSLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GMSLocator.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GMSLocator.java
index 69a1f60..3970efc 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GMSLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GMSLocator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 import java.io.File;
 import java.io.FileInputStream;
@@ -34,32 +34,32 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.InternalGemFireException;
+import org.apache.geode.InternalGemFireException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.GemFireCache;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.LocatorStats;
-import com.gemstone.gemfire.distributed.internal.SharedConfiguration;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MembershipManager;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember.InternalDistributedMemberWrapper;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSUtil;
-import com.gemstone.gemfire.distributed.internal.membership.gms.NetLocator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Locator;
-import com.gemstone.gemfire.distributed.internal.membership.gms.mgr.GMSMembershipManager;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpClient;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpServer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedObjectInput;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.GemFireCache;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.LocatorStats;
+import org.apache.geode.distributed.internal.SharedConfiguration;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MembershipManager;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember.InternalDistributedMemberWrapper;
+import org.apache.geode.distributed.internal.membership.gms.GMSUtil;
+import org.apache.geode.distributed.internal.membership.gms.NetLocator;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.Locator;
+import org.apache.geode.distributed.internal.membership.gms.mgr.GMSMembershipManager;
+import org.apache.geode.distributed.internal.tcpserver.TcpClient;
+import org.apache.geode.distributed.internal.tcpserver.TcpServer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedObjectInput;
+import org.apache.geode.internal.logging.LogService;
 
-import static com.gemstone.gemfire.internal.i18n.LocalizedStrings.LOCATOR_UNABLE_TO_RECOVER_VIEW;
+import static org.apache.geode.internal.i18n.LocalizedStrings.LOCATOR_UNABLE_TO_RECOVER_VIEW;
 
 public class GMSLocator implements Locator, NetLocator {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewRequest.java
index 9d582af..56cf9c9 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewRequest.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 public class GetViewRequest implements DataSerializableFixedID, PeerLocatorRequest {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewResponse.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewResponse.java
index 048e7c9..88da07f 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/GetViewResponse.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 public class GetViewResponse implements DataSerializableFixedID {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/PeerLocatorRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/PeerLocatorRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/PeerLocatorRequest.java
index 7597c94..236dd23 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/PeerLocatorRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/locator/PeerLocatorRequest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.locator;
+package org.apache.geode.distributed.internal.membership.gms.locator;
 
 /**
  * PeerLocatorRequest is a marker for messages that are intended to be handled

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/membership/GMSJoinLeave.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/membership/GMSJoinLeave.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/membership/GMSJoinLeave.java
index 1c6cf16..cc7c83a 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/membership/GMSJoinLeave.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/membership/GMSJoinLeave.java
@@ -14,31 +14,31 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.membership;
-
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.Locator;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSUtil;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.JoinLeave;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.MessageHandler;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.*;
-import com.gemstone.gemfire.distributed.internal.tcpserver.TcpClient;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.security.AuthenticationFailedException;
+package org.apache.geode.distributed.internal.membership.gms.membership;
+
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.Locator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.distributed.internal.membership.gms.GMSUtil;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.JoinLeave;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.MessageHandler;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
+import org.apache.geode.distributed.internal.membership.gms.messages.*;
+import org.apache.geode.distributed.internal.tcpserver.TcpClient;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.security.AuthenticationFailedException;
 
 import org.apache.logging.log4j.Logger;
 
@@ -48,10 +48,10 @@ import java.util.*;
 import java.util.concurrent.*;
 import java.util.concurrent.atomic.AtomicInteger;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.START_LOCATOR;
-import static com.gemstone.gemfire.distributed.internal.membership.gms.ServiceConfig.MEMBER_REQUEST_COLLECTION_INTERVAL;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.*;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.START_LOCATOR;
+import static org.apache.geode.distributed.internal.membership.gms.ServiceConfig.MEMBER_REQUEST_COLLECTION_INTERVAL;
+import static org.apache.geode.internal.DataSerializableFixedID.*;
 
 /**
  * GMSJoinLeave handles membership communication with other processes in the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HasMemberID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HasMemberID.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HasMemberID.java
index 1962edf..7080f91 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HasMemberID.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HasMemberID.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 public interface HasMemberID {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatMessage.java
index 6662d2c..ca38173 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatMessage.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.internal.Version;
 
 public class HeartbeatMessage extends HighPriorityDistributionMessage {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatRequestMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatRequestMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatRequestMessage.java
index e0f4515..9bbe758 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatRequestMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/HeartbeatRequestMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
 
 public class HeartbeatRequestMessage extends HighPriorityDistributionMessage{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/InstallViewMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/InstallViewMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/InstallViewMessage.java
index 224fef1..2f0fced 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/InstallViewMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/InstallViewMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,11 +23,11 @@ import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.internal.InternalDataSerializer;
 
 public class InstallViewMessage extends HighPriorityDistributionMessage {
   enum messageType {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinRequestMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinRequestMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinRequestMessage.java
index b282daa..e501269 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinRequestMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinRequestMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
 
 public class JoinRequestMessage extends HighPriorityDistributionMessage {
   private InternalDistributedMember memberID;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinResponseMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinResponseMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinResponseMessage.java
index ff20a4e..bdf4c12 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinResponseMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/JoinResponseMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,13 +24,13 @@ import java.util.Arrays;
 import java.util.Collections;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 public class JoinResponseMessage extends HighPriorityDistributionMessage {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/LeaveRequestMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/LeaveRequestMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/LeaveRequestMessage.java
index dd8475d..1fd0679 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/LeaveRequestMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/LeaveRequestMessage.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.Collection;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
 
 public class LeaveRequestMessage extends HighPriorityDistributionMessage
   implements HasMemberID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/NetworkPartitionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/NetworkPartitionMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/NetworkPartitionMessage.java
index a4a811f..2dea756 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/NetworkPartitionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/NetworkPartitionMessage.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.util.Collection;
 
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 public class NetworkPartitionMessage extends HighPriorityDistributionMessage {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/RemoveMemberMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/RemoveMemberMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/RemoveMemberMessage.java
index e7d82b5..3993f31 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/RemoveMemberMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/RemoveMemberMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,11 +22,11 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
 
 public class RemoveMemberMessage extends HighPriorityDistributionMessage
   implements HasMemberID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectMembersMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectMembersMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectMembersMessage.java
index 0b2f6ba..05ebc0c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectMembersMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectMembersMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,11 +22,11 @@ import java.io.IOException;
 import java.util.ArrayList;
 import java.util.List;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Version;
 
 public class SuspectMembersMessage extends HighPriorityDistributionMessage {
   final List<SuspectRequest> suspectRequests;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectRequest.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectRequest.java
index 5c26fa8..e50e40c 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/SuspectRequest.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 public class SuspectRequest {
   final InternalDistributedMember suspectMember;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/ViewAckMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/ViewAckMessage.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/ViewAckMessage.java
index 7ff64ba..464127b 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/ViewAckMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messages/ViewAckMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messages;
+package org.apache.geode.distributed.internal.membership.gms.messages;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
 
 public class ViewAckMessage extends HighPriorityDistributionMessage {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/AddressManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/AddressManager.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/AddressManager.java
index 06cd370..4010c00 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/AddressManager.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/AddressManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import java.lang.reflect.InvocationTargetException;
 import java.lang.reflect.Method;
@@ -29,7 +29,7 @@ import org.jgroups.stack.IpAddress;
 import org.jgroups.stack.Protocol;
 import org.jgroups.util.Responses;
 
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.Services;
 
 /**
  * JGroups will not send messages that have IpAddress destination addresses.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSEncrypt.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSEncrypt.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSEncrypt.java
index 6c41465..e442898 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSEncrypt.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSEncrypt.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import java.math.BigInteger;
 import java.security.*;
@@ -32,11 +32,11 @@ import javax.crypto.spec.DHParameterSpec;
 import javax.crypto.spec.IvParameterSpec;
 import javax.crypto.spec.SecretKeySpec;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember.InternalDistributedMemberWrapper;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember.InternalDistributedMemberWrapper;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 public class GMSEncrypt implements Cloneable {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSPingPonger.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSPingPonger.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSPingPonger.java
index e2951ee..31379ad 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSPingPonger.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSPingPonger.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import org.jgroups.Address;
 import org.jgroups.JChannel;
 import org.jgroups.Message;
 
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.internal.Version;
 
 public class GMSPingPonger {
   private byte[] pingInBytes = new byte[] { 'p', 'i', 'n', 'g' };

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSQuorumChecker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSQuorumChecker.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSQuorumChecker.java
index 72e2097..785bd67 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSQuorumChecker.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/GMSQuorumChecker.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import java.io.InputStream;
 import java.io.OutputStream;
@@ -34,11 +34,11 @@ import org.jgroups.Message;
 import org.jgroups.Receiver;
 import org.jgroups.View;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
-import com.gemstone.gemfire.internal.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.logging.LogService;
 
 public class GMSQuorumChecker implements QuorumChecker {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGAddress.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGAddress.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGAddress.java
index 1f97001..38be872 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGAddress.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGAddress.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.internal.SocketCreator;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.internal.SocketCreator;
 import org.jgroups.Global;
 import org.jgroups.stack.IpAddress;
 import org.jgroups.util.UUID;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessenger.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
index ca23639..bae03ef 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/JGroupsMessenger.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
-import static com.gemstone.gemfire.distributed.internal.membership.gms.GMSUtil.replaceStrings;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.JOIN_REQUEST;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.JOIN_RESPONSE;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.FIND_COORDINATOR_REQ;
-import static com.gemstone.gemfire.internal.DataSerializableFixedID.FIND_COORDINATOR_RESP;
+import static org.apache.geode.distributed.internal.membership.gms.GMSUtil.replaceStrings;
+import static org.apache.geode.internal.DataSerializableFixedID.JOIN_REQUEST;
+import static org.apache.geode.internal.DataSerializableFixedID.JOIN_RESPONSE;
+import static org.apache.geode.internal.DataSerializableFixedID.FIND_COORDINATOR_REQ;
+import static org.apache.geode.internal.DataSerializableFixedID.FIND_COORDINATOR_RESP;
 
 import java.io.BufferedReader;
 import java.io.ByteArrayInputStream;
@@ -64,40 +64,40 @@ import org.jgroups.stack.IpAddress;
 import org.jgroups.util.Digest;
 import org.jgroups.util.UUID;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.ForcedDisconnectException;
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.DurableClientAttributes;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.MemberAttributes;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.QuorumChecker;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.MessageHandler;
-import com.gemstone.gemfire.distributed.internal.membership.gms.interfaces.Messenger;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.JoinRequestMessage;
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.JoinResponseMessage;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.VersionedDataInputStream;
-import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
-import com.gemstone.gemfire.internal.cache.DirectReplyMessage;
-import com.gemstone.gemfire.internal.cache.DistributedCacheOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.log4j.AlertAppender;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.tcp.MemberShunnedException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.ForcedDisconnectException;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.DurableClientAttributes;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.MemberAttributes;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.QuorumChecker;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.MessageHandler;
+import org.apache.geode.distributed.internal.membership.gms.interfaces.Messenger;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
+import org.apache.geode.distributed.internal.membership.gms.messages.JoinRequestMessage;
+import org.apache.geode.distributed.internal.membership.gms.messages.JoinResponseMessage;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.OSProcess;
+import org.apache.geode.internal.SocketCreator;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.VersionedDataInputStream;
+import org.apache.geode.internal.admin.remote.RemoteTransportConfig;
+import org.apache.geode.internal.cache.DirectReplyMessage;
+import org.apache.geode.internal.cache.DistributedCacheOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.log4j.AlertAppender;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.tcp.MemberShunnedException;
 
 import it.unimi.dsi.fastutil.ints.Int2ObjectOpenHashMap;
 
@@ -110,12 +110,12 @@ public class JGroupsMessenger implements Messenger {
   /**
    * The location (in the product) of the locator Jgroups config file.
    */
-  private static final String DEFAULT_JGROUPS_TCP_CONFIG = "com/gemstone/gemfire/distributed/internal/membership/gms/messenger/jgroups-config.xml";
+  private static final String DEFAULT_JGROUPS_TCP_CONFIG = "org/apache/geode/distributed/internal/membership/gms/messenger/jgroups-config.xml";
 
   /**
    * The location (in the product) of the mcast Jgroups config file.
    */
-  private static final String JGROUPS_MCAST_CONFIG_FILE_NAME = "com/gemstone/gemfire/distributed/internal/membership/gms/messenger/jgroups-mcast.xml";
+  private static final String JGROUPS_MCAST_CONFIG_FILE_NAME = "org/apache/geode/distributed/internal/membership/gms/messenger/jgroups-mcast.xml";
 
   /** JG magic numbers for types added to the JG ClassConfigurator */
   private static final short JGROUPS_TYPE_JGADDRESS = 2000;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/StatRecorder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/StatRecorder.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/StatRecorder.java
index e013de6..95cd163 100755
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/StatRecorder.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/StatRecorder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import org.apache.logging.log4j.Logger;
 import org.jgroups.Event;
@@ -28,9 +28,9 @@ import org.jgroups.protocols.pbcast.NAKACK2;
 import org.jgroups.protocols.pbcast.NakAckHeader2;
 import org.jgroups.stack.Protocol;
 
-import com.gemstone.gemfire.distributed.internal.DMStats;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSUtil;
-import com.gemstone.gemfire.distributed.internal.membership.gms.Services;
+import org.apache.geode.distributed.internal.DMStats;
+import org.apache.geode.distributed.internal.membership.gms.GMSUtil;
+import org.apache.geode.distributed.internal.membership.gms.Services;
 
 import java.util.concurrent.RejectedExecutionException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/Transport.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/Transport.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/Transport.java
index e1d9af6..8951378 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/Transport.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/membership/gms/messenger/Transport.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.distributed.internal.membership.gms.messenger;
+package org.apache.geode.distributed.internal.membership.gms.messenger;
 
 import java.io.IOException;
 import java.io.InterruptedIOException;


[60/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/driver/PulseUITest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/driver/PulseUITest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/driver/PulseUITest.java
deleted file mode 100644
index 2445be8..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/testbed/driver/PulseUITest.java
+++ /dev/null
@@ -1,277 +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 com.vmware.geode.tools.pulse.testbed.driver;
-
-import static com.vmware.geode.tools.pulse.tests.PulseAbstractTest.*;
-import static org.junit.Assert.*;
-
-import java.net.InetAddress;
-import java.util.List;
-
-import org.junit.After;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.experimental.categories.Category;
-import org.openqa.selenium.By;
-import org.openqa.selenium.WebDriver;
-import org.openqa.selenium.WebElement;
-import org.openqa.selenium.firefox.FirefoxDriver;
-import org.openqa.selenium.support.ui.ExpectedCondition;
-import org.openqa.selenium.support.ui.WebDriverWait;
-
-import org.apache.geode.management.internal.JettyHelper;
-import org.apache.geode.test.junit.categories.UITest;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Locator;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Peer;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Region;
-import com.vmware.geode.tools.pulse.testbed.GemFireDistributedSystem.Server;
-import com.vmware.geode.tools.pulse.testbed.TestBed;
-
-@Ignore("TODO: test is ignored")
-@Category(UITest.class)
-public class PulseUITest {
-
-  private static WebDriver driver;
-  private static TestBed testBed;
-  private static String pulseURL;
-  private static String path;
-  private static org.eclipse.jetty.server.Server jetty = null;
-
-  private static final String userName = "admin";
-  private static final String pasword = "admin";
-  
-  private static final String DATA_VIEW_LABEL = "Data View";
-  private static final String CLUSTER_VIEW_MEMBERS_ID = "clusterTotalMembersText";
-  private static final String CLUSTER_VIEW_SERVERS_ID = "clusterServersText";
-  private static final String CLUSTER_VIEW_LOCATORS_ID = "clusterLocatorsText";
-  private static final String CLUSTER_VIEW_REGIONS_ID = "clusterTotalRegionsText";
-
-  @BeforeClass
-  public static void setUpJetty() throws Exception {
-    String host = InetAddress.getLocalHost().getHostAddress();
-    int port = 8080;
-    String context = "/pulse";
-    path = getPulseWarPath();
-    //System.setProperty("pulse.propMockDataUpdaterClass", "com.vmware.geode.tools.pulse.testbed.PropMockDataUpdater");
-
-    jetty = JettyHelper.initJetty(host, port, false, false, null, null, null);
-    JettyHelper.addWebApplication(jetty, context, getPulseWarPath());
-    jetty.start();
-
-    pulseURL = "http://" + host + ":" + port + context;
-    Thread.sleep(1000); //wait till tomcat settles down
-    driver = new FirefoxDriver();
-    driver.manage().window().maximize();//required to make all elements visible
-
-    Thread.sleep(5000); //wait till pulse starts polling threads...
-    testBed = new TestBed();
-    loginToPulse(driver, userName, pasword);
-  }
-
-  @AfterClass
-  public static void stopJetty() throws Exception {
-    jetty.stop();
-  }
-
-  @After
-  public void closeSession() {
-    driver.close();
-  }
-
-  private static void loginToPulse(WebDriver driver, String userName,String password){
-    driver.get(pulseURL);    
-    WebElement userNameElement = driver.findElement(By.id("user_name"));
-    WebElement passwordElement = driver.findElement(By.id("user_password"));
-    userNameElement.sendKeys(userName);
-    passwordElement.sendKeys(password);
-    passwordElement.submit();
-    WebElement userNameOnPulsePage = (new WebDriverWait(driver, 10))
-        .until(new ExpectedCondition<WebElement>() {
-          @Override
-          public WebElement apply(WebDriver d) {
-            return d.findElement(By.id("userName"));
-          }
-        });
-    assertNotNull(userNameOnPulsePage);
-  }
-  
-  
-  private void searchByLinkAndClick(String linkText){
-    WebElement  dataViewButton= By.linkText(linkText).findElement(driver);
-    assertNotNull(dataViewButton);   
-    dataViewButton.click();
-  }
-  
-  private void searchByIdAndClick(String id){
-    WebElement  element = driver.findElement(By.id(id));
-    assertNotNull(element);
-    element.click();    
-  }
-  
-  private void searchByXPathAndClick(String xpath){    
-    WebElement  element = driver.findElement(By.xpath(xpath));
-    assertNotNull(element);
-    element.click();    
-  }
-  
-  private void waitForElementByClassName(final String className, int seconds){
-    WebElement linkTextOnPulsePage1 = (new WebDriverWait(driver, seconds))
-    .until(new ExpectedCondition<WebElement>() {
-      @Override
-      public WebElement apply(WebDriver d) {
-        return d.findElement(By.className(className));
-      }
-    });
-    assertNotNull(linkTextOnPulsePage1);
-  }
-  
-  private void waitForElementById(final String id, int seconds){
-    WebElement element = (new WebDriverWait(driver, 10))
-    .until(new ExpectedCondition<WebElement>() {
-      @Override
-      public WebElement apply(WebDriver d) {
-        return d.findElement(By.id(id));
-      }
-    });
-    assertNotNull(element);
-  }
-  
-  @Test
-  public void testClusterViewTopRibbon() {
-    List<Server> servers = testBed.getRootDs().getServers();
-    List<Locator> locators = testBed.getRootDs().getLocators();
-    List<Peer> peers = testBed.getRootDs().getPeers();
-    List<Region> regions = testBed.getRootDs().getRegions();
-    int totalMembers = servers.size() + locators.size() + peers.size();
-    int clusterMembers = Integer.parseInt(driver.findElement(
-        By.id(CLUSTER_VIEW_MEMBERS_ID)).getText());
-    int clusterServers = Integer.parseInt(driver.findElement(
-        By.id(CLUSTER_VIEW_SERVERS_ID)).getText());
-    int clusterLocators = Integer.parseInt(driver.findElement(
-        By.id(CLUSTER_VIEW_LOCATORS_ID)).getText());
-    int clusterRegions = Integer.parseInt(driver.findElement(
-        By.id(CLUSTER_VIEW_REGIONS_ID)).getText());
-    assertEquals(totalMembers, clusterMembers);
-    assertEquals(servers.size(), clusterServers);
-    assertEquals(locators.size(), clusterLocators);
-    assertEquals(regions.size(), clusterRegions);
-  }  
-
-
-  @Test
-  public void testDataViewRegionProperties() {
-    searchByLinkAndClick(DATA_VIEW_LABEL);
-    waitForElementByClassName("pointDetailsPadding",10);    
-    searchByIdAndClick("btngridIcon");
-    
-    for(int i=1;i<testBed.getRootDs().getRegions().size();i++){
-      searchByIdAndClick(""+i);
-      String regionName1 = driver.findElement(By.id("regionName")).getText();
-      @SuppressWarnings("rawtypes")
-      List regionMemberscount1 = testBed.getRootDs().getRegion(regionName1)
-          .getMembers();
-      int regionEntCount1 = testBed.getRootDs().getRegion(regionName1)
-          .getEntryCount();
-      int regionMembers1 = Integer.parseInt(driver.findElement(
-          By.id("regionMembers")).getText());
-      int regionEntryCount1 = Integer.parseInt(driver.findElement(
-          By.id("regionEntryCount")).getText());
-      assertEquals(regionMemberscount1.size(), regionMembers1);
-      assertEquals(regionEntCount1, regionEntryCount1);
-    }
-  }
-
-  
-  @Test
-  public void testMemberViewRegions() {
-    
-    searchByLinkAndClick(DATA_VIEW_LABEL);
-    waitForElementByClassName("pointDetailsPadding",10);    
-    searchByXPathAndClick("//div[@title='peer1']");    
-    waitForElementById("memberRegionsCount",10);    
-    
-    List<Server> servers = testBed.getRootDs().getServers();
-    List<Locator> locators = testBed.getRootDs().getLocators();
-    List<Peer> peers = testBed.getRootDs().getPeers();    
-
-    String prevSelectedMember = "peer1";
-    
-    for (Peer p : peers) {
-      String peer = p.getName();
-      System.out.println("Checking regions mapping for member " + peer);
-      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
-      comboBox.click();                 
-      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
-      WebElement selectedMember = comboList.findElement(By.linkText(peer));
-      selectedMember.click();
-      timeout();
-      String peername = driver.findElement(By.id("memberName")).getText();      
-      List<Region> peerRegionscount = testBed.getRootDs().getRegions(peer);
-      int peerRegions = Integer.parseInt(driver.findElement(
-          By.id("memberRegionsCount")).getText());
-      assertEquals(peerRegionscount.size(), peerRegions);
-      prevSelectedMember = peername;
-    }
-    
-    for (Server s : servers) {
-      String server = s.getName();
-      System.out.println("Checking regions mapping for server " + server);
-      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
-      comboBox.click();                 
-      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
-      WebElement selectedMember = comboList.findElement(By.linkText(server));
-      selectedMember.click();
-      timeout();
-      String peername = driver.findElement(By.id("memberName")).getText();      
-      List<Region> serverRegionscount = testBed.getRootDs().getRegions(server);
-      int serverRegions = Integer.parseInt(driver.findElement(
-          By.id("memberRegionsCount")).getText());
-      assertEquals(serverRegionscount.size(), serverRegions);
-      prevSelectedMember = peername;            
-    }
-    /*
-    for (Locator l : locators) {      
-      String locator = l.getName();
-      System.out.println("Checking regions mapping for locator " + locator);
-      WebElement comboBox = driver.findElement(By.linkText(prevSelectedMember));
-      comboBox.click();                 
-      WebElement comboList = driver.findElement(By.id("clusterMembersContainer"));     
-      WebElement selectedMember = comboList.findElement(By.linkText(locator));
-      selectedMember.click();
-      timeout();
-      String peername = driver.findElement(By.id("memberName")).getText();      
-      List<Region> locatorRegionscount = testBed.getRootDs().getRegions(locator);
-      int locatorRegions = Integer.parseInt(driver.findElement(
-          By.id("memberRegionsCount")).getText());
-      assertIndexDetailsEquals(locatorRegionscount.size(), locatorRegions);
-      prevSelectedMember = peername;
-    }*/
-  }
-
-  public void timeout() {
-    WebElement memberNameOnPulsePage = (new WebDriverWait(driver, 10))
-        .until(new ExpectedCondition<WebElement>() {
-          @Override
-          public WebElement apply(WebDriver d) {
-            return d.findElement(By.id("memberName"));
-          }
-        });
-    assertNotNull(memberNameOnPulsePage);    
-  }  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatement.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatement.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatement.java
deleted file mode 100644
index ebd310d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatement.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 com.vmware.geode.tools.pulse.tests;
-
-public class AggregateStatement extends JMXBaseBean implements AggregateStatementMBean {
-  private String name = null;
-
-  public AggregateStatement(String name) {
-    this.name = name;
-  }
-
-  protected String getKey(String propName) {
-    return "aggregatestatement." + name + "." + propName;
-  }
-  
-  /**
-   * Query definition
-   * 
-   * @return
-   */
-  public String getQueryDefinition(){
-    return getString("queryDefinition");
-  }
-
-  /**
-   * Number of times this statement is compiled (including re compilations)
-   * 
-   * @return
-   */
-  @Override
-  public long getNumTimesCompiled(){
-    return getLong("numTimesCompiled");
-  }
-
-  /**
-   * Number of times this statement is executed
-   * 
-   * @return
-   */
-  @Override
-  public long getNumExecution(){
-    return getLong("numExecution");
-  }
-
-  /**
-   * Statements that are actively being processed during the statistics snapshot
-   * 
-   * @return
-   */
-  public long getNumExecutionsInProgress(){
-    return getLong("numExecutionsInProgress");
-  }
-
-  /**
-   * Number of times global index lookup message exchanges occurred
-   * 
-   * @return
-   */
-  public long getNumTimesGlobalIndexLookup(){
-    return getLong("numTimesGlobalIndexLookup");
-  }
-
-  /**
-   * Number of rows modified by DML operation of insert/delete/update
-   * 
-   * @return
-   */
-  public long getNumRowsModified(){
-    return getLong("numRowsModified");
-  }
-
-  /**
-   * Time spent(in milliseconds) in parsing the query string
-   * 
-   * @return
-   */
-  public long getParseTime(){
-    return getLong("parseTime");
-  }
-
-  /**
-   * Time spent (in milliseconds) mapping this statement with database object's metadata (bind)
-   * 
-   * @return
-   */
-  public long getBindTime(){
-    return getLong("bindTime");
-  }
-
-  /**
-   * Time spent (in milliseconds) determining the best execution path for this statement
-   * (optimize)
-   * 
-   * @return
-   */
-  public long getOptimizeTime(){
-    return getLong("optimizeTime");
-  }
-
-  /**
-   * Time spent (in milliseconds) compiling details about routing information of query strings to
-   * data node(s) (processQueryInfo)
-   * 
-   * @return
-   */
-  public long getRoutingInfoTime(){
-    return getLong("routingInfoTime");
-  }
-
-  /**
-   * Time spent (in milliseconds) to generate query execution plan definition (activation class)
-   * 
-   * @return
-   */
-  public long getGenerateTime(){
-    return getLong("generateTime");
-  }
-
-  /**
-   * Total compilation time (in milliseconds) of the statement on this node (prepMinion)
-   * 
-   * @return
-   */
-  public long getTotalCompilationTime(){
-    return getLong("totalCompilationTime");
-  }
-
-  /**
-   * Time spent (in nanoseconds) in creation of all the layers of query processing (ac.execute)
-   * 
-   * @return
-   */
-  public long getExecutionTime(){
-    return getLong("executionTime");
-  }
-
-  /**
-   * Time to apply (in nanoseconds) the projection and additional filters. (projectrestrict)
-   * 
-   * @return
-   */
-  public long getProjectionTime(){
-    return getLong("projectionTime");
-  }
-
-  /**
-   * Total execution time (in nanoseconds) taken to process the statement on this node
-   * (execute/open/next/close)
-   * 
-   * @return
-   */
-  public long getTotalExecutionTime(){
-    return getLong("totalExecutionTime");
-  }
-
-  /**
-   * Time taken (in nanoseconds) to modify rows by DML operation of insert/delete/update
-   * 
-   * @return
-   */
-  public long getRowsModificationTime(){
-    return getLong("rowsModificationTime");
-  }
-
-  /**
-   * Number of rows returned from remote nodes (ResultHolder/Get convertibles)
-   * 
-   * @return
-   */
-  public long getQNNumRowsSeen(){
-    return getLong("qnNumRowsSeen");
-  }
-
-  /**
-   * TCP send time (in nanoseconds) of all the messages including serialization time and queue
-   * wait time
-   * 
-   * @return
-   */
-  public long getQNMsgSendTime(){
-    return getLong("qnMsgSendTime");
-  }
-
-  /**
-   * Serialization time (in nanoseconds) for all the messages while sending to remote node(s)
-   * 
-   * @return
-   */
-  public long getQNMsgSerTime(){
-    return getLong("qnMsgSerTime");
-  }
-  
-  /**
-   * 
-   * 
-   * @return
-   */
-  public long getQNRespDeSerTime(){
-    return getLong("qnRespDeSerTime");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatementMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatementMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatementMBean.java
deleted file mode 100644
index b58b53b..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/AggregateStatementMBean.java
+++ /dev/null
@@ -1,168 +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 com.vmware.geode.tools.pulse.tests;
-
-public interface AggregateStatementMBean {
-  String OBJECT_NAME = "GemFireXD:service=Statement,type=Aggregate";
-
-  /**
-   * Query definition
-   *
-   * @return
-   */
-  String getQueryDefinition();
-
-  /**
-   * Number of times this statement is compiled (including re compilations)
-   *
-   * @return
-   */
-  long getNumTimesCompiled();
-
-  /**
-   * Number of times this statement is executed
-   *
-   * @return
-   */
-  long getNumExecution();
-
-  /**
-   * Statements that are actively being processed during the statistics snapshot
-   *
-   * @return
-   */
-  long getNumExecutionsInProgress();
-
-  /**
-   * Number of times global index lookup message exchanges occurred
-   *
-   * @return
-   */
-  long getNumTimesGlobalIndexLookup();
-
-  /**
-   * Number of rows modified by DML operation of insert/delete/update
-   *
-   * @return
-   */
-  long getNumRowsModified();
-
-  /**
-   * Time spent(in milliseconds) in parsing the query string
-   *
-   * @return
-   */
-  long getParseTime();
-
-  /**
-   * Time spent (in milliseconds) mapping this statement with database object's metadata (bind)
-   *
-   * @return
-   */
-  long getBindTime();
-
-  /**
-   * Time spent (in milliseconds) determining the best execution path for this statement
-   * (optimize)
-   *
-   * @return
-   */
-  long getOptimizeTime();
-
-  /**
-   * Time spent (in milliseconds) compiling details about routing information of query strings to
-   * data node(s) (processQueryInfo)
-   *
-   * @return
-   */
-  long getRoutingInfoTime();
-
-  /**
-   * Time spent (in milliseconds) to generate query execution plan definition (activation class)
-   *
-   * @return
-   */
-  long getGenerateTime();
-
-  /**
-   * Total compilation time (in milliseconds) of the statement on this node (prepMinion)
-   *
-   * @return
-   */
-  long getTotalCompilationTime();
-
-  /**
-   * Time spent (in nanoseconds) in creation of all the layers of query processing (ac.execute)
-   *
-   * @return
-   */
-  long getExecutionTime();
-
-  /**
-   * Time to apply (in nanoseconds) the projection and additional filters. (projectrestrict)
-   *
-   * @return
-   */
-  long getProjectionTime();
-
-  /**
-   * Total execution time (in nanoseconds) taken to process the statement on this node
-   * (execute/open/next/close)
-   *
-   * @return
-   */
-  long getTotalExecutionTime();
-
-  /**
-   * Time taken (in nanoseconds) to modify rows by DML operation of insert/delete/update
-   *
-   * @return
-   */
-  long getRowsModificationTime();
-
-  /**
-   * Number of rows returned from remote nodes (ResultHolder/Get convertibles)
-   *
-   * @return
-   */
-  long getQNNumRowsSeen();
-
-  /**
-   * TCP send time (in nanoseconds) of all the messages including serialization time and queue
-   * wait time
-   *
-   * @return
-   */
-  long getQNMsgSendTime();
-
-  /**
-   * Serialization time (in nanoseconds) for all the messages while sending to remote node(s)
-   *
-   * @return
-   */
-  long getQNMsgSerTime();
-
-  /**
-   *
-   *
-   * @return
-   */
-  long getQNRespDeSerTime();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/DataBrowserResultLoader.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/DataBrowserResultLoader.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/DataBrowserResultLoader.java
deleted file mode 100644
index 09fbda3..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/DataBrowserResultLoader.java
+++ /dev/null
@@ -1,84 +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 com.vmware.geode.tools.pulse.tests;
-
-import java.io.BufferedReader;
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.net.URL;
-
-public class DataBrowserResultLoader {
-  private static DataBrowserResultLoader dbResultLoader = new DataBrowserResultLoader();
-
-  public static DataBrowserResultLoader getInstance() {
-    return dbResultLoader;
-  }
-
-  public String load(String queryString) throws IOException {
-
-    URL url = null;
-    InputStream inputStream = null;
-    BufferedReader streamReader = null;
-    String inputStr = null;
-    StringBuilder sampleQueryResultResponseStrBuilder = null;
-
-    try {
-      ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-
-      if (queryString.equals(PulseAbstractTest.QUERY_TYPE_ONE)) {
-        url = classLoader.getResource("testQueryResultClusterSmall.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_TWO)) {
-        url = classLoader.getResource("testQueryResultSmall.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_THREE)) {
-        url = classLoader.getResource("testQueryResult.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_FOUR)) {
-        url = classLoader.getResource("testQueryResultWithStructSmall.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_FIVE)) {
-        url = classLoader.getResource("testQueryResultClusterWithStruct.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_SIX)) {
-        url = classLoader.getResource("testQueryResultHashMapSmall.txt");
-      } else if (queryString.equals(PulseAbstractTest.QUERY_TYPE_SEVENE)) {
-        url = classLoader.getResource("testQueryResult1000.txt");
-      } else {
-        url = classLoader.getResource("testQueryResult.txt");
-      }
-
-      File sampleQueryResultFile = new File(url.getPath());
-      inputStream = new FileInputStream(sampleQueryResultFile);
-      streamReader = new BufferedReader(new InputStreamReader(inputStream,
-          "UTF-8"));
-      sampleQueryResultResponseStrBuilder = new StringBuilder();
-
-      while ((inputStr = streamReader.readLine()) != null) {
-        sampleQueryResultResponseStrBuilder.append(inputStr);
-      }
-
-      // close stream reader
-      streamReader.close();
-
-    } catch (IOException ex) {
-      ex.printStackTrace();
-    }
-
-    return sampleQueryResultResponseStrBuilder.toString();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTable.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTable.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTable.java
deleted file mode 100644
index 957d074..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTable.java
+++ /dev/null
@@ -1,46 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.NotificationBroadcasterSupport;
-
-public class GemFireXDAggregateTable extends NotificationBroadcasterSupport
-    implements GemFireXDAggregateTableMBean {
-  private String name = null;
-
-  public GemFireXDAggregateTable(String name) {
-    this.name = name;
-  }
-
-  private String getKey(String propName) {
-    return "table." + name + "." + propName;
-  }
-
-  @Override
-  public long getEntrySize() {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(
-        getKey("EntrySize")));
-  }
-
-  @Override
-  public int getNumberOfRows() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("NumberOfRows")));
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTableMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTableMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTableMBean.java
deleted file mode 100644
index db0f45d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDAggregateTableMBean.java
+++ /dev/null
@@ -1,28 +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 com.vmware.geode.tools.pulse.tests;
-
-public interface GemFireXDAggregateTableMBean {
-  public static final String OBJECT_NAME = "GemFireXD:service=Table,type=Aggregate,table=";
-  
-  public long getEntrySize();
-
-  public int getNumberOfRows();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDCluster.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDCluster.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDCluster.java
deleted file mode 100644
index a2b1edc..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDCluster.java
+++ /dev/null
@@ -1,95 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.NotificationBroadcasterSupport;
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.CompositeDataSupport;
-import javax.management.openmbean.CompositeType;
-import javax.management.openmbean.OpenDataException;
-import javax.management.openmbean.OpenType;
-import javax.management.openmbean.SimpleType;
-
-public class GemFireXDCluster extends NotificationBroadcasterSupport implements
-    GemFireXDClusterMBean {
-  private String name = null;
-
-  private static String[] itemNames = { "connectionsAttempted",
-      "connectionsActive", "connectionsClosed", "connectionsFailed" };;
-  private static String[] itemDescriptions = { "connectionsAttempted",
-      "connectionsActive", "connectionsClosed", "connectionsFailed" };
-  private static OpenType[] itemTypes = { SimpleType.LONG, SimpleType.LONG,
-      SimpleType.LONG, SimpleType.LONG };
-  private static CompositeType networkServerClientConnectionStats = null;
-
-  static {
-    try {
-      networkServerClientConnectionStats = new CompositeType(
-          "NetworkServerClientConnectionStats",
-          "Network Server Client Connection Stats Information", itemNames,
-          itemDescriptions, itemTypes);
-
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-    }
-  }
-
-  public GemFireXDCluster(String name) {
-    this.name = name;
-  }
-
-  private String getKey(String propName) {
-    return "gemfirexd." + name + "." + propName;
-  }
-
-  @Override
-  public int getProcedureCallsCompleted() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("ProcedureCallsCompleted")));
-  }
-
-  @Override
-  public int getProcedureCallsInProgress() {
-    return Integer.parseInt(JMXProperties.getInstance().getProperty(
-        getKey("ProcedureCallsInProgress")));
-  }
-
-  @Override
-  public CompositeData getNetworkServerClientConnectionStats() {
-    String value = JMXProperties.getInstance().getProperty(
-        getKey("NetworkServerClientConnectionStats"), "");
-    String[] values = value.split(",");
-    Long[] itemValues = new Long[values.length];
-    for (int i = 0; i < values.length; i++) {
-      itemValues[i] = Long.parseLong(values[i]);
-    }
-
-    CompositeData nscCompData;
-    try {
-      nscCompData = new CompositeDataSupport(
-          networkServerClientConnectionStats, itemNames, itemValues);
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-      nscCompData = null;
-    }
-    return nscCompData;
-
-  }
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDClusterMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDClusterMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDClusterMBean.java
deleted file mode 100644
index 5a42d10..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDClusterMBean.java
+++ /dev/null
@@ -1,32 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.openmbean.CompositeData;
-
-public interface GemFireXDClusterMBean {
-  public static final String OBJECT_NAME = "GemFireXD:service=Cluster";
-
-  public int getProcedureCallsCompleted();
-
-  public int getProcedureCallsInProgress();
-
-  public CompositeData getNetworkServerClientConnectionStats();
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMember.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMember.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMember.java
deleted file mode 100644
index 16da77d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMember.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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.CompositeDataSupport;
-import javax.management.openmbean.CompositeType;
-import javax.management.openmbean.OpenDataException;
-import javax.management.openmbean.OpenType;
-import javax.management.openmbean.SimpleType;
-
-public class GemFireXDMember extends JMXBaseBean implements
-    GemFireXDMemberMBean {
-  private String name = null;
-
-  private static String[] itemNames = { "connectionsAttempted",
-      "connectionsActive", "connectionsClosed", "connectionsFailed" };;
-  private static String[] itemDescriptions = { "connectionsAttempted",
-      "connectionsActive", "connectionsClosed", "connectionsFailed" };
-  private static OpenType[] itemTypes = { SimpleType.LONG, SimpleType.LONG,
-      SimpleType.LONG, SimpleType.LONG };
-  private static CompositeType networkServerClientConnectionStats = null;
-
-  static {
-    try {
-      networkServerClientConnectionStats = new CompositeType(
-          "NetworkServerClientConnectionStats",
-          "Network Server Client Connection Stats Information", itemNames,
-          itemDescriptions, itemTypes);
-
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-    }
-  }
-
-  public GemFireXDMember(String name) {
-    this.name = name;
-  }
-
-  @Override
-  protected String getKey(String propName) {
-    return "gemfirexdmember." + name + "." + propName;
-  }
-
-  @Override
-  public boolean getDataStore() {
-    return getBoolean("DataStore");
-  }
-
-  @Override
-  public CompositeData getNetworkServerClientConnectionStats() {
-    Long[] itemValues = getLongArray("NetworkServerClientConnectionStats");
-    CompositeData nscCompData;
-    try {
-      nscCompData = new CompositeDataSupport(
-          networkServerClientConnectionStats, itemNames, itemValues);
-    } catch (OpenDataException e) {
-      e.printStackTrace();
-      nscCompData = null;
-    }
-    return nscCompData;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMemberMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMemberMBean.java
deleted file mode 100644
index ceda56d..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/GemFireXDMemberMBean.java
+++ /dev/null
@@ -1,31 +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 com.vmware.geode.tools.pulse.tests;
-
-import javax.management.openmbean.CompositeData;
-
-public interface GemFireXDMemberMBean {
-
-  public static final String OBJECT_NAME = "GemFireXD:group=DEFAULT,type=Member";
-
-  public boolean getDataStore();
-
-  public CompositeData getNetworkServerClientConnectionStats();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXBaseBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXBaseBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXBaseBean.java
deleted file mode 100644
index 2d1ffad..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXBaseBean.java
+++ /dev/null
@@ -1,67 +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 com.vmware.geode.tools.pulse.tests;
-
-public abstract class JMXBaseBean {
-
-  protected abstract String getKey(String propName);
-
-  protected String getString(String key) {
-    return JMXProperties.getInstance().getProperty(getKey(key));
-  }
-
-  protected String[] getStringArray(String key) {
-    return JMXProperties.getInstance().getProperty(getKey(key), "").split(" ");
-  }
-
-  protected boolean getBoolean(String key) {
-    return Boolean.parseBoolean(JMXProperties.getInstance().getProperty(
-        getKey(key)));
-  }
-
-  protected int getInt(String key) {
-    return Integer.parseInt(JMXProperties.getInstance()
-        .getProperty(getKey(key)));
-  }
-
-  protected long getLong(String key) {
-    return Long.parseLong(JMXProperties.getInstance().getProperty(getKey(key)));
-  }
-
-  protected Long[] getLongArray(String key) {
-    String value = JMXProperties.getInstance().getProperty(getKey(key), "");
-    String[] values = value.split(",");
-    Long[] longValues = new Long[values.length];
-    for (int i = 0; i < values.length; i++) {
-      longValues[i] = Long.parseLong(values[i]);
-    }
-    return longValues;
-  }
-
-  protected double getDouble(String key) {
-    return Double.parseDouble(JMXProperties.getInstance().getProperty(
-        getKey(key)));
-  }
-
-  protected float getFloat(String key) {
-    return Float.parseFloat(JMXProperties.getInstance()
-        .getProperty(getKey(key)));
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXProperties.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXProperties.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXProperties.java
deleted file mode 100644
index 1562594..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/JMXProperties.java
+++ /dev/null
@@ -1,47 +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 com.vmware.geode.tools.pulse.tests;
-
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.IOException;
-import java.util.Properties;
-
-public class JMXProperties extends Properties {
-  private static final long serialVersionUID = -6210901350494570026L;
-
-  private static JMXProperties props = new JMXProperties();
-
-  public static JMXProperties getInstance() {
-    return props;
-  }
-
-  public void load(String propFile) throws IOException {
-    if (propFile != null) {
-      FileInputStream fin;
-      fin = new FileInputStream(new File(propFile));
-      if (fin != null) {
-        clear();
-        load(fin);
-      }
-
-      fin.close();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Member.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Member.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Member.java
deleted file mode 100644
index 1192297..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/Member.java
+++ /dev/null
@@ -1,193 +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 com.vmware.geode.tools.pulse.tests;
-
-public class Member extends JMXBaseBean implements MemberMBean {
-  private String name = null;
-
-  public Member(String name) {
-    this.name = name;
-  }
-
-  protected String getKey(String propName) {
-    return "member." + name + "." + propName;
-  }
-
-  @Override
-  public boolean getManager() {
-    return getBoolean("manager");
-  }
-
-  @Override
-  public int getTotalRegionCount() {
-// This count is built dynamically in Pulse backend and region count is maintained in Cluster.Member data structure
-//    return getInt("totalRegionCount");
-    return 0;
-  }
-
-  @Override
-  public boolean getLocator() {
-    return getBoolean("locator");
-  }
-
-  @Override
-  public long getTotalDiskUsage() {
-    return getLong("totalDiskUsage");
-  }
-
-  @Override
-  public boolean getServer() {
-    return getBoolean("sever");
-  }
-
-  @Override
-  public String[] getGroups() {
-    return getStringArray("Groups");
-  }
-
-  @Override
-  /*public String[] getRedundancyZone() {
-    return getStringArray("RedundancyZone");
-  }*/
-  public String getRedundancyZone() {
-    return getString("RedundancyZone");
-  }
-
-  @Override
-  public long getTotalFileDescriptorOpen() {
-    return getLong("totalFileDescriptorOpen");
-  }
-
-  @Override
-  public double getLoadAverage() {
-    return getDouble("loadAverage");
-  }
-
-  @Override
-  public double getDiskWritesRate() {
-    return getDouble("diskWritesRate");
-  }
-
-  @Override
-  public long getJVMPauses() {
-    return getLong("JVMPauses");
-  }
-
-  @Override
-  public long getCurrentHeapSize() {
-//    return getLong("currentHeapSize");
-    return getLong("UsedMemory");
-  }
-
-  @Override
-  public long getMaximumHeapSize() {
-//    return getLong("maximumHeapSize");
-    return getLong("MaxMemory");
-  }
-
-  @Override
-  public long getUsedMemory() {
-    return getLong("UsedMemory");
-  }
-
-  @Override
-  public long getMaxMemory() {
-    return getLong("MaxMemory");
-  }
-
-  @Override
-  public int getNumThreads() {
-    return getInt("numThreads");
-  }
-
-  @Override
-  public long getMemberUpTime() {
-    return getLong("memberUpTime");
-  }
-
-  @Override
-  public String getHost() {
-    return getString("host");
-  }
-
-  @Override
-  public long getTotalBytesOnDisk() {
-    return getLong("totalBytesOnDisk");
-  }
-
-  @Override
-  public double getCpuUsage() {
-    return getDouble("cpuUsage");
-  }
-
-  @Override
-  public String getMember() {
-    return getString("member");
-  }
-
-  @Override
-  public String getId() {
-    return getString("id");
-  }
-
-  @Override
-  public double getAverageReads() {
-    return getDouble("averageReads");
-  }
-
-  @Override
-  public double getAverageWrites() {
-    return getDouble("averageWrites");
-  }
-
-  @Override
-  public int getPort() {
-    return getInt("port");
-  }
-
-  @Override
-  public long getFoo() {
-    return getLong("foo");
-  }
-
-  @Override
-  public long getOffHeapFreeSize() {
-    return getLong("OffHeapFreeSize");
-  }
-
-  @Override
-  public long getOffHeapUsedSize() {
-    return getLong("OffHeapUsedSize");
-  }
-
-  @Override
-  public long getOffHeapFreeMemory() {
-    return getLong("OffHeapFreeMemory");
-  }
-
-  @Override
-  public long getOffHeapUsedMemory() {
-    return getLong("OffHeapUsedMemory");
-  }
-
-  @Override
-  public String getVersion() {
-    return getString("Version");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/MemberMBean.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/MemberMBean.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/MemberMBean.java
deleted file mode 100644
index 6051270..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/MemberMBean.java
+++ /dev/null
@@ -1,86 +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 com.vmware.geode.tools.pulse.tests;
-
-public interface MemberMBean {
-  String OBJECT_NAME = "GemFire:type=Member";
-
-  boolean getManager();
-
-  int getTotalRegionCount();
-
-  boolean getLocator();
-
-  long getTotalDiskUsage();
-
-  boolean getServer();
-
-  String[] getGroups();
-
-  //public String[] getRedundancyZone();
-  String getRedundancyZone();
-
-  long getTotalFileDescriptorOpen();
-
-  double getLoadAverage();
-
-  double getDiskWritesRate();
-
-  long getJVMPauses();
-
-  long getCurrentHeapSize();
-
-  long getMaximumHeapSize();
-
-  long getUsedMemory();
-
-  long getMaxMemory();
-
-  int getNumThreads();
-
-  long getMemberUpTime();
-
-  String getHost();
-
-  long getTotalBytesOnDisk();
-
-  double getCpuUsage();
-
-  String getMember();
-
-  String getId();
-
-  double getAverageReads();
-
-  double getAverageWrites();
-
-  int getPort();
-
-  long getFoo();
-
-  long getOffHeapFreeSize();
-
-  long getOffHeapUsedSize();
-
-  long getOffHeapFreeMemory();
-
-  long getOffHeapUsedMemory();
-
-  String getVersion();
-}


[09/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapObjectKey.java
index dfffd73..b730528 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapObjectKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey1.java
index 3125dc7..21535b6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey1.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey2.java
index 34597bc..c9c25ed 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapStringKey2.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapUUIDKey.java
index 81af4b7..3ada237 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapUUIDKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeap.java
index fcc6c1b..da853e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapIntKey.java
index 11246db..6478199 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapIntKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapLongKey.java
index c2ab62e..23559e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapLongKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapObjectKey.java
index 2de736b..106bcf4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapObjectKey.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey1.java
index cbaf957..2b7bd5c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey1.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey2.java
index 8fe0113..ef65a04 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapStringKey2.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapUUIDKey.java
index 95cf625..6723118 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryOffHeapUUIDKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntry.java
index 0583568..80598ce 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeap.java
index 51d4ab1..cfa2325 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapIntKey.java
index e5bbaf3..6454f08 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapIntKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapLongKey.java
index eae764f..5c7dd26 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapLongKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapObjectKey.java
index 8241c92..533e18a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapObjectKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey1.java
index d63f5c4..37aaa7e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey1.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey2.java
index ab9f947..2587356 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapStringKey2.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapUUIDKey.java
index 5862ad5..18f11d3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryHeapUUIDKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeap.java
index e4081ef..8a5164e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapIntKey.java
index 096d89d..98e939c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapIntKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapLongKey.java
index e6d0238..5285b8d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapLongKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapObjectKey.java
index 18e767d..77040c1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapObjectKey.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey1.java
index 35eb3ac..9d8e119 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey1.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey2.java
index f7bbc3d..194efbd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapStringKey2.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapUUIDKey.java
index 7e1fcc7..1deafea 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsLRURegionEntryOffHeapUUIDKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntry.java
index 25547c3..bd1e1df 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeap.java
index fbde0bf..2563e18 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapIntKey.java
index 2ef67ae..c06ef02 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapIntKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapLongKey.java
index c2dfde0..4dc3a76 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapLongKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapObjectKey.java
index 8d4df4b..16a1fe2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapObjectKey.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey1.java
index 5c2880b..010c4d9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey1.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey2.java
index 11328bb..2f6cbfc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapStringKey2.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapUUIDKey.java
index 0dc152b..41c815b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryHeapUUIDKey.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeap.java
index 1922889..82d2e76 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapIntKey.java
index 154985d..5df9b36 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapIntKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapLongKey.java
index 510686a..8f21201 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapLongKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapObjectKey.java
index de82cf1..fa22099 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapObjectKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey1.java
index 6061a5f..2c296b5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey1.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey2.java
index de2556f..d61de5d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapStringKey2.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapUUIDKey.java
index 72e264c..c36eb31 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsRegionEntryOffHeapUUIDKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntry.java
index c70774a..95502a7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeap.java
index b987de8..27821ae 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapIntKey.java
index 5a5c1e2..27de526 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapIntKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapLongKey.java
index aa03151..93ce17b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapLongKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapObjectKey.java
index a680ec3..a212340 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapObjectKey.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey1.java
index d685c1b..07cc298 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey1.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey2.java
index ad9c23f..3f41996 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapStringKey2.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapUUIDKey.java
index 3830e3f..3875308 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryHeapUUIDKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeap.java
index d735865..865cea2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMThinDiskLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 


[75/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONObject.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONObject.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONObject.java
deleted file mode 100644
index 3fd3c38..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONObject.java
+++ /dev/null
@@ -1,1585 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.io.IOException;
-import java.io.StringWriter;
-import java.io.Writer;
-import java.lang.reflect.Field;
-import java.lang.reflect.Method;
-import java.lang.reflect.Modifier;
-import java.util.Collection;
-import java.util.Enumeration;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Locale;
-import java.util.Map;
-import java.util.ResourceBundle;
-
-/**
- * A JSONObject is an unordered collection of name/value pairs. Its external
- * form is a string wrapped in curly braces with colons between the names and
- * values, and commas between the values and names. The internal form is an
- * object having <code>get</code> and <code>opt</code> methods for accessing the
- * values by name, and <code>put</code> methods for adding or replacing values
- * by name. The values can be any of these types: <code>Boolean</code>,
- * <code>JSONArray</code>, <code>JSONObject</code>, <code>Number</code>,
- * <code>String</code>, or the <code>JSONObject.NULL</code> object. A JSONObject
- * constructor can be used to convert an external form JSON text into an
- * internal form whose values can be retrieved with the <code>get</code> and
- * <code>opt</code> methods, or to convert values into a JSON text using the
- * <code>put</code> and <code>toString</code> methods. A <code>get</code> method
- * returns a value if one can be found, and throws an exception if one cannot be
- * found. An <code>opt</code> method returns a default value instead of throwing
- * an exception, and so is useful for obtaining optional values.
- * <p>
- * The generic <code>get()</code> and <code>opt()</code> methods return an
- * object, which you can cast or query for type. There are also typed
- * <code>get</code> and <code>opt</code> methods that do type checking and type
- * coercion for you. The opt methods differ from the get methods in that they do
- * not throw. Instead, they return a specified value, such as null.
- * <p>
- * The <code>put</code> methods add or replace values in an object. For example,
- *
- * <pre>
- * myString = new JSONObject().put(&quot;JSON&quot;, &quot;Hello, World!&quot;).toString();
- * </pre>
- *
- * produces the string <code>{"JSON": "Hello, World"}</code>.
- * <p>
- * The texts produced by the <code>toString</code> methods strictly conform to
- * the JSON syntax rules. The constructors are more forgiving in the texts they
- * will accept:
- * <ul>
- * <li>An extra <code>,</code>&nbsp;<small>(comma)</small> may appear just
- * before the closing brace.</li>
- * <li>Strings may be quoted with <code>'</code>&nbsp;<small>(single
- * quote)</small>.</li>
- * <li>Strings do not need to be quoted at all if they do not begin with a quote
- * or single quote, and if they do not contain leading or trailing spaces, and
- * if they do not contain any of these characters:
- * <code>{ } [ ] / \ : , = ; #</code> and if they do not look like numbers and
- * if they are not the reserved words <code>true</code>, <code>false</code>, or
- * <code>null</code>.</li>
- * <li>Keys can be followed by <code>=</code> or <code>=></code> as well as by
- * <code>:</code>.</li>
- * <li>Values can be followed by <code>;</code> <small>(semicolon)</small> as
- * well as by <code>,</code> <small>(comma)</small>.</li>
- * </ul>
- *
- * @author JSON.org
- * @version 2012-07-02
- */
-public class JSONObject {
-
-    /**
-     * JSONObject.NULL is equivalent to the value that JavaScript calls null,
-     * whilst Java's null is equivalent to the value that JavaScript calls
-     * undefined.
-     */
-     private static final class Null {
-
-        /**
-         * There is only intended to be a single instance of the NULL object,
-         * so the clone method returns itself.
-         * @return     NULL.
-         */
-        protected final Object clone() {
-            return this;
-        }
-
-        /**
-         * A Null object is equal to the null value and to itself.
-         * @param object    An object to test for nullness.
-         * @return true if the object parameter is the JSONObject.NULL object
-         *  or null.
-         */
-        public boolean equals(Object object) {
-            return object == null || object == this;
-        }
-
-        /**
-         * Get the "null" string value.
-         * @return The string "null".
-         */
-        public String toString() {
-            return "null";
-        }
-    }
-
-
-    /**
-     * The map where the JSONObject's properties are kept.
-     */
-    private final Map map;
-
-
-    /**
-     * It is sometimes more convenient and less ambiguous to have a
-     * <code>NULL</code> object than to use Java's <code>null</code> value.
-     * <code>JSONObject.NULL.equals(null)</code> returns <code>true</code>.
-     * <code>JSONObject.NULL.toString()</code> returns <code>"null"</code>.
-     */
-    public static final Object NULL = new Null();
-
-
-    /**
-     * Construct an empty JSONObject.
-     */
-    public JSONObject() {
-        this.map = new HashMap();
-    }
-
-
-    /**
-     * Construct a JSONObject from a subset of another JSONObject.
-     * An array of strings is used to identify the keys that should be copied.
-     * Missing keys are ignored.
-     * @param jo A JSONObject.
-     * @param names An array of strings.
-     */
-    public JSONObject(JSONObject jo, String[] names) {
-        this();
-        for (int i = 0; i < names.length; i += 1) {
-            try {
-                this.putOnce(names[i], jo.opt(names[i]));
-            } catch (Exception ignore) {
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONObject from a JSONTokener.
-     * @param x A JSONTokener object containing the source string.
-     * @throws JSONException If there is a syntax error in the source string
-     *  or a duplicated key.
-     */
-    public JSONObject(JSONTokener x) throws JSONException {
-        this();
-        char c;
-        String key;
-
-        if (x.nextClean() != '{') {
-            throw x.syntaxError("A JSONObject text must begin with '{'");
-        }
-        for (;;) {
-            c = x.nextClean();
-            switch (c) {
-            case 0:
-                throw x.syntaxError("A JSONObject text must end with '}'");
-            case '}':
-                return;
-            default:
-                x.back();
-                key = x.nextValue().toString();
-            }
-
-// The key is followed by ':'. We will also tolerate '=' or '=>'.
-
-            c = x.nextClean();
-            if (c == '=') {
-                if (x.next() != '>') {
-                    x.back();
-                }
-            } else if (c != ':') {
-                throw x.syntaxError("Expected a ':' after a key");
-            }
-            this.putOnce(key, x.nextValue());
-
-// Pairs are separated by ','. We will also tolerate ';'.
-
-            switch (x.nextClean()) {
-            case ';':
-            case ',':
-                if (x.nextClean() == '}') {
-                    return;
-                }
-                x.back();
-                break;
-            case '}':
-                return;
-            default:
-                throw x.syntaxError("Expected a ',' or '}'");
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONObject from a Map.
-     *
-     * @param map A map object that can be used to initialize the contents of
-     *  the JSONObject.
-     */
-    public JSONObject(Map map) {
-        this.map = new HashMap();
-        if (map != null) {
-            Iterator i = map.entrySet().iterator();
-            while (i.hasNext()) {
-                Map.Entry e = (Map.Entry)i.next();
-                Object value = e.getValue();
-                if (value != null) {
-                    this.map.put(e.getKey(), wrap(value));
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONObject from an Object using bean getters.
-     * It reflects on all of the public methods of the object.
-     * For each of the methods with no parameters and a name starting
-     * with <code>"get"</code> or <code>"is"</code> followed by an uppercase letter,
-     * the method is invoked, and a key and the value returned from the getter method
-     * are put into the new JSONObject.
-     *
-     * The key is formed by removing the <code>"get"</code> or <code>"is"</code> prefix.
-     * If the second remaining character is not upper case, then the first
-     * character is converted to lower case.
-     *
-     * For example, if an object has a method named <code>"getName"</code>, and
-     * if the result of calling <code>object.getName()</code> is <code>"Larry Fine"</code>,
-     * then the JSONObject will contain <code>"name": "Larry Fine"</code>.
-     *
-     * @param bean An object that has getter methods that should be used
-     * to make a JSONObject.
-     */
-    public JSONObject(Object bean) {
-        this();
-        this.populateMap(bean);
-    }
-
-
-    /**
-     * Construct a JSONObject from an Object, using reflection to find the
-     * public members. The resulting JSONObject's keys will be the strings
-     * from the names array, and the values will be the field values associated
-     * with those keys in the object. If a key is not found or not visible,
-     * then it will not be copied into the new JSONObject.
-     * @param object An object that has fields that should be used to make a
-     * JSONObject.
-     * @param names An array of strings, the names of the fields to be obtained
-     * from the object.
-     */
-    public JSONObject(Object object, String names[]) {
-        this();
-        Class c = object.getClass();
-        for (int i = 0; i < names.length; i += 1) {
-            String name = names[i];
-            try {
-                this.putOpt(name, c.getField(name).get(object));
-            } catch (Exception ignore) {
-            }
-        }
-    }
-
-
-    /**
-     * Construct a JSONObject from a source JSON text string.
-     * This is the most commonly used JSONObject constructor.
-     * @param source    A string beginning
-     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
-     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
-     * @exception JSONException If there is a syntax error in the source
-     *  string or a duplicated key.
-     */
-    public JSONObject(String source) throws JSONException {
-        this(new JSONTokener(source));
-    }
-
-
-    /**
-     * Construct a JSONObject from a ResourceBundle.
-     * @param baseName The ResourceBundle base name.
-     * @param locale The Locale to load the ResourceBundle for.
-     * @throws JSONException If any JSONExceptions are detected.
-     */
-    public JSONObject(String baseName, Locale locale) throws JSONException {
-        this();
-        ResourceBundle bundle = ResourceBundle.getBundle(baseName, locale,
-                Thread.currentThread().getContextClassLoader());
-
-// Iterate through the keys in the bundle.
-
-        Enumeration keys = bundle.getKeys();
-        while (keys.hasMoreElements()) {
-            Object key = keys.nextElement();
-            if (key instanceof String) {
-
-// Go through the path, ensuring that there is a nested JSONObject for each
-// segment except the last. Add the value using the last segment's name into
-// the deepest nested JSONObject.
-
-                String[] path = ((String)key).split("\\.");
-                int last = path.length - 1;
-                JSONObject target = this;
-                for (int i = 0; i < last; i += 1) {
-                    String segment = path[i];
-                    JSONObject nextTarget = target.optJSONObject(segment);
-                    if (nextTarget == null) {
-                        nextTarget = new JSONObject();
-                        target.put(segment, nextTarget);
-                    }
-                    target = nextTarget;
-                }
-                target.put(path[last], bundle.getString((String)key));
-            }
-        }
-    }
-
-
-    /**
-     * Accumulate values under a key. It is similar to the put method except
-     * that if there is already an object stored under the key then a
-     * JSONArray is stored under the key to hold all of the accumulated values.
-     * If there is already a JSONArray, then the new value is appended to it.
-     * In contrast, the put method replaces the previous value.
-     *
-     * If only one value is accumulated that is not a JSONArray, then the
-     * result will be the same as using put. But if multiple values are
-     * accumulated, then the result will be like append.
-     * @param key   A key string.
-     * @param value An object to be accumulated under the key.
-     * @return this.
-     * @throws JSONException If the value is an invalid number
-     *  or if the key is null.
-     */
-    public JSONObject accumulate(
-        String key,
-        Object value
-    ) throws JSONException {
-        testValidity(value);
-        Object object = this.opt(key);
-        if (object == null) {
-            this.put(key, value instanceof JSONArray
-                    ? new JSONArray().put(value)
-                    : value);
-        } else if (object instanceof JSONArray) {
-            ((JSONArray)object).put(value);
-        } else {
-            this.put(key, new JSONArray().put(object).put(value));
-        }
-        return this;
-    }
-
-
-    /**
-     * Append values to the array under a key. If the key does not exist in the
-     * JSONObject, then the key is put in the JSONObject with its value being a
-     * JSONArray containing the value parameter. If the key was already
-     * associated with a JSONArray, then the value parameter is appended to it.
-     * @param key   A key string.
-     * @param value An object to be accumulated under the key.
-     * @return this.
-     * @throws JSONException If the key is null or if the current value
-     *  associated with the key is not a JSONArray.
-     */
-    public JSONObject append(String key, Object value) throws JSONException {
-        testValidity(value);
-        Object object = this.opt(key);
-        if (object == null) {
-            this.put(key, new JSONArray().put(value));
-        } else if (object instanceof JSONArray) {
-            this.put(key, ((JSONArray)object).put(value));
-        } else {
-            throw new JSONException("JSONObject[" + key +
-                    "] is not a JSONArray.");
-        }
-        return this;
-    }
-
-
-    /**
-     * Produce a string from a double. The string "null" will be returned if
-     * the number is not finite.
-     * @param  d A double.
-     * @return A String.
-     */
-    public static String doubleToString(double d) {
-        if (Double.isInfinite(d) || Double.isNaN(d)) {
-            return "null";
-        }
-
-// Shave off trailing zeros and decimal point, if possible.
-
-        String string = Double.toString(d);
-        if (string.indexOf('.') > 0 && string.indexOf('e') < 0 &&
-                string.indexOf('E') < 0) {
-            while (string.endsWith("0")) {
-                string = string.substring(0, string.length() - 1);
-            }
-            if (string.endsWith(".")) {
-                string = string.substring(0, string.length() - 1);
-            }
-        }
-        return string;
-    }
-
-
-    /**
-     * Get the value object associated with a key.
-     *
-     * @param key   A key string.
-     * @return      The object associated with the key.
-     * @throws      JSONException if the key is not found.
-     */
-    public Object get(String key) throws JSONException {
-        if (key == null) {
-            throw new JSONException("Null key.");
-        }
-        Object object = this.opt(key);
-        if (object == null) {
-            throw new JSONException("JSONObject[" + quote(key) +
-                    "] not found.");
-        }
-        return object;
-    }
-
-
-    /**
-     * Get the boolean value associated with a key.
-     *
-     * @param key   A key string.
-     * @return      The truth.
-     * @throws      JSONException
-     *  if the value is not a Boolean or the String "true" or "false".
-     */
-    public boolean getBoolean(String key) throws JSONException {
-        Object object = this.get(key);
-        if (object.equals(Boolean.FALSE) ||
-                (object instanceof String &&
-                ((String)object).equalsIgnoreCase("false"))) {
-            return false;
-        } else if (object.equals(Boolean.TRUE) ||
-                (object instanceof String &&
-                ((String)object).equalsIgnoreCase("true"))) {
-            return true;
-        }
-        throw new JSONException("JSONObject[" + quote(key) +
-                "] is not a Boolean.");
-    }
-
-
-    /**
-     * Get the double value associated with a key.
-     * @param key   A key string.
-     * @return      The numeric value.
-     * @throws JSONException if the key is not found or
-     *  if the value is not a Number object and cannot be converted to a number.
-     */
-    public double getDouble(String key) throws JSONException {
-        Object object = this.get(key);
-        try {
-            return object instanceof Number
-                ? ((Number)object).doubleValue()
-                : Double.parseDouble((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONObject[" + quote(key) +
-                "] is not a number.");
-        }
-    }
-
-
-    /**
-     * Get the int value associated with a key.
-     *
-     * @param key   A key string.
-     * @return      The integer value.
-     * @throws   JSONException if the key is not found or if the value cannot
-     *  be converted to an integer.
-     */
-    public int getInt(String key) throws JSONException {
-        Object object = this.get(key);
-        try {
-            return object instanceof Number
-                ? ((Number)object).intValue()
-                : Integer.parseInt((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONObject[" + quote(key) +
-                "] is not an int.");
-        }
-    }
-
-
-    /**
-     * Get the JSONArray value associated with a key.
-     *
-     * @param key   A key string.
-     * @return      A JSONArray which is the value.
-     * @throws      JSONException if the key is not found or
-     *  if the value is not a JSONArray.
-     */
-    public JSONArray getJSONArray(String key) throws JSONException {
-        Object object = this.get(key);
-        if (object instanceof JSONArray) {
-            return (JSONArray)object;
-        }
-        throw new JSONException("JSONObject[" + quote(key) +
-                "] is not a JSONArray.");
-    }
-
-
-    /**
-     * Get the JSONObject value associated with a key.
-     *
-     * @param key   A key string.
-     * @return      A JSONObject which is the value.
-     * @throws      JSONException if the key is not found or
-     *  if the value is not a JSONObject.
-     */
-    public JSONObject getJSONObject(String key) throws JSONException {
-        Object object = this.get(key);
-        if (object instanceof JSONObject) {
-            return (JSONObject)object;
-        }
-        throw new JSONException("JSONObject[" + quote(key) +
-                "] is not a JSONObject.");
-    }
-
-
-    /**
-     * Get the long value associated with a key.
-     *
-     * @param key   A key string.
-     * @return      The long value.
-     * @throws   JSONException if the key is not found or if the value cannot
-     *  be converted to a long.
-     */
-    public long getLong(String key) throws JSONException {
-        Object object = this.get(key);
-        try {
-            return object instanceof Number
-                ? ((Number)object).longValue()
-                : Long.parseLong((String)object);
-        } catch (Exception e) {
-            throw new JSONException("JSONObject[" + quote(key) +
-                "] is not a long.");
-        }
-    }
-
-
-    /**
-     * Get an array of field names from a JSONObject.
-     *
-     * @return An array of field names, or null if there are no names.
-     */
-    public static String[] getNames(JSONObject jo) {
-        int length = jo.length();
-        if (length == 0) {
-            return null;
-        }
-        Iterator iterator = jo.keys();
-        String[] names = new String[length];
-        int i = 0;
-        while (iterator.hasNext()) {
-            names[i] = (String)iterator.next();
-            i += 1;
-        }
-        return names;
-    }
-
-
-    /**
-     * Get an array of field names from an Object.
-     *
-     * @return An array of field names, or null if there are no names.
-     */
-    public static String[] getNames(Object object) {
-        if (object == null) {
-            return null;
-        }
-        Class klass = object.getClass();
-        Field[] fields = klass.getFields();
-        int length = fields.length;
-        if (length == 0) {
-            return null;
-        }
-        String[] names = new String[length];
-        for (int i = 0; i < length; i += 1) {
-            names[i] = fields[i].getName();
-        }
-        return names;
-    }
-
-
-    /**
-     * Get the string associated with a key.
-     *
-     * @param key   A key string.
-     * @return      A string which is the value.
-     * @throws   JSONException if there is no string value for the key.
-     */
-    public String getString(String key) throws JSONException {
-        Object object = this.get(key);
-        if (object instanceof String) {
-            return (String)object;
-        }
-        throw new JSONException("JSONObject[" + quote(key) +
-            "] not a string.");
-    }
-
-
-    /**
-     * Determine if the JSONObject contains a specific key.
-     * @param key   A key string.
-     * @return      true if the key exists in the JSONObject.
-     */
-    public boolean has(String key) {
-        return this.map.containsKey(key);
-    }
-
-
-    /**
-     * Increment a property of a JSONObject. If there is no such property,
-     * create one with a value of 1. If there is such a property, and if
-     * it is an Integer, Long, Double, or Float, then add one to it.
-     * @param key  A key string.
-     * @return this.
-     * @throws JSONException If there is already a property with this name
-     * that is not an Integer, Long, Double, or Float.
-     */
-    public JSONObject increment(String key) throws JSONException {
-        Object value = this.opt(key);
-        if (value == null) {
-            this.put(key, 1);
-        } else if (value instanceof Integer) {
-            this.put(key, ((Integer)value).intValue() + 1);
-        } else if (value instanceof Long) {
-            this.put(key, ((Long)value).longValue() + 1);
-        } else if (value instanceof Double) {
-            this.put(key, ((Double)value).doubleValue() + 1);
-        } else if (value instanceof Float) {
-            this.put(key, ((Float)value).floatValue() + 1);
-        } else {
-            throw new JSONException("Unable to increment [" + quote(key) + "].");
-        }
-        return this;
-    }
-
-
-    /**
-     * Determine if the value associated with the key is null or if there is
-     *  no value.
-     * @param key   A key string.
-     * @return      true if there is no value associated with the key or if
-     *  the value is the JSONObject.NULL object.
-     */
-    public boolean isNull(String key) {
-        return JSONObject.NULL.equals(this.opt(key));
-    }
-
-
-    /**
-     * Get an enumeration of the keys of the JSONObject.
-     *
-     * @return An iterator of the keys.
-     */
-    public Iterator keys() {
-        return this.map.keySet().iterator();
-    }
-
-
-    /**
-     * Get the number of keys stored in the JSONObject.
-     *
-     * @return The number of keys in the JSONObject.
-     */
-    public int length() {
-        return this.map.size();
-    }
-
-
-    /**
-     * Produce a JSONArray containing the names of the elements of this
-     * JSONObject.
-     * @return A JSONArray containing the key strings, or null if the JSONObject
-     * is empty.
-     */
-    public JSONArray names() {
-        JSONArray ja = new JSONArray();
-        Iterator  keys = this.keys();
-        while (keys.hasNext()) {
-            ja.put(keys.next());
-        }
-        return ja.length() == 0 ? null : ja;
-    }
-
-    /**
-     * Produce a string from a Number.
-     * @param  number A Number
-     * @return A String.
-     * @throws JSONException If n is a non-finite number.
-     */
-    public static String numberToString(Number number)
-            throws JSONException {
-        if (number == null) {
-            throw new JSONException("Null pointer");
-        }
-        testValidity(number);
-
-// Shave off trailing zeros and decimal point, if possible.
-
-        String string = number.toString();
-        if (string.indexOf('.') > 0 && string.indexOf('e') < 0 &&
-                string.indexOf('E') < 0) {
-            while (string.endsWith("0")) {
-                string = string.substring(0, string.length() - 1);
-            }
-            if (string.endsWith(".")) {
-                string = string.substring(0, string.length() - 1);
-            }
-        }
-        return string;
-    }
-
-
-    /**
-     * Get an optional value associated with a key.
-     * @param key   A key string.
-     * @return      An object which is the value, or null if there is no value.
-     */
-    public Object opt(String key) {
-        return key == null ? null : this.map.get(key);
-    }
-
-
-    /**
-     * Get an optional boolean associated with a key.
-     * It returns false if there is no such key, or if the value is not
-     * Boolean.TRUE or the String "true".
-     *
-     * @param key   A key string.
-     * @return      The truth.
-     */
-    public boolean optBoolean(String key) {
-        return this.optBoolean(key, false);
-    }
-
-
-    /**
-     * Get an optional boolean associated with a key.
-     * It returns the defaultValue if there is no such key, or if it is not
-     * a Boolean or the String "true" or "false" (case insensitive).
-     *
-     * @param key              A key string.
-     * @param defaultValue     The default.
-     * @return      The truth.
-     */
-    public boolean optBoolean(String key, boolean defaultValue) {
-        try {
-            return this.getBoolean(key);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get an optional double associated with a key,
-     * or NaN if there is no such key or if its value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key   A string which is the key.
-     * @return      An object which is the value.
-     */
-    public double optDouble(String key) {
-        return this.optDouble(key, Double.NaN);
-    }
-
-
-    /**
-     * Get an optional double associated with a key, or the
-     * defaultValue if there is no such key or if its value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key   A key string.
-     * @param defaultValue     The default.
-     * @return      An object which is the value.
-     */
-    public double optDouble(String key, double defaultValue) {
-        try {
-            return this.getDouble(key);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get an optional int value associated with a key,
-     * or zero if there is no such key or if the value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key   A key string.
-     * @return      An object which is the value.
-     */
-    public int optInt(String key) {
-        return this.optInt(key, 0);
-    }
-
-
-    /**
-     * Get an optional int value associated with a key,
-     * or the default if there is no such key or if the value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key   A key string.
-     * @param defaultValue     The default.
-     * @return      An object which is the value.
-     */
-    public int optInt(String key, int defaultValue) {
-        try {
-            return this.getInt(key);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get an optional JSONArray associated with a key.
-     * It returns null if there is no such key, or if its value is not a
-     * JSONArray.
-     *
-     * @param key   A key string.
-     * @return      A JSONArray which is the value.
-     */
-    public JSONArray optJSONArray(String key) {
-        Object o = this.opt(key);
-        return o instanceof JSONArray ? (JSONArray)o : null;
-    }
-
-
-    /**
-     * Get an optional JSONObject associated with a key.
-     * It returns null if there is no such key, or if its value is not a
-     * JSONObject.
-     *
-     * @param key   A key string.
-     * @return      A JSONObject which is the value.
-     */
-    public JSONObject optJSONObject(String key) {
-        Object object = this.opt(key);
-        return object instanceof JSONObject ? (JSONObject)object : null;
-    }
-
-
-    /**
-     * Get an optional long value associated with a key,
-     * or zero if there is no such key or if the value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key   A key string.
-     * @return      An object which is the value.
-     */
-    public long optLong(String key) {
-        return this.optLong(key, 0);
-    }
-
-
-    /**
-     * Get an optional long value associated with a key,
-     * or the default if there is no such key or if the value is not a number.
-     * If the value is a string, an attempt will be made to evaluate it as
-     * a number.
-     *
-     * @param key          A key string.
-     * @param defaultValue The default.
-     * @return             An object which is the value.
-     */
-    public long optLong(String key, long defaultValue) {
-        try {
-            return this.getLong(key);
-        } catch (Exception e) {
-            return defaultValue;
-        }
-    }
-
-
-    /**
-     * Get an optional string associated with a key.
-     * It returns an empty string if there is no such key. If the value is not
-     * a string and is not null, then it is converted to a string.
-     *
-     * @param key   A key string.
-     * @return      A string which is the value.
-     */
-    public String optString(String key) {
-        return this.optString(key, "");
-    }
-
-
-    /**
-     * Get an optional string associated with a key.
-     * It returns the defaultValue if there is no such key.
-     *
-     * @param key   A key string.
-     * @param defaultValue     The default.
-     * @return      A string which is the value.
-     */
-    public String optString(String key, String defaultValue) {
-        Object object = this.opt(key);
-        return NULL.equals(object) ? defaultValue : object.toString();
-    }
-
-
-    private void populateMap(Object bean) {
-        Class klass = bean.getClass();
-
-// If klass is a System class then set includeSuperClass to false.
-
-        boolean includeSuperClass = klass.getClassLoader() != null;
-
-        Method[] methods = includeSuperClass
-                ? klass.getMethods()
-                : klass.getDeclaredMethods();
-        for (int i = 0; i < methods.length; i += 1) {
-            try {
-                Method method = methods[i];
-                if (Modifier.isPublic(method.getModifiers())) {
-                    String name = method.getName();
-                    String key = "";
-                    if (name.startsWith("get")) {
-                        if ("getClass".equals(name) ||
-                                "getDeclaringClass".equals(name)) {
-                            key = "";
-                        } else {
-                            key = name.substring(3);
-                        }
-                    } else if (name.startsWith("is")) {
-                        key = name.substring(2);
-                    }
-                    if (key.length() > 0 &&
-                            Character.isUpperCase(key.charAt(0)) &&
-                            method.getParameterTypes().length == 0) {
-                        if (key.length() == 1) {
-                            key = key.toLowerCase();
-                        } else if (!Character.isUpperCase(key.charAt(1))) {
-                            key = key.substring(0, 1).toLowerCase() +
-                                key.substring(1);
-                        }
-
-                        Object result = method.invoke(bean, (Object[])null);
-                        if (result != null) {
-                            this.map.put(key, wrap(result));
-                        }
-                    }
-                }
-            } catch (Exception ignore) {
-            }
-        }
-    }
-
-
-    /**
-     * Put a key/boolean pair in the JSONObject.
-     *
-     * @param key   A key string.
-     * @param value A boolean which is the value.
-     * @return this.
-     * @throws JSONException If the key is null.
-     */
-    public JSONObject put(String key, boolean value) throws JSONException {
-        this.put(key, value ? Boolean.TRUE : Boolean.FALSE);
-        return this;
-    }
-
-
-    /**
-     * Put a key/value pair in the JSONObject, where the value will be a
-     * JSONArray which is produced from a Collection.
-     * @param key   A key string.
-     * @param value A Collection value.
-     * @return      this.
-     * @throws JSONException
-     */
-    public JSONObject put(String key, Collection value) throws JSONException {
-        this.put(key, new JSONArray(value));
-        return this;
-    }
-
-
-    /**
-     * Put a key/double pair in the JSONObject.
-     *
-     * @param key   A key string.
-     * @param value A double which is the value.
-     * @return this.
-     * @throws JSONException If the key is null or if the number is invalid.
-     */
-    public JSONObject put(String key, double value) throws JSONException {
-        this.put(key, new Double(value));
-        return this;
-    }
-
-
-    /**
-     * Put a key/int pair in the JSONObject.
-     *
-     * @param key   A key string.
-     * @param value An int which is the value.
-     * @return this.
-     * @throws JSONException If the key is null.
-     */
-    public JSONObject put(String key, int value) throws JSONException {
-        this.put(key, new Integer(value));
-        return this;
-    }
-
-
-    /**
-     * Put a key/long pair in the JSONObject.
-     *
-     * @param key   A key string.
-     * @param value A long which is the value.
-     * @return this.
-     * @throws JSONException If the key is null.
-     */
-    public JSONObject put(String key, long value) throws JSONException {
-        this.put(key, new Long(value));
-        return this;
-    }
-
-
-    /**
-     * Put a key/value pair in the JSONObject, where the value will be a
-     * JSONObject which is produced from a Map.
-     * @param key   A key string.
-     * @param value A Map value.
-     * @return      this.
-     * @throws JSONException
-     */
-    public JSONObject put(String key, Map value) throws JSONException {
-        this.put(key, new JSONObject(value));
-        return this;
-    }
-
-
-    /**
-     * Put a key/value pair in the JSONObject. If the value is null,
-     * then the key will be removed from the JSONObject if it is present.
-     * @param key   A key string.
-     * @param value An object which is the value. It should be of one of these
-     *  types: Boolean, Double, Integer, JSONArray, JSONObject, Long, String,
-     *  or the JSONObject.NULL object.
-     * @return this.
-     * @throws JSONException If the value is non-finite number
-     *  or if the key is null.
-     */
-    public JSONObject put(String key, Object value) throws JSONException {
-        if (key == null) {
-            throw new JSONException("Null key.");
-        }
-        if (value != null) {
-            testValidity(value);
-            this.map.put(key, value);
-        } else {
-            this.remove(key);
-        }
-        return this;
-    }
-
-
-    /**
-     * Put a key/value pair in the JSONObject, but only if the key and the
-     * value are both non-null, and only if there is not already a member
-     * with that name.
-     * @param key
-     * @param value
-     * @return his.
-     * @throws JSONException if the key is a duplicate
-     */
-    public JSONObject putOnce(String key, Object value) throws JSONException {
-        if (key != null && value != null) {
-            if (this.opt(key) != null) {
-                throw new JSONException("Duplicate key \"" + key + "\"");
-            }
-            this.put(key, value);
-        }
-        return this;
-    }
-
-
-    /**
-     * Put a key/value pair in the JSONObject, but only if the
-     * key and the value are both non-null.
-     * @param key   A key string.
-     * @param value An object which is the value. It should be of one of these
-     *  types: Boolean, Double, Integer, JSONArray, JSONObject, Long, String,
-     *  or the JSONObject.NULL object.
-     * @return this.
-     * @throws JSONException If the value is a non-finite number.
-     */
-    public JSONObject putOpt(String key, Object value) throws JSONException {
-        if (key != null && value != null) {
-            this.put(key, value);
-        }
-        return this;
-    }
-
-
-    /**
-     * Produce a string in double quotes with backslash sequences in all the
-     * right places. A backslash will be inserted within </, producing <\/,
-     * allowing JSON text to be delivered in HTML. In JSON text, a string
-     * cannot contain a control character or an unescaped quote or backslash.
-     * @param string A String
-     * @return  A String correctly formatted for insertion in a JSON text.
-     */
-    public static String quote(String string) {
-        StringWriter sw = new StringWriter();
-        synchronized (sw.getBuffer()) {
-            try {
-                return quote(string, sw).toString();
-            } catch (IOException ignored) {
-                // will never happen - we are writing to a string writer
-                return "";
-            }
-        }
-    }
-
-    public static Writer quote(String string, Writer w) throws IOException {
-        if (string == null || string.length() == 0) {
-            w.write("\"\"");
-            return w;
-        }
-
-        char b;
-        char c = 0;
-        String hhhh;
-        int i;
-        int len = string.length();
-
-        w.write('"');
-        for (i = 0; i < len; i += 1) {
-            b = c;
-            c = string.charAt(i);
-            switch (c) {
-            case '\\':
-            case '"':
-                w.write('\\');
-                w.write(c);
-                break;
-            case '/':
-                if (b == '<') {
-                    w.write('\\');
-                }
-                w.write(c);
-                break;
-            case '\b':
-                w.write("\\b");
-                break;
-            case '\t':
-                w.write("\\t");
-                break;
-            case '\n':
-                w.write("\\n");
-                break;
-            case '\f':
-                w.write("\\f");
-                break;
-            case '\r':
-                w.write("\\r");
-                break;
-            default:
-                if (c < ' ' || (c >= '\u0080' && c < '\u00a0')
-                        || (c >= '\u2000' && c < '\u2100')) {
-                    hhhh = "000" + Integer.toHexString(c);
-                    w.write("\\u" + hhhh.substring(hhhh.length() - 4));
-                } else {
-                    w.write(c);
-                }
-            }
-        }
-        w.write('"');
-        return w;
-    }
-
-    /**
-     * Remove a name and its value, if present.
-     * @param key The name to be removed.
-     * @return The value that was associated with the name,
-     * or null if there was no value.
-     */
-    public Object remove(String key) {
-        return this.map.remove(key);
-    }
-
-    /**
-     * Try to convert a string into a number, boolean, or null. If the string
-     * can't be converted, return the string.
-     * @param string A String.
-     * @return A simple JSON value.
-     */
-    public static Object stringToValue(String string) {
-        Double d;
-        if (string.equals("")) {
-            return string;
-        }
-        if (string.equalsIgnoreCase("true")) {
-            return Boolean.TRUE;
-        }
-        if (string.equalsIgnoreCase("false")) {
-            return Boolean.FALSE;
-        }
-        if (string.equalsIgnoreCase("null")) {
-            return JSONObject.NULL;
-        }
-
-        /*
-         * If it might be a number, try converting it.
-         * If a number cannot be produced, then the value will just
-         * be a string. Note that the plus and implied string
-         * conventions are non-standard. A JSON parser may accept
-         * non-JSON forms as long as it accepts all correct JSON forms.
-         */
-
-        char b = string.charAt(0);
-        if ((b >= '0' && b <= '9') || b == '.' || b == '-' || b == '+') {
-            try {
-                if (string.indexOf('.') > -1 ||
-                        string.indexOf('e') > -1 || string.indexOf('E') > -1) {
-                    d = Double.valueOf(string);
-                    if (!d.isInfinite() && !d.isNaN()) {
-                        return d;
-                    }
-                } else {
-                    Long myLong = new Long(string);
-                    if (myLong.longValue() == myLong.intValue()) {
-                        return new Integer(myLong.intValue());
-                    } else {
-                        return myLong;
-                    }
-                }
-            }  catch (Exception ignore) {
-            }
-        }
-        return string;
-    }
-
-
-    /**
-     * Throw an exception if the object is a NaN or infinite number.
-     * @param o The object to test.
-     * @throws JSONException If o is a non-finite number.
-     */
-    public static void testValidity(Object o) throws JSONException {
-        if (o != null) {
-            if (o instanceof Double) {
-                if (((Double)o).isInfinite() || ((Double)o).isNaN()) {
-                    throw new JSONException(
-                        "JSON does not allow non-finite numbers.");
-                }
-            } else if (o instanceof Float) {
-                if (((Float)o).isInfinite() || ((Float)o).isNaN()) {
-                    throw new JSONException(
-                        "JSON does not allow non-finite numbers.");
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Produce a JSONArray containing the values of the members of this
-     * JSONObject.
-     * @param names A JSONArray containing a list of key strings. This
-     * determines the sequence of the values in the result.
-     * @return A JSONArray of values.
-     * @throws JSONException If any of the values are non-finite numbers.
-     */
-    public JSONArray toJSONArray(JSONArray names) throws JSONException {
-        if (names == null || names.length() == 0) {
-            return null;
-        }
-        JSONArray ja = new JSONArray();
-        for (int i = 0; i < names.length(); i += 1) {
-            ja.put(this.opt(names.getString(i)));
-        }
-        return ja;
-    }
-
-    /**
-     * Make a JSON text of this JSONObject. For compactness, no whitespace
-     * is added. If this would not result in a syntactically correct JSON text,
-     * then null will be returned instead.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     *
-     * @return a printable, displayable, portable, transmittable
-     *  representation of the object, beginning
-     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
-     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
-     */
-    public String toString() {
-        try {
-            return this.toString(0);
-        } catch (Exception e) {
-            return null;
-        }
-    }
-
-
-    /**
-     * Make a prettyprinted JSON text of this JSONObject.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     * @param indentFactor The number of spaces to add to each level of
-     *  indentation.
-     * @return a printable, displayable, portable, transmittable
-     *  representation of the object, beginning
-     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
-     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
-     * @throws JSONException If the object contains an invalid number.
-     */
-    public String toString(int indentFactor) throws JSONException {
-        StringWriter w = new StringWriter();
-        synchronized (w.getBuffer()) {
-            return this.write(w, indentFactor, 0).toString();
-        }
-    }
-
-    /**
-     * Make a JSON text of an Object value. If the object has an
-     * value.toJSONString() method, then that method will be used to produce
-     * the JSON text. The method is required to produce a strictly
-     * conforming text. If the object does not contain a toJSONString
-     * method (which is the most common case), then a text will be
-     * produced by other means. If the value is an array or Collection,
-     * then a JSONArray will be made from it and its toJSONString method
-     * will be called. If the value is a MAP, then a JSONObject will be made
-     * from it and its toJSONString method will be called. Otherwise, the
-     * value's toString method will be called, and the result will be quoted.
-     *
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     * @param value The value to be serialized.
-     * @return a printable, displayable, transmittable
-     *  representation of the object, beginning
-     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
-     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
-     * @throws JSONException If the value is or contains an invalid number.
-     */
-    public static String valueToString(Object value) throws JSONException {
-        if (value == null || value.equals(null)) {
-            return "null";
-        }
-        if (value instanceof JSONString) {
-            Object object;
-            try {
-                object = ((JSONString)value).toJSONString();
-            } catch (Exception e) {
-                throw new JSONException(e);
-            }
-            if (object instanceof String) {
-                return (String)object;
-            }
-            throw new JSONException("Bad value from toJSONString: " + object);
-        }
-        if (value instanceof Number) {
-            return numberToString((Number) value);
-        }
-        if (value instanceof Boolean || value instanceof JSONObject ||
-                value instanceof JSONArray) {
-            return value.toString();
-        }
-        if (value instanceof Map) {
-            return new JSONObject((Map)value).toString();
-        }
-        if (value instanceof Collection) {
-            return new JSONArray((Collection)value).toString();
-        }
-        if (value.getClass().isArray()) {
-            return new JSONArray(value).toString();
-        }
-        return quote(value.toString());
-    }
-
-     /**
-      * Wrap an object, if necessary. If the object is null, return the NULL
-      * object. If it is an array or collection, wrap it in a JSONArray. If
-      * it is a map, wrap it in a JSONObject. If it is a standard property
-      * (Double, String, et al) then it is already wrapped. Otherwise, if it
-      * comes from one of the java packages, turn it into a string. And if
-      * it doesn't, try to wrap it in a JSONObject. If the wrapping fails,
-      * then null is returned.
-      *
-      * @param object The object to wrap
-      * @return The wrapped value
-      */
-     public static Object wrap(Object object) {
-         try {
-             if (object == null) {
-                 return NULL;
-             }
-             if (object instanceof JSONObject || object instanceof JSONArray  ||
-                     NULL.equals(object)      || object instanceof JSONString ||
-                     object instanceof Byte   || object instanceof Character  ||
-                     object instanceof Short  || object instanceof Integer    ||
-                     object instanceof Long   || object instanceof Boolean    ||
-                     object instanceof Float  || object instanceof Double     ||
-                     object instanceof String || object instanceof Enum) {
-                 return object;
-             }
-
-             if (object instanceof Collection) {
-                 return new JSONArray((Collection)object);
-             }
-             if (object.getClass().isArray()) {
-                 return new JSONArray(object);
-             }
-             if (object instanceof Map) {
-                 return new JSONObject((Map)object);
-             }
-             Package objectPackage = object.getClass().getPackage();
-             String objectPackageName = objectPackage != null
-                 ? objectPackage.getName()
-                 : "";
-             if (
-                 objectPackageName.startsWith("java.") ||
-                 objectPackageName.startsWith("javax.") ||
-                 object.getClass().getClassLoader() == null
-             ) {
-                 return object.toString();
-             }
-             return new JSONObject(object);
-         } catch(Exception exception) {
-             return null;
-         }
-     }
-
-
-     /**
-      * Write the contents of the JSONObject as JSON text to a writer.
-      * For compactness, no whitespace is added.
-      * <p>
-      * Warning: This method assumes that the data structure is acyclical.
-      *
-      * @return The writer.
-      * @throws JSONException
-      */
-     public Writer write(Writer writer) throws JSONException {
-        return this.write(writer, 0, 0);
-    }
-
-
-    static final Writer writeValue(Writer writer, Object value,
-            int indentFactor, int indent) throws JSONException, IOException {
-        if (value == null || value.equals(null)) {
-            writer.write("null");
-        } else if (value instanceof JSONObject) {
-            ((JSONObject) value).write(writer, indentFactor, indent);
-        } else if (value instanceof JSONArray) {
-            ((JSONArray) value).write(writer, indentFactor, indent);
-        } else if (value instanceof Map) {
-            new JSONObject((Map) value).write(writer, indentFactor, indent);
-        } else if (value instanceof Collection) {
-            new JSONArray((Collection) value).write(writer, indentFactor,
-                    indent);
-        } else if (value.getClass().isArray()) {
-            new JSONArray(value).write(writer, indentFactor, indent);
-        } else if (value instanceof Number) {
-            writer.write(numberToString((Number) value));
-        } else if (value instanceof Boolean) {
-            writer.write(value.toString());
-        } else if (value instanceof JSONString) {
-            Object o;
-            try {
-                o = ((JSONString) value).toJSONString();
-            } catch (Exception e) {
-                throw new JSONException(e);
-            }
-            writer.write(o != null ? o.toString() : quote(value.toString()));
-        } else {
-            quote(value.toString(), writer);
-        }
-        return writer;
-    }
-
-    static final void indent(Writer writer, int indent) throws IOException {
-        for (int i = 0; i < indent; i += 1) {
-            writer.write(' ');
-        }
-    }
-
-    /**
-     * Write the contents of the JSONObject as JSON text to a writer. For
-     * compactness, no whitespace is added.
-     * <p>
-     * Warning: This method assumes that the data structure is acyclical.
-     *
-     * @return The writer.
-     * @throws JSONException
-     */
-    Writer write(Writer writer, int indentFactor, int indent)
-            throws JSONException {
-        try {
-            boolean commanate = false;
-            final int length = this.length();
-            Iterator keys = this.keys();
-            writer.write('{');
-
-            if (length == 1) {
-                Object key = keys.next();
-                writer.write(quote(key.toString()));
-                writer.write(':');
-                if (indentFactor > 0) {
-                    writer.write(' ');
-                }
-                writeValue(writer, this.map.get(key), indentFactor, indent);
-            } else if (length != 0) {
-                final int newindent = indent + indentFactor;
-                while (keys.hasNext()) {
-                    Object key = keys.next();
-                    if (commanate) {
-                        writer.write(',');
-                    }
-                    if (indentFactor > 0) {
-                        writer.write('\n');
-                    }
-                    indent(writer, newindent);
-                    writer.write(quote(key.toString()));
-                    writer.write(':');
-                    if (indentFactor > 0) {
-                        writer.write(' ');
-                    }
-                    writeValue(writer, this.map.get(key), indentFactor,
-                            newindent);
-                    commanate = true;
-                }
-                if (indentFactor > 0) {
-                    writer.write('\n');
-                }
-                indent(writer, indent);
-            }
-            writer.write('}');
-            return writer;
-        } catch (IOException exception) {
-            throw new JSONException(exception);
-        }
-     }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONString.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONString.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONString.java
deleted file mode 100644
index 64674ff..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONString.java
+++ /dev/null
@@ -1,37 +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 com.vmware.geode.tools.pulse.internal.json;
-/**
- * The <code>JSONString</code> interface allows a <code>toJSONString()</code> 
- * method so that a class can change the behavior of 
- * <code>JSONObject.toString()</code>, <code>JSONArray.toString()</code>,
- * and <code>JSONWriter.value(</code>Object<code>)</code>. The 
- * <code>toJSONString</code> method will be used instead of the default behavior 
- * of using the Object's <code>toString()</code> method and quoting the result.
- */
-public interface JSONString {
-    /**
-     * The <code>toJSONString</code> method allows a class to produce its own JSON 
-     * serialization. 
-     * 
-     * @return A strictly syntactically correct JSON text.
-     */
-    String toJSONString();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONStringer.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONStringer.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONStringer.java
deleted file mode 100644
index 41adf5f..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONStringer.java
+++ /dev/null
@@ -1,73 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.io.StringWriter;
-
-/**
- * JSONStringer provides a quick and convenient way of producing JSON text.
- * The texts produced strictly conform to JSON syntax rules. No whitespace is
- * added, so the results are ready for transmission or storage. Each instance of
- * JSONStringer can produce one JSON text.
- * <p>
- * A JSONStringer instance provides a <code>value</code> method for appending
- * values to the
- * text, and a <code>key</code>
- * method for adding keys before values in objects. There are <code>array</code>
- * and <code>endArray</code> methods that make and bound array values, and
- * <code>object</code> and <code>endObject</code> methods which make and bound
- * object values. All of these methods return the JSONWriter instance,
- * permitting cascade style. For example, <pre>
- * myString = new JSONStringer()
- *     .object()
- *         .key("JSON")
- *         .value("Hello, World!")
- *     .endObject()
- *     .toString();</pre> which produces the string <pre>
- * {"JSON":"Hello, World!"}</pre>
- * <p>
- * The first method called must be <code>array</code> or <code>object</code>.
- * There are no methods for adding commas or colons. JSONStringer adds them for
- * you. Objects and arrays can be nested up to 20 levels deep.
- * <p>
- * This can sometimes be easier than using a JSONObject to build a string.
- * @author JSON.org
- * @version 2008-09-18
- */
-public class JSONStringer extends JSONWriter {
-    /**
-     * Make a fresh JSONStringer. It can be used to build one JSON text.
-     */
-    public JSONStringer() {
-        super(new StringWriter());
-    }
-
-    /**
-     * Return the JSON text. This method is used to obtain the product of the
-     * JSONStringer instance. It will return <code>null</code> if there was a
-     * problem in the construction of the JSON text (such as the calls to
-     * <code>array</code> were not properly balanced with calls to
-     * <code>endArray</code>).
-     * @return The JSON text.
-     */
-    public String toString() {
-        return this.mode == 'd' ? this.writer.toString() : null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONTokener.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONTokener.java
deleted file mode 100644
index 99f5658..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONTokener.java
+++ /dev/null
@@ -1,441 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.io.BufferedReader;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.io.Reader;
-import java.io.StringReader;
-
-/**
- * A JSONTokener takes a source string and extracts characters and tokens from
- * it. It is used by the JSONObject and JSONArray constructors to parse
- * JSON source strings.
- * @author JSON.org
- * @version 2012-02-16
- */
-public class JSONTokener {
-
-    private long    character;
-    private boolean eof;
-    private long    index;
-    private long    line;
-    private char    previous;
-    private Reader  reader;
-    private boolean usePrevious;
-
-
-    /**
-     * Construct a JSONTokener from a Reader.
-     *
-     * @param reader     A reader.
-     */
-    public JSONTokener(Reader reader) {
-        this.reader = reader.markSupported()
-            ? reader
-            : new BufferedReader(reader);
-        this.eof = false;
-        this.usePrevious = false;
-        this.previous = 0;
-        this.index = 0;
-        this.character = 1;
-        this.line = 1;
-    }
-
-
-    /**
-     * Construct a JSONTokener from an InputStream.
-     */
-    public JSONTokener(InputStream inputStream) throws JSONException {
-        this(new InputStreamReader(inputStream));
-    }
-
-
-    /**
-     * Construct a JSONTokener from a string.
-     *
-     * @param s     A source string.
-     */
-    public JSONTokener(String s) {
-        this(new StringReader(s));
-    }
-
-
-    /**
-     * Back up one character. This provides a sort of lookahead capability,
-     * so that you can test for a digit or letter before attempting to parse
-     * the next number or identifier.
-     */
-    public void back() throws JSONException {
-        if (this.usePrevious || this.index <= 0) {
-            throw new JSONException("Stepping back two steps is not supported");
-        }
-        this.index -= 1;
-        this.character -= 1;
-        this.usePrevious = true;
-        this.eof = false;
-    }
-
-
-    /**
-     * Get the hex value of a character (base16).
-     * @param c A character between '0' and '9' or between 'A' and 'F' or
-     * between 'a' and 'f'.
-     * @return  An int between 0 and 15, or -1 if c was not a hex digit.
-     */
-    public static int dehexchar(char c) {
-        if (c >= '0' && c <= '9') {
-            return c - '0';
-        }
-        if (c >= 'A' && c <= 'F') {
-            return c - ('A' - 10);
-        }
-        if (c >= 'a' && c <= 'f') {
-            return c - ('a' - 10);
-        }
-        return -1;
-    }
-
-    public boolean end() {
-        return this.eof && !this.usePrevious;
-    }
-
-
-    /**
-     * Determine if the source string still contains characters that next()
-     * can consume.
-     * @return true if not yet at the end of the source.
-     */
-    public boolean more() throws JSONException {
-        this.next();
-        if (this.end()) {
-            return false;
-        }
-        this.back();
-        return true;
-    }
-
-
-    /**
-     * Get the next character in the source string.
-     *
-     * @return The next character, or 0 if past the end of the source string.
-     */
-    public char next() throws JSONException {
-        int c;
-        if (this.usePrevious) {
-            this.usePrevious = false;
-            c = this.previous;
-        } else {
-            try {
-                c = this.reader.read();
-            } catch (IOException exception) {
-                throw new JSONException(exception);
-            }
-
-            if (c <= 0) { // End of stream
-                this.eof = true;
-                c = 0;
-            }
-        }
-        this.index += 1;
-        if (this.previous == '\r') {
-            this.line += 1;
-            this.character = c == '\n' ? 0 : 1;
-        } else if (c == '\n') {
-            this.line += 1;
-            this.character = 0;
-        } else {
-            this.character += 1;
-        }
-        this.previous = (char) c;
-        return this.previous;
-    }
-
-
-    /**
-     * Consume the next character, and check that it matches a specified
-     * character.
-     * @param c The character to match.
-     * @return The character.
-     * @throws JSONException if the character does not match.
-     */
-    public char next(char c) throws JSONException {
-        char n = this.next();
-        if (n != c) {
-            throw this.syntaxError("Expected '" + c + "' and instead saw '" +
-                    n + "'");
-        }
-        return n;
-    }
-
-
-    /**
-     * Get the next n characters.
-     *
-     * @param n     The number of characters to take.
-     * @return      A string of n characters.
-     * @throws JSONException
-     *   Substring bounds error if there are not
-     *   n characters remaining in the source string.
-     */
-     public String next(int n) throws JSONException {
-         if (n == 0) {
-             return "";
-         }
-
-         char[] chars = new char[n];
-         int pos = 0;
-
-         while (pos < n) {
-             chars[pos] = this.next();
-             if (this.end()) {
-                 throw this.syntaxError("Substring bounds error");
-             }
-             pos += 1;
-         }
-         return new String(chars);
-     }
-
-
-    /**
-     * Get the next char in the string, skipping whitespace.
-     * @throws JSONException
-     * @return  A character, or 0 if there are no more characters.
-     */
-    public char nextClean() throws JSONException {
-        for (;;) {
-            char c = this.next();
-            if (c == 0 || c > ' ') {
-                return c;
-            }
-        }
-    }
-
-
-    /**
-     * Return the characters up to the next close quote character.
-     * Backslash processing is done. The formal JSON format does not
-     * allow strings in single quotes, but an implementation is allowed to
-     * accept them.
-     * @param quote The quoting character, either
-     *      <code>"</code>&nbsp;<small>(double quote)</small> or
-     *      <code>'</code>&nbsp;<small>(single quote)</small>.
-     * @return      A String.
-     * @throws JSONException Unterminated string.
-     */
-    public String nextString(char quote) throws JSONException {
-        char c;
-        StringBuffer sb = new StringBuffer();
-        for (;;) {
-            c = this.next();
-            switch (c) {
-            case 0:
-            case '\n':
-            case '\r':
-                throw this.syntaxError("Unterminated string");
-            case '\\':
-                c = this.next();
-                switch (c) {
-                case 'b':
-                    sb.append('\b');
-                    break;
-                case 't':
-                    sb.append('\t');
-                    break;
-                case 'n':
-                    sb.append('\n');
-                    break;
-                case 'f':
-                    sb.append('\f');
-                    break;
-                case 'r':
-                    sb.append('\r');
-                    break;
-                case 'u':
-                    sb.append((char)Integer.parseInt(this.next(4), 16));
-                    break;
-                case '"':
-                case '\'':
-                case '\\':
-                case '/':
-                    sb.append(c);
-                    break;
-                default:
-                    throw this.syntaxError("Illegal escape.");
-                }
-                break;
-            default:
-                if (c == quote) {
-                    return sb.toString();
-                }
-                sb.append(c);
-            }
-        }
-    }
-
-
-    /**
-     * Get the text up but not including the specified character or the
-     * end of line, whichever comes first.
-     * @param  delimiter A delimiter character.
-     * @return   A string.
-     */
-    public String nextTo(char delimiter) throws JSONException {
-        StringBuffer sb = new StringBuffer();
-        for (;;) {
-            char c = this.next();
-            if (c == delimiter || c == 0 || c == '\n' || c == '\r') {
-                if (c != 0) {
-                    this.back();
-                }
-                return sb.toString().trim();
-            }
-            sb.append(c);
-        }
-    }
-
-
-    /**
-     * Get the text up but not including one of the specified delimiter
-     * characters or the end of line, whichever comes first.
-     * @param delimiters A set of delimiter characters.
-     * @return A string, trimmed.
-     */
-    public String nextTo(String delimiters) throws JSONException {
-        char c;
-        StringBuffer sb = new StringBuffer();
-        for (;;) {
-            c = this.next();
-            if (delimiters.indexOf(c) >= 0 || c == 0 ||
-                    c == '\n' || c == '\r') {
-                if (c != 0) {
-                    this.back();
-                }
-                return sb.toString().trim();
-            }
-            sb.append(c);
-        }
-    }
-
-
-    /**
-     * Get the next value. The value can be a Boolean, Double, Integer,
-     * JSONArray, JSONObject, Long, or String, or the JSONObject.NULL object.
-     * @throws JSONException If syntax error.
-     *
-     * @return An object.
-     */
-    public Object nextValue() throws JSONException {
-        char c = this.nextClean();
-        String string;
-
-        switch (c) {
-            case '"':
-            case '\'':
-                return this.nextString(c);
-            case '{':
-                this.back();
-                return new JSONObject(this);
-            case '[':
-                this.back();
-                return new JSONArray(this);
-        }
-
-        /*
-         * Handle unquoted text. This could be the values true, false, or
-         * null, or it can be a number. An implementation (such as this one)
-         * is allowed to also accept non-standard forms.
-         *
-         * Accumulate characters until we reach the end of the text or a
-         * formatting character.
-         */
-
-        StringBuffer sb = new StringBuffer();
-        while (c >= ' ' && ",:]}/\\\"[{;=#".indexOf(c) < 0) {
-            sb.append(c);
-            c = this.next();
-        }
-        this.back();
-
-        string = sb.toString().trim();
-        if ("".equals(string)) {
-            throw this.syntaxError("Missing value");
-        }
-        return JSONObject.stringToValue(string);
-    }
-
-
-    /**
-     * Skip characters until the next character is the requested character.
-     * If the requested character is not found, no characters are skipped.
-     * @param to A character to skip to.
-     * @return The requested character, or zero if the requested character
-     * is not found.
-     */
-    public char skipTo(char to) throws JSONException {
-        char c;
-        try {
-            long startIndex = this.index;
-            long startCharacter = this.character;
-            long startLine = this.line;
-            this.reader.mark(1000000);
-            do {
-                c = this.next();
-                if (c == 0) {
-                    this.reader.reset();
-                    this.index = startIndex;
-                    this.character = startCharacter;
-                    this.line = startLine;
-                    return c;
-                }
-            } while (c != to);
-        } catch (IOException exc) {
-            throw new JSONException(exc);
-        }
-
-        this.back();
-        return c;
-    }
-
-
-    /**
-     * Make a JSONException to signal a syntax error.
-     *
-     * @param message The error message.
-     * @return  A JSONException object, suitable for throwing
-     */
-    public JSONException syntaxError(String message) {
-        return new JSONException(message + this.toString());
-    }
-
-
-    /**
-     * Make a printable string of this JSONTokener.
-     *
-     * @return " at {index} [character {character} line {line}]"
-     */
-    public String toString() {
-        return " at " + this.index + " [character " + this.character + " line " +
-            this.line + "]";
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONWriter.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONWriter.java
deleted file mode 100644
index d1a661c..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/JSONWriter.java
+++ /dev/null
@@ -1,322 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.io.IOException;
-import java.io.Writer;
-
-/**
- * JSONWriter provides a quick and convenient way of producing JSON text.
- * The texts produced strictly conform to JSON syntax rules. No whitespace is
- * added, so the results are ready for transmission or storage. Each instance of
- * JSONWriter can produce one JSON text.
- * <p>
- * A JSONWriter instance provides a <code>value</code> method for appending
- * values to the
- * text, and a <code>key</code>
- * method for adding keys before values in objects. There are <code>array</code>
- * and <code>endArray</code> methods that make and bound array values, and
- * <code>object</code> and <code>endObject</code> methods which make and bound
- * object values. All of these methods return the JSONWriter instance,
- * permitting a cascade style. For example, <pre>
- * new JSONWriter(myWriter)
- *     .object()
- *         .key("JSON")
- *         .value("Hello, World!")
- *     .endObject();</pre> which writes <pre>
- * {"JSON":"Hello, World!"}</pre>
- * <p>
- * The first method called must be <code>array</code> or <code>object</code>.
- * There are no methods for adding commas or colons. JSONWriter adds them for
- * you. Objects and arrays can be nested up to 20 levels deep.
- * <p>
- * This can sometimes be easier than using a JSONObject to build a string.
- * @author JSON.org
- * @version 2011-11-24
- */
-public class JSONWriter {
-    private static final int maxdepth = 200;
-
-    /**
-     * The comma flag determines if a comma should be output before the next
-     * value.
-     */
-    private boolean comma;
-
-    /**
-     * The current mode. Values:
-     * 'a' (array),
-     * 'd' (done),
-     * 'i' (initial),
-     * 'k' (key),
-     * 'o' (object).
-     */
-    protected char mode;
-
-    /**
-     * The object/array stack.
-     */
-    private final JSONObject stack[];
-
-    /**
-     * The stack top index. A value of 0 indicates that the stack is empty.
-     */
-    private int top;
-
-    /**
-     * The writer that will receive the output.
-     */
-    protected Writer writer;
-
-    /**
-     * Make a fresh JSONWriter. It can be used to build one JSON text.
-     */
-    public JSONWriter(Writer w) {
-        this.comma = false;
-        this.mode = 'i';
-        this.stack = new JSONObject[maxdepth];
-        this.top = 0;
-        this.writer = w;
-    }
-
-    /**
-     * Append a value.
-     * @param string A string value.
-     * @return this
-     * @throws JSONException If the value is out of sequence.
-     */
-    private JSONWriter append(String string) throws JSONException {
-        if (string == null) {
-            throw new JSONException("Null pointer");
-        }
-        if (this.mode == 'o' || this.mode == 'a') {
-            try {
-                if (this.comma && this.mode == 'a') {
-                    this.writer.write(',');
-                }
-                this.writer.write(string);
-            } catch (IOException e) {
-                throw new JSONException(e);
-            }
-            if (this.mode == 'o') {
-                this.mode = 'k';
-            }
-            this.comma = true;
-            return this;
-        }
-        throw new JSONException("Value out of sequence.");
-    }
-
-    /**
-     * Begin appending a new array. All values until the balancing
-     * <code>endArray</code> will be appended to this array. The
-     * <code>endArray</code> method must be called to mark the array's end.
-     * @return this
-     * @throws JSONException If the nesting is too deep, or if the object is
-     * started in the wrong place (for example as a key or after the end of the
-     * outermost array or object).
-     */
-    public JSONWriter array() throws JSONException {
-        if (this.mode == 'i' || this.mode == 'o' || this.mode == 'a') {
-            this.push(null);
-            this.append("[");
-            this.comma = false;
-            return this;
-        }
-        throw new JSONException("Misplaced array.");
-    }
-
-    /**
-     * End something.
-     * @param mode Mode
-     * @param c Closing character
-     * @return this
-     * @throws JSONException If unbalanced.
-     */
-    private JSONWriter end(char mode, char c) throws JSONException {
-        if (this.mode != mode) {
-            throw new JSONException(mode == 'a'
-                ? "Misplaced endArray."
-                : "Misplaced endObject.");
-        }
-        this.pop(mode);
-        try {
-            this.writer.write(c);
-        } catch (IOException e) {
-            throw new JSONException(e);
-        }
-        this.comma = true;
-        return this;
-    }
-
-    /**
-     * End an array. This method most be called to balance calls to
-     * <code>array</code>.
-     * @return this
-     * @throws JSONException If incorrectly nested.
-     */
-    public JSONWriter endArray() throws JSONException {
-        return this.end('a', ']');
-    }
-
-    /**
-     * End an object. This method most be called to balance calls to
-     * <code>object</code>.
-     * @return this
-     * @throws JSONException If incorrectly nested.
-     */
-    public JSONWriter endObject() throws JSONException {
-        return this.end('k', '}');
-    }
-
-    /**
-     * Append a key. The key will be associated with the next value. In an
-     * object, every value must be preceded by a key.
-     * @param string A key string.
-     * @return this
-     * @throws JSONException If the key is out of place. For example, keys
-     *  do not belong in arrays or if the key is null.
-     */
-    public JSONWriter key(String string) throws JSONException {
-        if (string == null) {
-            throw new JSONException("Null key.");
-        }
-        if (this.mode == 'k') {
-            try {
-                this.stack[this.top - 1].putOnce(string, Boolean.TRUE);
-                if (this.comma) {
-                    this.writer.write(',');
-                }
-                this.writer.write(JSONObject.quote(string));
-                this.writer.write(':');
-                this.comma = false;
-                this.mode = 'o';
-                return this;
-            } catch (IOException e) {
-                throw new JSONException(e);
-            }
-        }
-        throw new JSONException("Misplaced key.");
-    }
-
-
-    /**
-     * Begin appending a new object. All keys and values until the balancing
-     * <code>endObject</code> will be appended to this object. The
-     * <code>endObject</code> method must be called to mark the object's end.
-     * @return this
-     * @throws JSONException If the nesting is too deep, or if the object is
-     * started in the wrong place (for example as a key or after the end of the
-     * outermost array or object).
-     */
-    public JSONWriter object() throws JSONException {
-        if (this.mode == 'i') {
-            this.mode = 'o';
-        }
-        if (this.mode == 'o' || this.mode == 'a') {
-            this.append("{");
-            this.push(new JSONObject());
-            this.comma = false;
-            return this;
-        }
-        throw new JSONException("Misplaced object.");
-
-    }
-
-
-    /**
-     * Pop an array or object scope.
-     * @param c The scope to close.
-     * @throws JSONException If nesting is wrong.
-     */
-    private void pop(char c) throws JSONException {
-        if (this.top <= 0) {
-            throw new JSONException("Nesting error.");
-        }
-        char m = this.stack[this.top - 1] == null ? 'a' : 'k';
-        if (m != c) {
-            throw new JSONException("Nesting error.");
-        }
-        this.top -= 1;
-        this.mode = this.top == 0
-            ? 'd'
-            : this.stack[this.top - 1] == null
-            ? 'a'
-            : 'k';
-    }
-
-    /**
-     * Push an array or object scope.
-     * @param jo The scope to open.
-     * @throws JSONException If nesting is too deep.
-     */
-    private void push(JSONObject jo) throws JSONException {
-        if (this.top >= maxdepth) {
-            throw new JSONException("Nesting too deep.");
-        }
-        this.stack[this.top] = jo;
-        this.mode = jo == null ? 'a' : 'k';
-        this.top += 1;
-    }
-
-
-    /**
-     * Append either the value <code>true</code> or the value
-     * <code>false</code>.
-     * @param b A boolean.
-     * @return this
-     * @throws JSONException
-     */
-    public JSONWriter value(boolean b) throws JSONException {
-        return this.append(b ? "true" : "false");
-    }
-
-    /**
-     * Append a double value.
-     * @param d A double.
-     * @return this
-     * @throws JSONException If the number is not finite.
-     */
-    public JSONWriter value(double d) throws JSONException {
-        return this.value(new Double(d));
-    }
-
-    /**
-     * Append a long value.
-     * @param l A long.
-     * @return this
-     * @throws JSONException
-     */
-    public JSONWriter value(long l) throws JSONException {
-        return this.append(Long.toString(l));
-    }
-
-
-    /**
-     * Append an object value.
-     * @param object The object to append. It can be null, or a Boolean, Number,
-     *   String, JSONObject, or JSONArray, or an object that implements JSONString.
-     * @return this
-     * @throws JSONException If the value is out of sequence.
-     */
-    public JSONWriter value(Object object) throws JSONException {
-        return this.append(JSONObject.valueToString(object));
-    }
-}


[63/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemberService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemberService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemberService.java
new file mode 100644
index 0000000..40eef85
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemberService.java
@@ -0,0 +1,132 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.TimeUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.math.BigDecimal;
+import java.math.RoundingMode;
+import java.text.DecimalFormat;
+import java.util.ArrayList;
+import java.util.List;
+
+/**
+ * Class ClusterMemberService
+ * 
+ * This class contains implementations of getting Cluster Member's details
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+// @Service("ClusterMember")
+@Service("ClusterMembers")
+@Scope("singleton")
+public class ClusterMemberService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  private final String HEAP_USAGE = "heapUsage";
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    Cluster.Member[] clusterMembersList = cluster.getMembers();
+
+    // create members json
+    ArrayNode memberListJson = mapper.createArrayNode();
+    for (Cluster.Member clusterMember : clusterMembersList) {
+      ObjectNode memberJSON = mapper.createObjectNode();
+      // getting members detail
+      memberJSON.put("gemfireVersion", clusterMember.getGemfireVersion());
+      memberJSON.put("memberId", clusterMember.getId());
+      memberJSON.put("name", clusterMember.getName());
+      memberJSON.put("host", clusterMember.getHost());
+
+      List<String> serverGroups = clusterMember.getServerGroups();
+      if(serverGroups.size() == 0){
+        serverGroups = new ArrayList<>();
+        serverGroups.add(PulseConstants.DEFAULT_SERVER_GROUP);
+      }
+
+      memberJSON.put("serverGroups", mapper.valueToTree(serverGroups));
+
+      List<String> redundancyZones = clusterMember.getRedundancyZones();
+      if(redundancyZones.size() == 0){
+        redundancyZones = new ArrayList<String>();
+        redundancyZones.add(PulseConstants.DEFAULT_REDUNDANCY_ZONE);
+      }
+      memberJSON.put("redundancyZones", mapper.valueToTree(redundancyZones));
+
+      long usedHeapSize = cluster.getUsedHeapSize();
+      long currentHeap = clusterMember.getCurrentHeapSize();
+      if (usedHeapSize > 0) {
+        double heapUsage = ((double) currentHeap / (double) usedHeapSize) * 100;
+        memberJSON.put(this.HEAP_USAGE, truncate(heapUsage, 2));
+      } else {
+        memberJSON.put(this.HEAP_USAGE, 0);
+      }
+      double currentCPUUsage = clusterMember.getCpuUsage();
+      double loadAvg = clusterMember.getLoadAverage();
+
+      memberJSON.put("cpuUsage", truncate(currentCPUUsage, 2));
+      memberJSON.put("currentHeapUsage", clusterMember.getCurrentHeapSize());
+      memberJSON.put("isManager", clusterMember.isManager());
+      memberJSON.put("uptime", TimeUtils.convertTimeSecondsToHMS(clusterMember.getUptime()));
+      memberJSON.put("loadAvg", truncate(loadAvg, 2));
+      memberJSON.put("sockets", clusterMember.getTotalFileDescriptorOpen());
+      memberJSON.put("threads", clusterMember.getNumThreads());
+
+      // Number of member clients
+      if (PulseController.getPulseProductSupport().equalsIgnoreCase(
+          PulseConstants.PRODUCT_NAME_SQLFIRE)){
+        memberJSON.put("clients", clusterMember.getNumSqlfireClients());
+      }else{
+        memberJSON.put("clients", clusterMember.getMemberClientsHMap().size());
+      }
+      memberJSON.put("queues", clusterMember.getQueueBacklog());
+
+      memberListJson.add(memberJSON);
+    }
+    // cluster's Members
+    responseJSON.put("members", memberListJson);
+    // Send json response
+    return responseJSON;
+  }
+
+  private double truncate(double value, int places) {
+    return new BigDecimal(value).setScale(places, RoundingMode.HALF_UP).doubleValue();
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMembersRGraphService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMembersRGraphService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMembersRGraphService.java
new file mode 100644
index 0000000..6972144
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMembersRGraphService.java
@@ -0,0 +1,359 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import java.text.DecimalFormat;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+
+import javax.servlet.http.HttpServletRequest;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+
+/**
+ * Class ClusterMembersRGraphService
+ * 
+ * This class contains implementations of getting List of Cluster members and
+ * their details
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("ClusterMembersRGraph")
+@Scope("singleton")
+public class ClusterMembersRGraphService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String CLUSTER = "clustor";
+  private final String MEMBER_COUNT = "memberCount";
+  private final String ID = "id";
+  private final String NAME = "name";
+  private final String DATA = "data";
+  private final String MEMORY_USAGE = "memoryUsage";
+  private final String CPU_USAGE = "cpuUsage";
+  private final String REGIONS = "regions";
+  private final String HOST = "host";
+  private final String PORT = "port";
+  private final String CLIENTS = "clients";
+  private final String GC_PAUSES = "gcPauses";
+  private final String GATEWAY_SENDER = "gatewaySender";
+  private final String GATEWAY_RECEIVER = "gatewayReceiver";
+  private final String LOAD_AVG = "loadAvg";
+  private final String SOCKETS = "sockets";
+  private final String THREADS = "threads";
+  private final String NUM_THREADS = "numThreads";
+
+  private final String MEMBER_NODE_TYPE_NORMAL = "Normal";
+  private final String MEMBER_NODE_TYPE_WARNING = "Warning";
+  private final String MEMBER_NODE_TYPE_ERROR = "Error";
+  private final String MEMBER_NODE_TYPE_SEVERE = "Severe";
+  private final String CHILDREN = "children";
+
+  // traversing the alert array list and members which have severe, error or
+  // warnings
+  // alerts saving them in three different arraylists
+  private List<String> severeAlertList;
+  private List<String> errorAlertsList;
+  private List<String> warningAlertsList;
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // Reference to repository
+    Repository repository = Repository.get();
+
+    // get cluster object
+    Cluster cluster = repository.getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // cluster's Members
+    responseJSON.put(this.CLUSTER,
+        getPhysicalServerJson(cluster, repository.getJmxHost(), repository.getJmxPort()));
+    responseJSON.put(this.MEMBER_COUNT, cluster.getMemberCount());
+
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * function used for getting all members details in format of JSON Object
+   * array defined under a cluster. This function create json based on the
+   * relation of physical host and members related to it.
+   * 
+   * @param cluster
+   * @param host
+   * @param port
+   * @return Array list of JSON objects for required fields of members in
+   *         cluster
+   */
+  private ObjectNode getPhysicalServerJson(Cluster cluster, String host, String port) {
+    Map<String, List<Cluster.Member>> physicalToMember = cluster.getPhysicalToMember();
+
+    ObjectNode clusterTopologyJSON = mapper.createObjectNode();
+
+    clusterTopologyJSON.put(this.ID, cluster.getClusterId());
+    clusterTopologyJSON.put(this.NAME, cluster.getClusterId());
+    ObjectNode data1 = mapper.createObjectNode();
+    clusterTopologyJSON.put(this.DATA, data1);
+    ArrayNode childHostArray = mapper.createArrayNode();
+    DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
+
+    updateAlertLists(cluster);
+
+    for (Map.Entry<String, List<Cluster.Member>> physicalToMem : physicalToMember.entrySet()) {
+      String hostName = physicalToMem.getKey();
+      double hostCpuUsage = 0.0;
+      long hostMemoryUsage = 0;
+      double hostLoadAvg = 0.0;
+      int hostNumThreads = 0;
+      long hostSockets = 0;
+      boolean hostSevere = false;
+      boolean hostError = false;
+      boolean hostWarning = false;
+      String hostStatus;
+      ObjectNode childHostObject = mapper.createObjectNode();
+      childHostObject.put(this.ID, hostName);
+      childHostObject.put(this.NAME, hostName);
+
+      ArrayNode membersArray = mapper.createArrayNode();
+
+      List<Cluster.Member> memberList = physicalToMem.getValue();
+      for (Cluster.Member member : memberList) {
+        ObjectNode memberJSONObj = mapper.createObjectNode();
+
+        memberJSONObj.put(this.ID, member.getId());
+        memberJSONObj.put(this.NAME, member.getName());
+
+        ObjectNode memberData = mapper.createObjectNode();
+
+        memberData.put("gemfireVersion", member.getGemfireVersion());
+
+        Long currentHeap = member.getCurrentHeapSize();
+        Long usedHeapSize = cluster.getUsedHeapSize();
+
+        if (usedHeapSize > 0) {
+          double heapUsage = (currentHeap.doubleValue() / usedHeapSize.doubleValue()) * 100;
+
+          memberData.put(this.MEMORY_USAGE,
+              Double.valueOf(df2.format(heapUsage)));
+        } else
+          memberData.put(this.MEMORY_USAGE, 0);
+
+        double currentCPUUsage = member.getCpuUsage();
+
+        memberData.put(this.CPU_USAGE,
+            Double.valueOf(df2.format(currentCPUUsage)));
+        memberData.put(this.REGIONS, member.getMemberRegions().size());
+        memberData.put(this.HOST, member.getHost());
+        if ((member.getMemberPort() == null)
+            || (member.getMemberPort().equals(""))) {
+          memberData.put(this.PORT, "-");
+        } else {
+          memberData.put(this.PORT, member.getMemberPort());
+        }
+        memberData.put(this.CLIENTS, member.getMemberClientsHMap().size());
+        memberData.put(this.GC_PAUSES, member.getGarbageCollectionCount());
+        memberData.put(this.NUM_THREADS, member.getNumThreads());
+
+        // Host CPU Usage is aggregate of all members cpu usage
+        // hostCpuUsage = hostCpuUsage + currentCPUUsage;
+        hostCpuUsage = member.getHostCpuUsage();
+        hostMemoryUsage = hostMemoryUsage + member.getCurrentHeapSize();
+        hostLoadAvg = member.getLoadAverage();
+        hostNumThreads = member.getNumThreads();
+        hostSockets = member.getTotalFileDescriptorOpen();
+
+        // defining the status of Member Icons for R Graph based on the alerts
+        // created for that member
+        String memberNodeType = "";
+        // for severe alert
+        if (severeAlertList.contains(member.getName())) {
+          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_SEVERE);
+          if (!hostSevere) {
+            hostSevere = true;
+          }
+        } else if (errorAlertsList.contains(member.getName())) {
+          // for error alerts
+          memberNodeType = getMemberNodeType(member,
+              this.MEMBER_NODE_TYPE_ERROR);
+          if (!hostError) {
+            hostError = true;
+          }
+        }
+        // for warning alerts
+        else if (warningAlertsList.contains(member.getName())) {
+          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_WARNING);
+          if (!hostWarning) {
+            hostWarning = true;
+          }
+        } else {
+          memberNodeType = getMemberNodeType(member, this.MEMBER_NODE_TYPE_NORMAL);
+        }
+
+        memberData.put("nodeType", memberNodeType);
+        memberData.put("$type", memberNodeType);
+        memberData.put(this.GATEWAY_SENDER, member.getGatewaySenderList().size());
+        if (member.getGatewayReceiver() != null) {
+          memberData.put(this.GATEWAY_RECEIVER, 1);
+        } else {
+          memberData.put(this.GATEWAY_RECEIVER, 0);
+        }
+        memberJSONObj.put(this.DATA, memberData);
+        memberJSONObj.put(this.CHILDREN, mapper.createArrayNode());
+        membersArray.add(memberJSONObj);
+      }
+      ObjectNode data = mapper.createObjectNode();
+
+      data.put(this.LOAD_AVG, Double.valueOf(df2.format(hostLoadAvg)));
+      data.put(this.SOCKETS, hostSockets);
+      data.put(this.THREADS, hostNumThreads);
+      data.put(this.CPU_USAGE, Double.valueOf(df2.format(hostCpuUsage)));
+      data.put(this.MEMORY_USAGE, hostMemoryUsage);
+
+      String hostNodeType;
+      // setting physical host status
+      if (hostSevere) {
+        hostStatus = this.MEMBER_NODE_TYPE_SEVERE;
+        hostNodeType = "hostSevereNode";
+      } else if (hostError) {
+        hostStatus = this.MEMBER_NODE_TYPE_ERROR;
+        hostNodeType = "hostErrorNode";
+      } else if (hostWarning) {
+        hostStatus = this.MEMBER_NODE_TYPE_WARNING;
+        hostNodeType = "hostWarningNode";
+      } else {
+        hostStatus = this.MEMBER_NODE_TYPE_NORMAL;
+        hostNodeType = "hostNormalNode";
+      }
+      data.put("hostStatus", hostStatus);
+      data.put("$type", hostNodeType);
+
+      childHostObject.put(this.DATA, data);
+
+      childHostObject.put(this.CHILDREN, membersArray);
+      childHostArray.add(childHostObject);
+    }
+    clusterTopologyJSON.put(this.CHILDREN, childHostArray);
+
+    return clusterTopologyJSON;
+  }
+
+  /**
+   * used for getting member node type based on member's current state
+   * 
+   * @param member
+   *          Member
+   * @param memberState
+   *          i.e Severe, Error, Warning or Normal
+   * @return
+   */
+  private String getMemberNodeType(Cluster.Member member, String memberState) {
+    String memberNodeType = "";
+
+    if ((member.isLocator()) && (member.isServer()) && (member.isManager())) {
+      memberNodeType = "memberLocatorManagerServer" + memberState + "Node";
+    } else if ((member.isLocator()) && (member.isServer())
+        && !(member.isManager())) {
+      memberNodeType = "memberLocatorServer" + memberState + "Node";
+    } else if ((member.isLocator()) && !(member.isServer())
+        && (member.isManager())) {
+      memberNodeType = "memberLocatorManager" + memberState + "Node";
+    } else if ((member.isLocator()) && !(member.isServer())
+        && !(member.isManager())) {
+      memberNodeType = "memberLocator" + memberState + "Node";
+    } else if (!(member.isLocator()) && (member.isServer())
+        && (member.isManager())) {
+      memberNodeType = "memberManagerServer" + memberState + "Node";
+    } else if (!(member.isLocator()) && (member.isServer())
+        && !(member.isManager())) {
+      memberNodeType = "memberServer" + memberState + "Node";
+    } else if (!(member.isLocator()) && !(member.isServer())
+        && (member.isManager())) {
+      memberNodeType = "memberManager" + memberState + "Node";
+    } else if (!(member.isLocator()) && !(member.isServer())
+        && !(member.isManager())) {
+      memberNodeType = "member" + memberState + "Node";
+    }
+    return memberNodeType;
+  }
+
+  /**
+   * function used for getting list of all the alerts and save the member names
+   * in respective error, warning and severe alert lists
+   * 
+   * @param cluster
+   */
+  private void updateAlertLists(Cluster cluster) {
+
+    severeAlertList = new ArrayList<String>();
+    errorAlertsList = new ArrayList<String>();
+    warningAlertsList = new ArrayList<String>();
+
+    Cluster.Alert[] alertsList = cluster.getAlertsList();
+
+    for (Cluster.Alert alert : alertsList) {
+      // if alert is severe
+      if (alert.getSeverity() == Cluster.Alert.SEVERE) {
+        if (errorAlertsList.contains(alert.getMemberName())) {
+          errorAlertsList.remove(alert.getMemberName());
+        } else if (warningAlertsList.contains(alert.getMemberName())) {
+          warningAlertsList.remove(alert.getMemberName());
+        }
+        if (!severeAlertList.contains(alert.getMemberName())) {
+          severeAlertList.add(alert.getMemberName());
+        }
+      }
+      // if alert is error
+      else if (alert.getSeverity() == Cluster.Alert.ERROR) {
+        if (!severeAlertList.contains(alert.getMemberName())) {
+          if (warningAlertsList.contains(alert.getMemberName())) {
+            warningAlertsList.remove(alert.getMemberName());
+          }
+          if (!errorAlertsList.contains(alert.getMemberName())) {
+            errorAlertsList.add(alert.getMemberName());
+          }
+        }
+      }
+      // if alert is warning
+      else if (alert.getSeverity() == Cluster.Alert.WARNING) {
+        if (!severeAlertList.contains(alert.getMemberName())) {
+          if (!errorAlertsList.contains(alert.getMemberName())) {
+            if (!warningAlertsList.contains(alert.getMemberName())) {
+              warningAlertsList.add(alert.getMemberName());
+            }
+          }
+        }
+      }
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemoryUsageService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemoryUsageService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemoryUsageService.java
new file mode 100644
index 0000000..bde7270
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterMemoryUsageService.java
@@ -0,0 +1,65 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class ClusterMemoryUsageService
+ * 
+ * This class contains implementations of getting Cluster's overall current
+ * memory usage details and its trend over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterMemoryUsage")
+@Scope("singleton")
+public class ClusterMemoryUsageService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // cluster's Memory Usage trend added to json response object
+
+    responseJSON.put("currentMemoryUsage", cluster.getUsedHeapSize());
+    responseJSON.put("memoryUsageTrend",
+        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_MEMORY_USAGE)));
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionService.java
new file mode 100644
index 0000000..ab0aef3
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionService.java
@@ -0,0 +1,211 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.List;
+import java.util.Map;
+
+/**
+ * Class ClusterRegionService
+ *
+ * This class contains implementations of getting Cluster's regions details
+ *
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterRegion")
+@Scope("singleton")
+public class ClusterRegionService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String ENTRY_SIZE = "entrySize";
+
+  // Comparator based upon regions entry count
+  private static Comparator<Cluster.Region> regionEntryCountComparator = (r1, r2) -> {
+    long r1Cnt = r1.getSystemRegionEntryCount();
+    long r2Cnt = r2.getSystemRegionEntryCount();
+    if (r1Cnt < r2Cnt) {
+      return -1;
+    } else if (r1Cnt > r2Cnt) {
+      return 1;
+    } else {
+      return 0;
+    }
+  };
+
+  @Override
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    String userName = request.getUserPrincipal().getName();
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // getting cluster's Regions
+    responseJSON.put("clusterName", cluster.getServerName());
+    responseJSON.put("userName", userName);
+    responseJSON.put("region", getRegionJson(cluster));
+
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * This method is used to get various regions associated with the given
+   * cluster and create json for each region fields and returns Array List for
+   * all the regions associated with given cluster
+   *
+   * @param cluster
+   * @return ArrayNode Array List
+   */
+  private ArrayNode getRegionJson(Cluster cluster) {
+
+    Long totalHeapSize = cluster.getTotalHeapSize();
+    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
+
+    Map<String, Cluster.Region> clusterRegions = cluster.getClusterRegions();
+
+    List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
+    clusterRegionsList.addAll(clusterRegions.values());
+
+    Collections.sort(clusterRegionsList, regionEntryCountComparator);
+
+    ArrayNode regionListJson = mapper.createArrayNode();
+    for (int count = 0; count < clusterRegionsList.size(); count++) {
+      Cluster.Region reg = clusterRegionsList.get(count);
+      ObjectNode regionJSON = mapper.createObjectNode();
+
+      regionJSON.put("name", reg.getName());
+      regionJSON.put("totalMemory", totalHeapSize);
+      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
+      regionJSON.put("memberCount", reg.getMemberCount());
+
+      final String regionType = reg.getRegionType();
+      regionJSON.put("type", regionType);
+      regionJSON.put("getsRate", reg.getGetsRate());
+      regionJSON.put("putsRate", reg.getPutsRate());
+
+      Cluster.Member[] clusterMembersList = cluster.getMembers();
+
+      ArrayNode memberNameArray = mapper.createArrayNode();
+      for (String memberName : reg.getMemberName()) {
+        for (Cluster.Member member : clusterMembersList) {
+          String name = member.getName();
+          name = name.replace(":", "-");
+          String id = member.getId();
+          id = id.replace(":", "-");
+
+          if ((memberName.equals(id)) || (memberName.equals(name))) {
+            ObjectNode regionMember = mapper.createObjectNode();
+            regionMember.put("id", member.getId());
+            regionMember.put("name", member.getName());
+            memberNameArray.add(regionMember);
+            break;
+          }
+        }
+      }
+
+      regionJSON.put("memberNames", memberNameArray);
+      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
+
+      Boolean persistent = reg.getPersistentEnabled();
+      if (persistent) {
+        regionJSON.put("persistence", VALUE_ON);
+      } else {
+        regionJSON.put("persistence", VALUE_OFF);
+      }
+
+      Boolean isEnableOffHeapMemory = reg.isEnableOffHeapMemory();
+      if (isEnableOffHeapMemory) {
+        regionJSON.put("isEnableOffHeapMemory", VALUE_ON);
+      } else {
+        regionJSON.put("isEnableOffHeapMemory", VALUE_OFF);
+      }
+
+      String regCompCodec = reg.getCompressionCodec();
+      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
+        regionJSON.put("compressionCodec", reg.getCompressionCodec());
+      } else {
+        regionJSON.put("compressionCodec", VALUE_NA);
+      }
+
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController
+          .getPulseProductSupport())) {
+        // Convert region path to dot separated region path
+        regionJSON.put("regionPath",
+            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
+      } else {
+        regionJSON.put("regionPath", reg.getFullPath());
+      }
+
+      regionJSON.put("memoryReadsTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
+      regionJSON.put("memoryWritesTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
+      regionJSON.put("diskReadsTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
+      regionJSON.put("diskWritesTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
+      regionJSON.put("emptyNodes", reg.getEmptyNode());
+      Long entrySize = reg.getEntrySize();
+      DecimalFormat form = new DecimalFormat(
+          PulseConstants.DECIMAL_FORMAT_PATTERN_2);
+      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
+
+      if (entrySize < 0) {
+        regionJSON.put(this.ENTRY_SIZE, VALUE_NA);
+      } else {
+        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
+      }
+      regionJSON.put("dataUsage", reg.getDiskUsage());
+      regionJSON.put("wanEnabled", reg.getWanEnabled());
+      regionJSON.put("totalDataUsage", totalDiskUsage);
+
+      regionJSON.put("memoryUsage", entrySizeInMB);
+
+      regionListJson.add(regionJSON);
+    }
+
+    return regionListJson;
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionsService.java
new file mode 100644
index 0000000..d0f4c77
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterRegionsService.java
@@ -0,0 +1,206 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.List;
+import java.util.Map;
+
+/**
+ * Class ClusterRegionsService
+ * 
+ * This class contains implementations of getting Cluster's regions details
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterRegions")
+@Scope("singleton")
+public class ClusterRegionsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String ENTRY_SIZE = "entrySize";
+
+  // Comparator based upon regions entry count
+  private static Comparator<Cluster.Region> regionEntryCountComparator = (r1, r2) -> {
+    long r1Cnt = r1.getSystemRegionEntryCount();
+    long r2Cnt = r2.getSystemRegionEntryCount();
+    if (r1Cnt < r2Cnt) {
+      return -1;
+    } else if (r1Cnt > r2Cnt) {
+      return 1;
+    } else {
+      return 0;
+    }
+  };
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // getting cluster's Regions
+    responseJSON.put("regions", getRegionJson(cluster));
+
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * This method is used to get various regions associated with the given
+   * cluster and create json for each region fields and returns Array List for
+   * all the regions associated with given cluster
+   * 
+   * @param cluster
+   * @return JSONObject Array List
+   */
+  private ArrayNode getRegionJson(Cluster cluster) {
+
+    Long totalHeapSize = cluster.getTotalHeapSize();
+    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
+
+    Map<String, Cluster.Region> clusterRegions = cluster.getClusterRegions();
+
+    List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
+    clusterRegionsList.addAll(clusterRegions.values());
+
+    Collections.sort(clusterRegionsList, regionEntryCountComparator);
+
+    ArrayNode regionListJson = mapper.createArrayNode();
+    for (int count = 0; count < clusterRegionsList.size(); count++) {
+      Cluster.Region reg = clusterRegionsList.get(count);
+      ObjectNode regionJSON = mapper.createObjectNode();
+
+      regionJSON.put("name", reg.getName());
+      regionJSON.put("totalMemory", totalHeapSize);
+      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
+      regionJSON.put("memberCount", reg.getMemberCount());
+
+      final String regionType = reg.getRegionType();
+      regionJSON.put("type", regionType);
+      regionJSON.put("getsRate", reg.getGetsRate());
+      regionJSON.put("putsRate", reg.getPutsRate());
+
+      Cluster.Member[] clusterMembersList = cluster.getMembers();
+
+      ArrayNode memberNameArray = mapper.createArrayNode();
+      for (String memberName : reg.getMemberName()) {
+        for (Cluster.Member member : clusterMembersList) {
+          String name = member.getName();
+          name = name.replace(":", "-");
+          String id = member.getId();
+          id = id.replace(":", "-");
+
+          if ((memberName.equals(id)) || (memberName.equals(name))) {
+            ObjectNode regionMember = mapper.createObjectNode();
+            regionMember.put("id", member.getId());
+            regionMember.put("name", member.getName());
+            memberNameArray.add(regionMember);
+            break;
+          }
+        }
+      }
+
+      regionJSON.put("memberNames", memberNameArray);
+      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
+
+      Boolean persistent = reg.getPersistentEnabled();
+      if (persistent) {
+        regionJSON.put("persistence", this.VALUE_ON);
+      } else {
+        regionJSON.put("persistence", this.VALUE_OFF);
+      }
+
+      Boolean isEnableOffHeapMemory = reg.isEnableOffHeapMemory();
+      if (isEnableOffHeapMemory) {
+        regionJSON.put("isEnableOffHeapMemory", this.VALUE_ON);
+      } else {
+        regionJSON.put("isEnableOffHeapMemory", this.VALUE_OFF);
+      }
+
+      String regCompCodec = reg.getCompressionCodec();
+      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
+        regionJSON.put("compressionCodec", reg.getCompressionCodec());
+      } else {
+        regionJSON.put("compressionCodec", this.VALUE_NA);
+      }
+
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
+        // Convert region path to dot separated region path
+        regionJSON.put("regionPath",
+            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
+        regionJSON.put("id",
+            StringUtils.getTableNameFromRegionName(reg.getFullPath()));
+      } else {
+        regionJSON.put("regionPath", reg.getFullPath());
+        regionJSON.put("id", reg.getFullPath());
+      }
+
+      regionJSON.put("memoryReadsTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
+      regionJSON.put("memoryWritesTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
+      regionJSON.put("diskReadsTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
+      regionJSON.put("diskWritesTrend",
+          mapper.valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
+      regionJSON.put("emptyNodes", reg.getEmptyNode());
+      Long entrySize = reg.getEntrySize();
+      DecimalFormat form = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN_2);
+      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
+
+      if (entrySize < 0) {
+        regionJSON.put(this.ENTRY_SIZE, this.VALUE_NA);
+      } else {
+        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
+      }
+      regionJSON.put("dataUsage", reg.getDiskUsage());
+      regionJSON.put("wanEnabled", reg.getWanEnabled());
+      regionJSON.put("totalDataUsage", totalDiskUsage);
+
+      regionJSON.put("memoryUsage", entrySizeInMB);
+
+      regionListJson.add(regionJSON);
+    }
+
+    return regionListJson;
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionService.java
new file mode 100644
index 0000000..2dffa2c
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionService.java
@@ -0,0 +1,237 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.apache.geode.tools.pulse.internal.util.TimeUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.List;
+
+/**
+ * Class ClusterSelectedRegionService
+ *
+ * This class contains implementations of getting Cluster's selected region details
+ *
+ * @since GemFire version 7.5 cedar  2014-03-01
+ */
+
+@Component
+@Service("ClusterSelectedRegion")
+@Scope("singleton")
+public class ClusterSelectedRegionService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String ENTRY_SIZE = "entrySize";
+
+  // Comparator based upon regions entry count
+  private static Comparator<Cluster.Member> memberCurrentHeapUsageComparator = (m1, m2) -> {
+    long m1HeapUsage = m1.getCurrentHeapSize();
+    long m2HeapUsage = m2.getCurrentHeapSize();
+    if (m1HeapUsage < m2HeapUsage) {
+      return -1;
+    } else if (m1HeapUsage > m2HeapUsage) {
+      return 1;
+    } else {
+      return 0;
+    }
+  };
+
+  @Override
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    String userName = request.getUserPrincipal().getName();
+    String pulseData = request.getParameter("pulseData");
+    JsonNode parameterMap = mapper.readTree(pulseData);
+    String selectedRegionFullPath = parameterMap.get("ClusterSelectedRegion").get("regionFullPath").textValue();
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // getting cluster's Regions
+    responseJSON.put("clusterName", cluster.getServerName());
+    responseJSON.put("userName", userName);
+    responseJSON.put("selectedRegion", getSelectedRegionJson(cluster, selectedRegionFullPath));
+
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * Create JSON for selected cluster region
+   *
+   * @param cluster
+   * @return ObjectNode Array List
+   */
+  private ObjectNode getSelectedRegionJson(Cluster cluster, String selectedRegionFullPath) {
+    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+    Long totalHeapSize = cluster.getTotalHeapSize();
+    Long totalDiskUsage = cluster.getTotalBytesOnDisk();
+
+    Cluster.Region reg = cluster.getClusterRegion(selectedRegionFullPath);
+    if (reg != null){
+      ObjectNode regionJSON = mapper.createObjectNode();
+
+      regionJSON.put("name", reg.getName());
+      regionJSON.put("path", reg.getFullPath());
+      regionJSON.put("totalMemory", totalHeapSize);
+      regionJSON.put("systemRegionEntryCount", reg.getSystemRegionEntryCount());
+      regionJSON.put("memberCount", reg.getMemberCount());
+
+      final String regionType = reg.getRegionType();
+      regionJSON.put("type", regionType);
+      regionJSON.put("getsRate", reg.getGetsRate());
+      regionJSON.put("putsRate", reg.getPutsRate());
+      regionJSON.put("lruEvictionRate", reg.getLruEvictionRate());
+
+      DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
+      Cluster.Member[] clusterMembersList = cluster.getMembers();
+
+      // collect members of this region
+      List<Cluster.Member> clusterMembersL = new ArrayList<Cluster.Member>();
+      for (String memberName : reg.getMemberName()) {
+       for (Cluster.Member member : clusterMembersList) {
+          String name = member.getName();
+          name = name.replace(":", "-");
+          String id = member.getId();
+          id = id.replace(":", "-");
+
+          if ((memberName.equals(id)) || (memberName.equals(name))) {
+             clusterMembersL.add(member);
+          }
+        }
+      }
+
+      // sort members of this region
+      Collections.sort(clusterMembersL, memberCurrentHeapUsageComparator);
+
+      // return sorted member list by heap usage
+      ArrayNode memberArray = mapper.createArrayNode();
+      for (Cluster.Member member : clusterMembersL) {
+          ObjectNode regionMember = mapper.createObjectNode();
+          regionMember.put("memberId", member.getId());
+          regionMember.put("name", member.getName());
+          regionMember.put("host", member.getHost());
+
+          long usedHeapSize = cluster.getUsedHeapSize();
+          long currentHeap = member.getCurrentHeapSize();
+          if (usedHeapSize > 0) {
+            double heapUsage = ((double) currentHeap / (double) usedHeapSize) * 100;
+            regionMember.put("heapUsage", Double.valueOf(df2.format(heapUsage)));
+          } else {
+            regionMember.put("heapUsage", 0);
+          }
+          double currentCPUUsage = member.getCpuUsage();
+          double loadAvg = member.getLoadAverage();
+
+          regionMember.put("cpuUsage", Double.valueOf(df2.format(currentCPUUsage)));
+          regionMember.put("currentHeapUsage", member.getCurrentHeapSize());
+          regionMember.put("isManager", member.isManager());
+          regionMember.put("uptime", TimeUtils.convertTimeSecondsToHMS(member.getUptime()));
+
+          regionMember.put("loadAvg", Double.valueOf(df2.format(loadAvg)));
+          regionMember.put("sockets", member.getTotalFileDescriptorOpen());
+          regionMember.put("threads", member.getNumThreads());
+
+          if (PulseController.getPulseProductSupport().equalsIgnoreCase(
+              PulseConstants.PRODUCT_NAME_SQLFIRE)){
+            regionMember.put("clients", member.getNumSqlfireClients());
+          }else{
+            regionMember.put("clients", member.getMemberClientsHMap().size());
+          }
+          regionMember.put("queues", member.getQueueBacklog());
+          memberArray.add(regionMember);
+      }
+
+      regionJSON.put("members", memberArray);
+      regionJSON.put("entryCount", reg.getSystemRegionEntryCount());
+
+      regionJSON.put("persistence", reg.getPersistentEnabled() ? PulseService.VALUE_ON : PulseService.VALUE_OFF);
+
+      regionJSON.put("isEnableOffHeapMemory", reg.isEnableOffHeapMemory() ? PulseService.VALUE_ON : PulseService.VALUE_OFF);
+
+      String regCompCodec = reg.getCompressionCodec();
+      if (StringUtils.isNotNullNotEmptyNotWhiteSpace(regCompCodec)) {
+        regionJSON.put("compressionCodec", reg.getCompressionCodec());
+      } else {
+        regionJSON.put("compressionCodec", PulseService.VALUE_NA);
+      }
+
+      if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
+        // Convert region path to dot separated region path
+        regionJSON.put("regionPath", StringUtils.getTableNameFromRegionName(reg.getFullPath()));
+      } else {
+        regionJSON.put("regionPath", reg.getFullPath());
+      }
+
+      regionJSON.put("memoryReadsTrend",
+          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_GETS_PER_SEC_TREND)));
+      regionJSON.put("memoryWritesTrend",
+          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_PUTS_PER_SEC_TREND)));
+      regionJSON.put("diskReadsTrend",
+          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_READS_PER_SEC_TREND)));
+      regionJSON.put("diskWritesTrend",
+          mapper.<JsonNode>valueToTree(reg.getRegionStatisticTrend(Cluster.Region.REGION_STAT_DISK_WRITES_PER_SEC_TREND)));
+
+      regionJSON.put("emptyNodes", reg.getEmptyNode());
+      Long entrySize = reg.getEntrySize();
+      DecimalFormat form = new DecimalFormat(
+          PulseConstants.DECIMAL_FORMAT_PATTERN_2);
+      String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
+      if (entrySize < 0) {
+        regionJSON.put(this.ENTRY_SIZE, PulseService.VALUE_NA);
+      } else {
+        regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
+      }
+      regionJSON.put("dataUsage", reg.getDiskUsage());
+      regionJSON.put("wanEnabled", reg.getWanEnabled());
+      regionJSON.put("totalDataUsage", totalDiskUsage);
+      regionJSON.put("memoryUsage", entrySizeInMB);
+
+      LOGGER.fine("calling getSelectedRegionJson :: regionJSON = " + regionJSON);
+      return regionJSON;
+    } else {
+      ObjectNode responseJSON = mapper.createObjectNode();
+      responseJSON.put("errorOnRegion", "Region [" + selectedRegionFullPath + "] is not available");
+      return responseJSON;
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
new file mode 100644
index 0000000..abf8e6f
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterSelectedRegionsMemberService.java
@@ -0,0 +1,143 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Cluster.RegionOnMember;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.Comparator;
+import java.util.List;
+
+/**
+ * Class ClusterSelectedRegionsMemberService
+ *
+ * This class contains implementations of getting Cluster's selected region's member specific details
+ * for all members in that region
+ *
+ * @since GemFire version 7.5 cedar 2014-03-01
+ */
+
+@Component
+@Service("ClusterSelectedRegionsMember")
+@Scope("singleton")
+public class ClusterSelectedRegionsMemberService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  //Comparator based upon regions entry count
+  private static Comparator<Cluster.RegionOnMember> romEntryCountComparator = (m1, m2) -> {
+      long m1EntryCount = m1.getEntryCount();
+      long m2EntryCount = m2.getEntryCount();
+      if (m1EntryCount < m2EntryCount) {
+        return -1;
+      } else if (m1EntryCount > m2EntryCount) {
+        return 1;
+      } else {
+        return 0;
+      }
+    };
+
+  @Override
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+    String userName = request.getUserPrincipal().getName();
+    String pulseData = request.getParameter("pulseData");
+    JsonNode parameterMap = mapper.readTree(pulseData);
+    String selectedRegionFullPath = parameterMap.get("ClusterSelectedRegionsMember").get("regionFullPath").textValue();
+    LOGGER.finest("ClusterSelectedRegionsMemberService selectedRegionFullPath = " + selectedRegionFullPath);
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // getting cluster's Regions
+    responseJSON.put("clusterName", cluster.getServerName());
+    responseJSON.put("userName", userName);
+    responseJSON.put("selectedRegionsMembers", getSelectedRegionsMembersJson(cluster, selectedRegionFullPath));
+    // Send json response
+    return responseJSON;
+  }
+
+  /**
+   * Create JSON for selected cluster region's all members
+   */
+  private ObjectNode getSelectedRegionsMembersJson(Cluster cluster, String selectedRegionFullPath) {
+    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+    Cluster.Region reg = cluster.getClusterRegion(selectedRegionFullPath);
+
+    if (reg != null){
+      ObjectNode regionMemberJSON = mapper.createObjectNode();
+      RegionOnMember[] regionOnMembers = reg.getRegionOnMembers();
+
+      //sort on entry count
+      List<RegionOnMember> romList = Arrays.asList(regionOnMembers);
+      Collections.sort(romList, romEntryCountComparator);
+
+      for(RegionOnMember rom : romList) {
+        ObjectNode memberJSON = mapper.createObjectNode();
+        memberJSON.put("memberName", rom.getMemberName());
+        memberJSON.put("regionFullPath", rom.getRegionFullPath());
+        memberJSON.put("entryCount", rom.getEntryCount());
+        memberJSON.put("entrySize", rom.getEntrySize());
+
+        memberJSON.put("accessor", ((rom.getLocalMaxMemory() == 0) ? "True" : "False"));
+        LOGGER.finest("calling getSelectedRegionsMembersJson :: rom.getLocalMaxMemory() = " + rom.getLocalMaxMemory());
+
+        memberJSON.put("memoryReadsTrend",
+            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND)));
+        LOGGER.finest("memoryReadsTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_GETS_PER_SEC_TREND).length);
+
+        memberJSON.put("memoryWritesTrend",
+            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND)));
+        LOGGER.finest("memoryWritesTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_PUTS_PER_SEC_TREND).length);
+
+        memberJSON.put("diskReadsTrend",
+            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND)));
+        LOGGER.finest("diskReadsTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_READS_PER_SEC_TREND).length);
+
+        memberJSON.put("diskWritesTrend",
+            mapper.<JsonNode>valueToTree(rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND)));
+        LOGGER.finest("diskWritesTrend = " + rom.getRegionOnMemberStatisticTrend(RegionOnMember.REGION_ON_MEMBER_STAT_DISK_WRITES_PER_SEC_TREND).length);
+
+        regionMemberJSON.put(rom.getMemberName(), memberJSON);
+      }
+
+      LOGGER.fine("calling getSelectedRegionsMembersJson :: regionJSON = " + regionMemberJSON);
+      return regionMemberJSON;
+    } else {
+      ObjectNode responseJSON = mapper.createObjectNode();
+      responseJSON.put("errorOnRegion", "Region [" + selectedRegionFullPath + "] is not available");
+      return responseJSON;
+    }
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterWANInfoService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterWANInfoService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterWANInfoService.java
new file mode 100644
index 0000000..fd6793d
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterWANInfoService.java
@@ -0,0 +1,75 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.util.Map;
+
+/**
+ * Class ClusterWANInfoService
+ * 
+ * This class contains implementations of getting Cluster's WAN Informations
+ * (connected clusters)
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("ClusterWANInfo")
+@Scope("singleton")
+public class ClusterWANInfoService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // members list
+    ArrayNode connectedClusterListJson = mapper.createArrayNode();
+
+    for (Map.Entry<String, Boolean> entry : cluster.getWanInformation()
+        .entrySet()) {
+      ObjectNode clusterJSON = mapper.createObjectNode();
+      clusterJSON.put("clusterId", entry.getKey());
+      clusterJSON.put("name", entry.getKey());
+      clusterJSON.put("status", entry.getValue());
+
+      connectedClusterListJson.add(clusterJSON);
+    }
+    // Response JSON
+    responseJSON.put("connectedClusters", connectedClusterListJson);
+    // Send json response
+    return responseJSON;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberAsynchEventQueuesService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
new file mode 100644
index 0000000..5200704
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberAsynchEventQueuesService.java
@@ -0,0 +1,99 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberAsynchEventQueuesService
+ * 
+ * This class contains implementations of getting Asynchronous Event Queues
+ * details of Cluster Member.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberAsynchEventQueues")
+@Scope("singleton")
+public class MemberAsynchEventQueuesService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberAsynchEventQueues").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      Cluster.AsyncEventQueue[] asyncEventQueues = clusterMember
+          .getMemberAsyncEventQueueList();
+      ArrayNode asyncEventQueueJsonList = mapper.createArrayNode();
+
+      if (asyncEventQueues != null && asyncEventQueues.length > 0) {
+        responseJSON.put("isAsyncEventQueuesPresent", true);
+
+        for (Cluster.AsyncEventQueue asyncEventQueue : asyncEventQueues) {
+          ObjectNode asyncEventQueueJSON = mapper.createObjectNode();
+          asyncEventQueueJSON.put("id", asyncEventQueue.getId());
+          asyncEventQueueJSON.put("primary", asyncEventQueue.getPrimary());
+          asyncEventQueueJSON.put("senderType", asyncEventQueue.isParallel());
+          asyncEventQueueJSON
+              .put("batchSize", asyncEventQueue.getBatchSize());
+          asyncEventQueueJSON.put("batchTimeInterval",
+              asyncEventQueue.getBatchTimeInterval());
+          asyncEventQueueJSON.put("batchConflationEnabled",
+              asyncEventQueue.isBatchConflationEnabled());
+          asyncEventQueueJSON.put("asyncEventListener",
+              asyncEventQueue.getAsyncEventListener());
+          asyncEventQueueJSON.put("queueSize",
+              asyncEventQueue.getEventQueueSize());
+
+          asyncEventQueueJsonList.add(asyncEventQueueJSON);
+        }
+        responseJSON.put("asyncEventQueues", asyncEventQueueJsonList);
+      } else {
+        responseJSON.put("isAsyncEventQueuesPresent", false);
+      }
+
+    }
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberClientsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberClientsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberClientsService.java
new file mode 100644
index 0000000..ddd2b76
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberClientsService.java
@@ -0,0 +1,101 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.apache.geode.tools.pulse.internal.util.TimeUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberClientsService
+ * 
+ * This class contains implementations of getting Memeber's Clients.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberClients")
+@Scope("singleton")
+public class MemberClientsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  // String constants used for forming a json response
+  private final String NAME = "name";
+  private final String HOST = "host";
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberClients").get("memberName").textValue();
+
+    ArrayNode clientListJson = mapper.createArrayNode();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+    if (clusterMember != null) {
+      responseJSON.put("memberId", clusterMember.getId());
+      responseJSON.put(this.NAME, clusterMember.getName());
+      responseJSON.put(this.HOST, clusterMember.getHost());
+
+      // member's clients
+
+      Cluster.Client[] memberClients = clusterMember.getMemberClients();
+      for (Cluster.Client memberClient : memberClients) {
+        ObjectNode regionJSON = mapper.createObjectNode();
+        regionJSON.put("clientId", memberClient.getId());
+        regionJSON.put(this.NAME, memberClient.getName());
+        regionJSON.put(this.HOST, memberClient.getHost());
+        regionJSON.put("queueSize", memberClient.getQueueSize());
+        regionJSON.put("clientCQCount", memberClient.getClientCQCount());
+        regionJSON.put("isConnected", memberClient.isConnected() ? "Yes" : "No");
+        regionJSON.put("isSubscriptionEnabled", memberClient.isSubscriptionEnabled() ? "Yes" : "No");
+        regionJSON.put("uptime", TimeUtils.convertTimeSecondsToHMS(memberClient.getUptime()));
+
+        regionJSON.put("cpuUsage", String.format("%.4f", memberClient.getCpuUsage()).toString());
+        // regionJSON.put("cpuUsage", memberClient.getCpuUsage());
+        regionJSON.put("threads", memberClient.getThreads());
+        regionJSON.put("gets", memberClient.getGets());
+        regionJSON.put("puts", memberClient.getPuts());
+
+        clientListJson.add(regionJSON);
+      }
+      responseJSON.put("memberClients", clientListJson);
+    }
+    // Send json response
+    return responseJSON;
+
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDetailsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDetailsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDetailsService.java
new file mode 100644
index 0000000..79cc2ba
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDetailsService.java
@@ -0,0 +1,122 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+
+/**
+ * Class MemberDetailsService
+ * 
+ * This class contains implementations of getting Memeber's Statistics.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberDetails")
+@Scope("singleton")
+public class MemberDetailsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    String userName = request.getUserPrincipal().getName();
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberDetails").get("memberName").textValue();
+    DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils
+        .makeCompliantName(memberName));
+    if (clusterMember != null) {
+      responseJSON.put("memberId", clusterMember.getId());
+      responseJSON.put("name", clusterMember.getName());
+      responseJSON.put("host", clusterMember.getHost());
+      responseJSON.put("clusterId", cluster.getId());
+      responseJSON.put("clusterName", cluster.getServerName());
+      responseJSON.put("userName", userName);
+      double loadAvg = clusterMember.getLoadAverage();
+      responseJSON.put("loadAverage", Double.valueOf(df2.format(loadAvg)));
+      responseJSON.put("sockets", clusterMember.getTotalFileDescriptorOpen());
+      responseJSON.put("threads", clusterMember.getNumThreads());
+      responseJSON.put("offHeapFreeSize", clusterMember.getOffHeapFreeSize());
+      responseJSON.put("offHeapUsedSize", clusterMember.getOffHeapUsedSize());
+      responseJSON.put("regionsCount", clusterMember.getMemberRegionsList().length);
+
+      // Number of member clients
+      if (PulseController.getPulseProductSupport().equalsIgnoreCase(
+          PulseConstants.PRODUCT_NAME_SQLFIRE)){
+        responseJSON.put("numClients", clusterMember.getNumSqlfireClients());
+      } else {
+        responseJSON.put("numClients", clusterMember.getMemberClientsHMap().size());
+      }
+
+      Long diskUsageVal = clusterMember.getTotalDiskUsage();
+      Double diskUsage = diskUsageVal.doubleValue() / 1024;
+
+      responseJSON.put("diskStorageUsed", Double.valueOf(df2.format(diskUsage)));
+
+      Cluster.Alert[] alertsList = cluster.getAlertsList();
+
+      String status = "Normal";
+
+      for (Cluster.Alert alert : alertsList) {
+        if (clusterMember.getName().equals(alert.getMemberName())) {
+          if (alert.getSeverity() == Cluster.Alert.SEVERE) {
+            status = "Severe";
+            break;
+          } else if (alert.getSeverity() == Cluster.Alert.ERROR) {
+            status = "Error";
+          } else if (alert.getSeverity() == Cluster.Alert.WARNING) {
+            status = "Warning";
+          }
+        }
+      }
+
+      responseJSON.put("status", status);
+
+    } else {
+      responseJSON.put("errorOnMember", "Member [" + memberName
+          + "] is not available");
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDiskThroughputService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDiskThroughputService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDiskThroughputService.java
new file mode 100644
index 0000000..9f1eba9
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberDiskThroughputService.java
@@ -0,0 +1,76 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberDiskThroughputService
+ * 
+ * This class contains implementations for getting Memeber's current Disk
+ * Throughput trends over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+@Component
+@Service("MemberDiskThroughput")
+@Scope("singleton")
+public class MemberDiskThroughputService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // members list
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberDiskThroughput").get("memberName").textValue();
+
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      responseJSON.put("throughputWrites", clusterMember.getThroughputWrites());
+      responseJSON.put("throughputWritesTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_THROUGHPUT_WRITES)));
+      responseJSON.put("throughputReads", clusterMember.getThroughputWrites());
+      responseJSON.put("throughputReadsTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_THROUGHPUT_READS)));
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGCPausesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGCPausesService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGCPausesService.java
new file mode 100644
index 0000000..b1fa07c
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/MemberGCPausesService.java
@@ -0,0 +1,73 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class MemberGCPausesService
+ * 
+ * This class contains implementations of getting Memeber's GC Pauses (JVM
+ * Pauses) details and its trend over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("MemberGCPauses")
+@Scope("singleton")
+public class MemberGCPausesService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // members list
+    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
+    String memberName = requestDataJSON.get("MemberGCPauses").get("memberName").textValue();
+    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
+
+    if (clusterMember != null) {
+      // response
+      responseJSON.put("gcPausesTrend",
+          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_GARBAGE_COLLECTION)));
+      responseJSON.put("gcPausesCount", clusterMember.getGarbageCollectionCount());
+    }
+
+    // Send json response
+    return responseJSON;
+  }
+}


[34/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedResultSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedResultSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedResultSet.java
index f7b6311..3877bd0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedResultSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedResultSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 
 
@@ -30,15 +30,15 @@ import java.util.List;
 import java.util.Set;
 import java.util.SortedSet;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class LinkedResultSet extends java.util.LinkedHashSet implements Ordered,
     SelectResults, DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedStructSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedStructSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedStructSet.java
index 3cfa738..5c3f964 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedStructSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/LinkedStructSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -28,17 +28,17 @@ import java.util.List;
 import java.util.Set;
 import java.util.SortedSet;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class LinkedStructSet extends LinkedHashSet<Struct> implements
     SelectResults<Struct>, Ordered, DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
index 4cc3fa0..b6eafd4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/MethodDispatch.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MethodDispatch.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MethodDispatch.java
index 16a3e42..084a360 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MethodDispatch.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MethodDispatch.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 
 import java.util.*;
 import java.lang.reflect.*;
 
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/NWayMergeResults.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/NWayMergeResults.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/NWayMergeResults.java
index 6be806a..03e9651 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/NWayMergeResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/NWayMergeResults.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -29,18 +29,18 @@ import java.util.List;
 import java.util.NoSuchElementException;
 import java.util.Set;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.utils.LimitIterator;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.HeapDataOutputStream;
-import com.gemstone.gemfire.internal.HeapDataOutputStream.LongUpdater;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.utils.LimitIterator;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.HeapDataOutputStream;
+import org.apache.geode.internal.HeapDataOutputStream.LongUpdater;
+import org.apache.geode.internal.Version;
 
 /**
  * The n - way merge results returns a sorted results on the cumulative sorted

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Negatable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Negatable.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Negatable.java
index 8642f5e..bf20faf 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Negatable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Negatable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 /**
  * Marker interface to mark CompiledValue classes that know how to negate themselves.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/NullToken.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/NullToken.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/NullToken.java
index 4d21d29..4e1aed4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/NullToken.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/NullToken.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  * A Token representing null.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ObjectIntHashMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ObjectIntHashMap.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ObjectIntHashMap.java
index 113eb8d..d111670 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ObjectIntHashMap.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ObjectIntHashMap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.IOException;
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparator.java
index a99a515..9203b2a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparator.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Comparator;
 import java.util.Iterator;
 import java.util.List;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.VMCachedDeserializable;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * A generic comparator class which compares two Object/StructImpl according to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparatorUnmapped.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparatorUnmapped.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparatorUnmapped.java
index 6eb8c46..6843d9c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparatorUnmapped.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrderByComparatorUnmapped.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenCustomHashMap;
 
@@ -23,11 +23,11 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.types.ObjectType;
 
 @Deprecated
 public class OrderByComparatorUnmapped extends OrderByComparator {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Ordered.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Ordered.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Ordered.java
index b55de6a..30d8e1a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Ordered.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Ordered.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Comparator;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrganizedOperands.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrganizedOperands.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrganizedOperands.java
index 3b55cc3..2b44471 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrganizedOperands.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/OrganizedOperands.java
@@ -19,7 +19,7 @@
  *
  * 
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 /**
  * Helper class object which gets created during organization of operands in a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/PRQueryTraceInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PRQueryTraceInfo.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PRQueryTraceInfo.java
index 6cbe397..344c3ba 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PRQueryTraceInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PRQueryTraceInfo.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,12 +22,12 @@ import java.io.IOException;
 import java.util.Collection;
 import java.util.Iterator;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 
 public class PRQueryTraceInfo implements DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
index 70c6f7c..3d8db8d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.lang.reflect.*;
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.NameNotFoundException;
-import com.gemstone.gemfire.cache.query.QueryService; 
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.*;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.NameNotFoundException;
+import org.apache.geode.cache.query.QueryService; 
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.*;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/PlanInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PlanInfo.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PlanInfo.java
index f42416a..ed803a6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PlanInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PlanInfo.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 /**
  * Encapsulates evaluation info about compiled values

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ProxyQueryService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ProxyQueryService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ProxyQueryService.java
index 21274c1..fc19039 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ProxyQueryService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ProxyQueryService.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -24,29 +24,29 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.internal.ProxyCache;
-import com.gemstone.gemfire.cache.client.internal.UserAttributes;
-import com.gemstone.gemfire.cache.query.CqAttributes;
-import com.gemstone.gemfire.cache.query.CqException;
-import com.gemstone.gemfire.cache.query.CqExistsException;
-import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.cache.query.CqServiceStatistics;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.IndexExistsException;
-import com.gemstone.gemfire.cache.query.IndexInvalidException;
-import com.gemstone.gemfire.cache.query.IndexNameConflictException;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.MultiIndexCreationException;
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.RegionNotFoundException;
-import com.gemstone.gemfire.cache.query.internal.cq.ClientCQ;
-import com.gemstone.gemfire.cache.query.internal.cq.InternalCqQuery;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.internal.ProxyCache;
+import org.apache.geode.cache.client.internal.UserAttributes;
+import org.apache.geode.cache.query.CqAttributes;
+import org.apache.geode.cache.query.CqException;
+import org.apache.geode.cache.query.CqExistsException;
+import org.apache.geode.cache.query.CqQuery;
+import org.apache.geode.cache.query.CqServiceStatistics;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.IndexExistsException;
+import org.apache.geode.cache.query.IndexInvalidException;
+import org.apache.geode.cache.query.IndexNameConflictException;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.MultiIndexCreationException;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.RegionNotFoundException;
+import org.apache.geode.cache.query.internal.cq.ClientCQ;
+import org.apache.geode.cache.query.internal.cq.InternalCqQuery;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A wrapper class over an actual QueryService instance. This is used when the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
index b43d082..7de8266 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.StringReader;
 import java.util.ArrayList;
@@ -30,28 +30,28 @@ import org.apache.logging.log4j.Logger;
 import antlr.collections.AST;
 import antlr.debug.misc.ASTFrame;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.parse.GemFireAST;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexer;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLParser;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.MapTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.MapType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.parse.GemFireAST;
+import org.apache.geode.cache.query.internal.parse.OQLLexer;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.parse.OQLParser;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.MapTypeImpl;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.MapType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * Class Description
@@ -82,7 +82,7 @@ public class QCompiler implements OQLLexerTokenTypes {
       OQLParser parser = new OQLParser (lexer);
       // by default use Unsupported AST class, overridden for supported
       // operators in the grammer proper
-      parser.setASTNodeClass ("com.gemstone.gemfire.cache.query.internal.parse.ASTUnsupported");
+      parser.setASTNodeClass ("org.apache.geode.cache.query.internal.parse.ASTUnsupported");
       parser.queryProgram ();
       GemFireAST n = (GemFireAST)parser.getAST ();
       n.compile(this);
@@ -100,7 +100,7 @@ public class QCompiler implements OQLLexerTokenTypes {
       OQLParser parser = new OQLParser (lexer);
       // by default use Unsupported AST class, overridden for supported
       // operators in the grammer proper
-      parser.setASTNodeClass ("com.gemstone.gemfire.cache.query.internal.parse.ASTUnsupported");
+      parser.setASTNodeClass ("org.apache.geode.cache.query.internal.parse.ASTUnsupported");
       parser.loneFromClause ();
       GemFireAST n = (GemFireAST)parser.getAST ();
       n.compile(this);
@@ -119,7 +119,7 @@ public class QCompiler implements OQLLexerTokenTypes {
       OQLParser parser = new OQLParser (lexer);
       // by default use Unsupported AST class, overridden for supported
       // operators in the grammer proper
-      parser.setASTNodeClass ("com.gemstone.gemfire.cache.query.internal.parse.ASTUnsupported");
+      parser.setASTNodeClass ("org.apache.geode.cache.query.internal.parse.ASTUnsupported");
       parser.loneProjectionAttributes ();
       GemFireAST n = (GemFireAST)parser.getAST ();
       // don't compile TOK_STAR
@@ -185,7 +185,7 @@ public class QCompiler implements OQLLexerTokenTypes {
       OQLParser parser = new OQLParser (lexer);
       // by default use Unsupported AST class, overridden for supported
       // operators in the grammer proper
-      parser.setASTNodeClass ("com.gemstone.gemfire.cache.query.internal.parse.ASTUnsupported");
+      parser.setASTNodeClass ("org.apache.geode.cache.query.internal.parse.ASTUnsupported");
       parser.loneImports();
       GemFireAST n = (GemFireAST)parser.getAST ();
       n.compile(this);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QRegion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QRegion.java
index 052200f..e1be5f3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QRegion.java
@@ -14,18 +14,18 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 import java.io.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.query.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.query.*;
 import java.util.concurrent.locks.Lock;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.cache.LocalDataSet;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.cache.LocalDataSet;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * @since GemFire 4.0

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QScope.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QScope.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QScope.java
index 789d8c3..b0e590a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QScope.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QScope.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionCanceledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionCanceledException.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionCanceledException.java
index e863004..d475727 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionCanceledException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionCanceledException.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.cache.control.ResourceManager;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.cache.control.ResourceManager;
 /**
  * Internal exception thrown when a query has been canceled and QueryMonitor.isQueryExecutionCanceled() is called
  * Due to various threads using the method, access to the query object may not be available for certain threads

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionContext.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionContext.java
index 25ec088..5fde70c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutionContext.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import it.unimi.dsi.fastutil.ints.IntOpenHashSet;
 
@@ -24,10 +24,10 @@ import java.util.List;
 import java.util.Map;
 import java.util.Stack;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * This ExecutionContext will be used ONLY for querying because this

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutor.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutor.java
index 6084d23..c18205e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryExecutor.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.TypeMismatchException;
 
 /**
  * An interface allowing different Region implementations to support 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryMonitor.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryMonitor.java
index d4ca1a9..fb96621 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryMonitor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentLinkedQueue;
@@ -24,13 +24,13 @@ import java.util.concurrent.atomic.AtomicBoolean;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.query.Query;
-import com.gemstone.gemfire.cache.query.QueryExecutionLowMemoryException;
-import com.gemstone.gemfire.cache.query.QueryExecutionTimeoutException;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.query.Query;
+import org.apache.geode.cache.query.QueryExecutionLowMemoryException;
+import org.apache.geode.cache.query.QueryExecutionTimeoutException;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * QueryMonitor class, monitors the query execution time. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
index f2658e2..a79dd14 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.query.*;
+import org.apache.geode.cache.query.*;
 
 /**
  * This interface is used by testing/debugging code to be notified of query

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverAdapter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverAdapter.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverAdapter.java
index 574b3b8..4b25359 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverAdapter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverAdapter.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 
-import com.gemstone.gemfire.cache.query.*;
+import org.apache.geode.cache.query.*;
 
 /**
  * This class provides 'do-nothing' implementations of all of the methods of
@@ -308,7 +308,7 @@ public class QueryObserverAdapter implements QueryObserver {
   }
 
   /**
-   * @see com.gemstone.gemfire.cache.query.internal.QueryObserver#beforeIndexLookup(com.gemstone.gemfire.cache.query.Index,
+   * @see org.apache.geode.cache.query.internal.QueryObserver#beforeIndexLookup(org.apache.geode.cache.query.Index,
    *      int, java.lang.Object, int, java.lang.Object, java.util.Set)
    */
   public void beforeIndexLookup(Index index, int lowerBoundOperator,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverHolder.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverHolder.java
index b1c4675..685bfc9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverHolder.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserverHolder.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 /**
  * This class is intended to hold a single 'observer' which will receive

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
index 8279c99..a29b599 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -28,32 +28,32 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.index.AbstractIndex;
-import com.gemstone.gemfire.cache.query.internal.index.IndexData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.index.IndexProtocol;
-import com.gemstone.gemfire.cache.query.internal.index.IndexUtils;
-import com.gemstone.gemfire.cache.query.internal.index.PartitionedIndex;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.index.AbstractIndex;
+import org.apache.geode.cache.query.internal.index.IndexData;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.index.IndexProtocol;
+import org.apache.geode.cache.query.internal.index.IndexUtils;
+import org.apache.geode.cache.query.internal.index.PartitionedIndex;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
 
 public class QueryUtils {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
index 6397f74..0f1eae6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
@@ -17,7 +17,7 @@
 /*
  * Created on Jan 27, 2008
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -26,21 +26,21 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.AmbiguousNameException;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.Index;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-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.TypeMismatchException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
+import org.apache.geode.cache.query.AmbiguousNameException;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.Index;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
 
 /**
  * This structure contains all the filter evaluatable CompiledComparision

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
index c0d4dc4..971f544 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,13 +22,13 @@ import java.io.IOException;
 import java.util.Collection;
 import java.util.Iterator;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.internal.ObjectIntHashMap.Entry;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.internal.ObjectIntHashMap.Entry;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CachePerfStats;
 
 public class ResultsBag extends Bag implements
     DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionCopyOnReadWrapper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionCopyOnReadWrapper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionCopyOnReadWrapper.java
index f9ba2f7..8147771 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionCopyOnReadWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionCopyOnReadWrapper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -23,12 +23,12 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
+import org.apache.geode.CopyHelper;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
 
 /**
  * Class that wraps any SelectResults and performs copy on read when iterating through the results

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionPdxDeserializerWrapper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionPdxDeserializerWrapper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionPdxDeserializerWrapper.java
index 5a57d98..91945f5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionPdxDeserializerWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionPdxDeserializerWrapper.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.ArrayList;
 import java.util.Collection;
@@ -23,14 +23,14 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Set;
 
-import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.CopyHelper;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 public class ResultsCollectionPdxDeserializerWrapper implements
     SelectResults {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
index 6f35770..6bd5f8a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 import java.io.*;
 import java.lang.reflect.Array;
 import java.lang.reflect.Modifier;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.cache.EntriesSet;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.cache.EntriesSet;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
 
 /**
  * Implementation of SelectResults that wraps an existing java.util.Collection

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsSet.java
index 2d513bf..e30013d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsSet.java
@@ -15,22 +15,22 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 // @todo probably should assert element type when elements added
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/RuntimeIterator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RuntimeIterator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RuntimeIterator.java
index 1eb8691..0e2bb9b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RuntimeIterator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RuntimeIterator.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 import java.util.*;
 import java.lang.reflect.Method;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.index.IndexCreationHelper;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.*;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.index.IndexCreationHelper;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.*;
 
 /**
  * Value representing a current iteration element. This is the representation

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/SelectResultsComparator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SelectResultsComparator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SelectResultsComparator.java
index c63e1b5..8321a62 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SelectResultsComparator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SelectResultsComparator.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Comparator;
 
-import com.gemstone.gemfire.cache.query.SelectResults;
+import org.apache.geode.cache.query.SelectResults;
 
 /**
  * Comparator used by the sorted set for storing the results obtained from

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultSet.java
index f30e865..0d1fb65 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultSet.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 import java.io.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.*;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  * Implementation of SelectResults that extends TreeSet This is the sorted

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
index 4f6e225..15f777b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Comparator;
 import java.util.Iterator;
@@ -23,10 +23,10 @@ import java.util.Map;
 import java.util.SortedMap;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.CachePerfStats;
 
 /**
  * This results set is used to sort the data allowing duplicates. If the data

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
index f318240..78c9749 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Arrays;
 import java.util.Collection;
@@ -23,14 +23,14 @@ import java.util.HashSet;
 import java.util.Iterator;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructSet.java
index b165e0e..48c78c8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructSet.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 import java.io.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.*;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  * A TreeSet constrained to contain Structs of all the same type. To conserve on

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
index 03439a7..7e95f82 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import it.unimi.dsi.fastutil.Hash;
 
@@ -26,14 +26,14 @@ import java.util.Collection;
 import java.util.Iterator;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.query.Struct;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.cache.query.types.CollectionType;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.cache.query.types.StructType;
-import com.gemstone.gemfire.internal.cache.CachePerfStats;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.Struct;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.cache.query.types.StructType;
+import org.apache.geode.internal.cache.CachePerfStats;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A Bag constrained to contain Structs of all the same type. To conserve on

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructFields.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructFields.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructFields.java
index 5aae91f..bc53d1d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructFields.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructFields.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.Iterator;
 
-import com.gemstone.gemfire.cache.query.types.CollectionType;
+import org.apache.geode.cache.query.types.CollectionType;
 
 /**
  * This interface is to be implemented by all SelectResults implementation which

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructImpl.java
index 673a84e..1f6bf07 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructImpl.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.util.*;
 import java.io.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * Implementation of Struct

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructSet.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructSet.java
index af2dbe7..5a10bb4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructSet.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import it.unimi.dsi.fastutil.objects.AbstractObjectIterator;
 import it.unimi.dsi.fastutil.objects.ObjectIterator;
@@ -25,13 +25,13 @@ import java.io.DataOutput;
 import java.io.IOException;
 import java.util.*;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.cache.query.internal.types.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A Set constrained to contain Structs of all the same type. To conserve on

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Support.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Support.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Support.java
index 9c12b13..3c55dcc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Support.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Support.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.InternalGemFireError;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
 
 
 
@@ -88,7 +88,7 @@ public class Support
                 throw new InternalGemFireError(LocalizedStrings.Support_ERROR_ASSERTION_FAILED_0.toLocalizedString(message));
         }
         
-            // com.gemstone.persistence.jdo.GsRuntime.notifyCDebugger(null);
+            // org.apache.persistence.jdo.GsRuntime.notifyCDebugger(null);
     }
     
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/Undefined.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Undefined.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Undefined.java
index e65c796..2e21f96 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Undefined.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Undefined.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal;
+package org.apache.geode.cache.query.internal;
 
 import java.io.*;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 /**
  * An UNDEFINED value is the result of accessing an attribute of a null-valued
@@ -41,7 +41,7 @@ public final class Undefined implements DataSerializableFixedID, Comparable, Ser
     Support.assertState(QueryService.UNDEFINED == null,
         "UNDEFINED constant already instantiated");
 
-    // com.gemstone.persistence.CanonicalizationHelper
+    // org.apache.persistence.CanonicalizationHelper
     // .putCanonicalObj("com/gemstone/persistence/query/QueryService.UNDEFINED",
     // this);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AbstractAggregator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AbstractAggregator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AbstractAggregator.java
index 0d56a3a..dc998a5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AbstractAggregator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AbstractAggregator.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.Aggregator;
+import org.apache.geode.cache.query.Aggregator;
 
 /**
  * Abstract Aggregator class providing support for downcasting the result

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Avg.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Avg.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Avg.java
index 7a0f00a..5607f46 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Avg.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Avg.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Computes the non distinct average for replicated region based queries

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgBucketNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgBucketNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgBucketNode.java
index dae038e..a3240aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgBucketNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgBucketNode.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * The aggregator for compuing average which is used on the bucket node for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinct.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinct.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinct.java
index 4548731..db22e2d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinct.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinct.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Computes the average of distinct values for replicated region based queries.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinctPRQueryNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinctPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinctPRQueryNode.java
index 20d368d..59d7760 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinctPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgDistinctPRQueryNode.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 /**
  * Computes the final average of distinct values for the partitioned region

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgPRQueryNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgPRQueryNode.java
index f892971..f7dbc94 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/AvgPRQueryNode.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 /**
  * Computes the final non distinct average for a partitioned region based query.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Count.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Count.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Count.java
index 8992150..523c5aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Count.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/Count.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
-import com.gemstone.gemfire.cache.query.Aggregator;
-import com.gemstone.gemfire.cache.query.QueryService;
+import org.apache.geode.cache.query.Aggregator;
+import org.apache.geode.cache.query.QueryService;
 
 /**
  * Computes the count of the non distinct rows for replicated & PR based

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinct.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinct.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinct.java
index c878a24..5068f85 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinct.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinct.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinctPRQueryNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinctPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinctPRQueryNode.java
index b2f88a7..2f3fc27 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinctPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountDistinctPRQueryNode.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.aggregate;
+package org.apache.geode.cache.query.internal.aggregate;
 
 import java.util.Set;
 



[65/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONObject.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONObject.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONObject.java
new file mode 100644
index 0000000..abfbcdd
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONObject.java
@@ -0,0 +1,1585 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.io.IOException;
+import java.io.StringWriter;
+import java.io.Writer;
+import java.lang.reflect.Field;
+import java.lang.reflect.Method;
+import java.lang.reflect.Modifier;
+import java.util.Collection;
+import java.util.Enumeration;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Locale;
+import java.util.Map;
+import java.util.ResourceBundle;
+
+/**
+ * A JSONObject is an unordered collection of name/value pairs. Its external
+ * form is a string wrapped in curly braces with colons between the names and
+ * values, and commas between the values and names. The internal form is an
+ * object having <code>get</code> and <code>opt</code> methods for accessing the
+ * values by name, and <code>put</code> methods for adding or replacing values
+ * by name. The values can be any of these types: <code>Boolean</code>,
+ * <code>JSONArray</code>, <code>JSONObject</code>, <code>Number</code>,
+ * <code>String</code>, or the <code>JSONObject.NULL</code> object. A JSONObject
+ * constructor can be used to convert an external form JSON text into an
+ * internal form whose values can be retrieved with the <code>get</code> and
+ * <code>opt</code> methods, or to convert values into a JSON text using the
+ * <code>put</code> and <code>toString</code> methods. A <code>get</code> method
+ * returns a value if one can be found, and throws an exception if one cannot be
+ * found. An <code>opt</code> method returns a default value instead of throwing
+ * an exception, and so is useful for obtaining optional values.
+ * <p>
+ * The generic <code>get()</code> and <code>opt()</code> methods return an
+ * object, which you can cast or query for type. There are also typed
+ * <code>get</code> and <code>opt</code> methods that do type checking and type
+ * coercion for you. The opt methods differ from the get methods in that they do
+ * not throw. Instead, they return a specified value, such as null.
+ * <p>
+ * The <code>put</code> methods add or replace values in an object. For example,
+ *
+ * <pre>
+ * myString = new JSONObject().put(&quot;JSON&quot;, &quot;Hello, World!&quot;).toString();
+ * </pre>
+ *
+ * produces the string <code>{"JSON": "Hello, World"}</code>.
+ * <p>
+ * The texts produced by the <code>toString</code> methods strictly conform to
+ * the JSON syntax rules. The constructors are more forgiving in the texts they
+ * will accept:
+ * <ul>
+ * <li>An extra <code>,</code>&nbsp;<small>(comma)</small> may appear just
+ * before the closing brace.</li>
+ * <li>Strings may be quoted with <code>'</code>&nbsp;<small>(single
+ * quote)</small>.</li>
+ * <li>Strings do not need to be quoted at all if they do not begin with a quote
+ * or single quote, and if they do not contain leading or trailing spaces, and
+ * if they do not contain any of these characters:
+ * <code>{ } [ ] / \ : , = ; #</code> and if they do not look like numbers and
+ * if they are not the reserved words <code>true</code>, <code>false</code>, or
+ * <code>null</code>.</li>
+ * <li>Keys can be followed by <code>=</code> or <code>=></code> as well as by
+ * <code>:</code>.</li>
+ * <li>Values can be followed by <code>;</code> <small>(semicolon)</small> as
+ * well as by <code>,</code> <small>(comma)</small>.</li>
+ * </ul>
+ *
+ * @author JSON.org
+ * @version 2012-07-02
+ */
+public class JSONObject {
+
+    /**
+     * JSONObject.NULL is equivalent to the value that JavaScript calls null,
+     * whilst Java's null is equivalent to the value that JavaScript calls
+     * undefined.
+     */
+     private static final class Null {
+
+        /**
+         * There is only intended to be a single instance of the NULL object,
+         * so the clone method returns itself.
+         * @return     NULL.
+         */
+        protected final Object clone() {
+            return this;
+        }
+
+        /**
+         * A Null object is equal to the null value and to itself.
+         * @param object    An object to test for nullness.
+         * @return true if the object parameter is the JSONObject.NULL object
+         *  or null.
+         */
+        public boolean equals(Object object) {
+            return object == null || object == this;
+        }
+
+        /**
+         * Get the "null" string value.
+         * @return The string "null".
+         */
+        public String toString() {
+            return "null";
+        }
+    }
+
+
+    /**
+     * The map where the JSONObject's properties are kept.
+     */
+    private final Map map;
+
+
+    /**
+     * It is sometimes more convenient and less ambiguous to have a
+     * <code>NULL</code> object than to use Java's <code>null</code> value.
+     * <code>JSONObject.NULL.equals(null)</code> returns <code>true</code>.
+     * <code>JSONObject.NULL.toString()</code> returns <code>"null"</code>.
+     */
+    public static final Object NULL = new Null();
+
+
+    /**
+     * Construct an empty JSONObject.
+     */
+    public JSONObject() {
+        this.map = new HashMap();
+    }
+
+
+    /**
+     * Construct a JSONObject from a subset of another JSONObject.
+     * An array of strings is used to identify the keys that should be copied.
+     * Missing keys are ignored.
+     * @param jo A JSONObject.
+     * @param names An array of strings.
+     */
+    public JSONObject(JSONObject jo, String[] names) {
+        this();
+        for (int i = 0; i < names.length; i += 1) {
+            try {
+                this.putOnce(names[i], jo.opt(names[i]));
+            } catch (Exception ignore) {
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONObject from a JSONTokener.
+     * @param x A JSONTokener object containing the source string.
+     * @throws JSONException If there is a syntax error in the source string
+     *  or a duplicated key.
+     */
+    public JSONObject(JSONTokener x) throws JSONException {
+        this();
+        char c;
+        String key;
+
+        if (x.nextClean() != '{') {
+            throw x.syntaxError("A JSONObject text must begin with '{'");
+        }
+        for (;;) {
+            c = x.nextClean();
+            switch (c) {
+            case 0:
+                throw x.syntaxError("A JSONObject text must end with '}'");
+            case '}':
+                return;
+            default:
+                x.back();
+                key = x.nextValue().toString();
+            }
+
+// The key is followed by ':'. We will also tolerate '=' or '=>'.
+
+            c = x.nextClean();
+            if (c == '=') {
+                if (x.next() != '>') {
+                    x.back();
+                }
+            } else if (c != ':') {
+                throw x.syntaxError("Expected a ':' after a key");
+            }
+            this.putOnce(key, x.nextValue());
+
+// Pairs are separated by ','. We will also tolerate ';'.
+
+            switch (x.nextClean()) {
+            case ';':
+            case ',':
+                if (x.nextClean() == '}') {
+                    return;
+                }
+                x.back();
+                break;
+            case '}':
+                return;
+            default:
+                throw x.syntaxError("Expected a ',' or '}'");
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONObject from a Map.
+     *
+     * @param map A map object that can be used to initialize the contents of
+     *  the JSONObject.
+     */
+    public JSONObject(Map map) {
+        this.map = new HashMap();
+        if (map != null) {
+            Iterator i = map.entrySet().iterator();
+            while (i.hasNext()) {
+                Map.Entry e = (Map.Entry)i.next();
+                Object value = e.getValue();
+                if (value != null) {
+                    this.map.put(e.getKey(), wrap(value));
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONObject from an Object using bean getters.
+     * It reflects on all of the public methods of the object.
+     * For each of the methods with no parameters and a name starting
+     * with <code>"get"</code> or <code>"is"</code> followed by an uppercase letter,
+     * the method is invoked, and a key and the value returned from the getter method
+     * are put into the new JSONObject.
+     *
+     * The key is formed by removing the <code>"get"</code> or <code>"is"</code> prefix.
+     * If the second remaining character is not upper case, then the first
+     * character is converted to lower case.
+     *
+     * For example, if an object has a method named <code>"getName"</code>, and
+     * if the result of calling <code>object.getName()</code> is <code>"Larry Fine"</code>,
+     * then the JSONObject will contain <code>"name": "Larry Fine"</code>.
+     *
+     * @param bean An object that has getter methods that should be used
+     * to make a JSONObject.
+     */
+    public JSONObject(Object bean) {
+        this();
+        this.populateMap(bean);
+    }
+
+
+    /**
+     * Construct a JSONObject from an Object, using reflection to find the
+     * public members. The resulting JSONObject's keys will be the strings
+     * from the names array, and the values will be the field values associated
+     * with those keys in the object. If a key is not found or not visible,
+     * then it will not be copied into the new JSONObject.
+     * @param object An object that has fields that should be used to make a
+     * JSONObject.
+     * @param names An array of strings, the names of the fields to be obtained
+     * from the object.
+     */
+    public JSONObject(Object object, String names[]) {
+        this();
+        Class c = object.getClass();
+        for (int i = 0; i < names.length; i += 1) {
+            String name = names[i];
+            try {
+                this.putOpt(name, c.getField(name).get(object));
+            } catch (Exception ignore) {
+            }
+        }
+    }
+
+
+    /**
+     * Construct a JSONObject from a source JSON text string.
+     * This is the most commonly used JSONObject constructor.
+     * @param source    A string beginning
+     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
+     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
+     * @exception JSONException If there is a syntax error in the source
+     *  string or a duplicated key.
+     */
+    public JSONObject(String source) throws JSONException {
+        this(new JSONTokener(source));
+    }
+
+
+    /**
+     * Construct a JSONObject from a ResourceBundle.
+     * @param baseName The ResourceBundle base name.
+     * @param locale The Locale to load the ResourceBundle for.
+     * @throws JSONException If any JSONExceptions are detected.
+     */
+    public JSONObject(String baseName, Locale locale) throws JSONException {
+        this();
+        ResourceBundle bundle = ResourceBundle.getBundle(baseName, locale,
+                Thread.currentThread().getContextClassLoader());
+
+// Iterate through the keys in the bundle.
+
+        Enumeration keys = bundle.getKeys();
+        while (keys.hasMoreElements()) {
+            Object key = keys.nextElement();
+            if (key instanceof String) {
+
+// Go through the path, ensuring that there is a nested JSONObject for each
+// segment except the last. Add the value using the last segment's name into
+// the deepest nested JSONObject.
+
+                String[] path = ((String)key).split("\\.");
+                int last = path.length - 1;
+                JSONObject target = this;
+                for (int i = 0; i < last; i += 1) {
+                    String segment = path[i];
+                    JSONObject nextTarget = target.optJSONObject(segment);
+                    if (nextTarget == null) {
+                        nextTarget = new JSONObject();
+                        target.put(segment, nextTarget);
+                    }
+                    target = nextTarget;
+                }
+                target.put(path[last], bundle.getString((String)key));
+            }
+        }
+    }
+
+
+    /**
+     * Accumulate values under a key. It is similar to the put method except
+     * that if there is already an object stored under the key then a
+     * JSONArray is stored under the key to hold all of the accumulated values.
+     * If there is already a JSONArray, then the new value is appended to it.
+     * In contrast, the put method replaces the previous value.
+     *
+     * If only one value is accumulated that is not a JSONArray, then the
+     * result will be the same as using put. But if multiple values are
+     * accumulated, then the result will be like append.
+     * @param key   A key string.
+     * @param value An object to be accumulated under the key.
+     * @return this.
+     * @throws JSONException If the value is an invalid number
+     *  or if the key is null.
+     */
+    public JSONObject accumulate(
+        String key,
+        Object value
+    ) throws JSONException {
+        testValidity(value);
+        Object object = this.opt(key);
+        if (object == null) {
+            this.put(key, value instanceof JSONArray
+                    ? new JSONArray().put(value)
+                    : value);
+        } else if (object instanceof JSONArray) {
+            ((JSONArray)object).put(value);
+        } else {
+            this.put(key, new JSONArray().put(object).put(value));
+        }
+        return this;
+    }
+
+
+    /**
+     * Append values to the array under a key. If the key does not exist in the
+     * JSONObject, then the key is put in the JSONObject with its value being a
+     * JSONArray containing the value parameter. If the key was already
+     * associated with a JSONArray, then the value parameter is appended to it.
+     * @param key   A key string.
+     * @param value An object to be accumulated under the key.
+     * @return this.
+     * @throws JSONException If the key is null or if the current value
+     *  associated with the key is not a JSONArray.
+     */
+    public JSONObject append(String key, Object value) throws JSONException {
+        testValidity(value);
+        Object object = this.opt(key);
+        if (object == null) {
+            this.put(key, new JSONArray().put(value));
+        } else if (object instanceof JSONArray) {
+            this.put(key, ((JSONArray)object).put(value));
+        } else {
+            throw new JSONException("JSONObject[" + key +
+                    "] is not a JSONArray.");
+        }
+        return this;
+    }
+
+
+    /**
+     * Produce a string from a double. The string "null" will be returned if
+     * the number is not finite.
+     * @param  d A double.
+     * @return A String.
+     */
+    public static String doubleToString(double d) {
+        if (Double.isInfinite(d) || Double.isNaN(d)) {
+            return "null";
+        }
+
+// Shave off trailing zeros and decimal point, if possible.
+
+        String string = Double.toString(d);
+        if (string.indexOf('.') > 0 && string.indexOf('e') < 0 &&
+                string.indexOf('E') < 0) {
+            while (string.endsWith("0")) {
+                string = string.substring(0, string.length() - 1);
+            }
+            if (string.endsWith(".")) {
+                string = string.substring(0, string.length() - 1);
+            }
+        }
+        return string;
+    }
+
+
+    /**
+     * Get the value object associated with a key.
+     *
+     * @param key   A key string.
+     * @return      The object associated with the key.
+     * @throws      JSONException if the key is not found.
+     */
+    public Object get(String key) throws JSONException {
+        if (key == null) {
+            throw new JSONException("Null key.");
+        }
+        Object object = this.opt(key);
+        if (object == null) {
+            throw new JSONException("JSONObject[" + quote(key) +
+                    "] not found.");
+        }
+        return object;
+    }
+
+
+    /**
+     * Get the boolean value associated with a key.
+     *
+     * @param key   A key string.
+     * @return      The truth.
+     * @throws      JSONException
+     *  if the value is not a Boolean or the String "true" or "false".
+     */
+    public boolean getBoolean(String key) throws JSONException {
+        Object object = this.get(key);
+        if (object.equals(Boolean.FALSE) ||
+                (object instanceof String &&
+                ((String)object).equalsIgnoreCase("false"))) {
+            return false;
+        } else if (object.equals(Boolean.TRUE) ||
+                (object instanceof String &&
+                ((String)object).equalsIgnoreCase("true"))) {
+            return true;
+        }
+        throw new JSONException("JSONObject[" + quote(key) +
+                "] is not a Boolean.");
+    }
+
+
+    /**
+     * Get the double value associated with a key.
+     * @param key   A key string.
+     * @return      The numeric value.
+     * @throws JSONException if the key is not found or
+     *  if the value is not a Number object and cannot be converted to a number.
+     */
+    public double getDouble(String key) throws JSONException {
+        Object object = this.get(key);
+        try {
+            return object instanceof Number
+                ? ((Number)object).doubleValue()
+                : Double.parseDouble((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONObject[" + quote(key) +
+                "] is not a number.");
+        }
+    }
+
+
+    /**
+     * Get the int value associated with a key.
+     *
+     * @param key   A key string.
+     * @return      The integer value.
+     * @throws   JSONException if the key is not found or if the value cannot
+     *  be converted to an integer.
+     */
+    public int getInt(String key) throws JSONException {
+        Object object = this.get(key);
+        try {
+            return object instanceof Number
+                ? ((Number)object).intValue()
+                : Integer.parseInt((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONObject[" + quote(key) +
+                "] is not an int.");
+        }
+    }
+
+
+    /**
+     * Get the JSONArray value associated with a key.
+     *
+     * @param key   A key string.
+     * @return      A JSONArray which is the value.
+     * @throws      JSONException if the key is not found or
+     *  if the value is not a JSONArray.
+     */
+    public JSONArray getJSONArray(String key) throws JSONException {
+        Object object = this.get(key);
+        if (object instanceof JSONArray) {
+            return (JSONArray)object;
+        }
+        throw new JSONException("JSONObject[" + quote(key) +
+                "] is not a JSONArray.");
+    }
+
+
+    /**
+     * Get the JSONObject value associated with a key.
+     *
+     * @param key   A key string.
+     * @return      A JSONObject which is the value.
+     * @throws      JSONException if the key is not found or
+     *  if the value is not a JSONObject.
+     */
+    public JSONObject getJSONObject(String key) throws JSONException {
+        Object object = this.get(key);
+        if (object instanceof JSONObject) {
+            return (JSONObject)object;
+        }
+        throw new JSONException("JSONObject[" + quote(key) +
+                "] is not a JSONObject.");
+    }
+
+
+    /**
+     * Get the long value associated with a key.
+     *
+     * @param key   A key string.
+     * @return      The long value.
+     * @throws   JSONException if the key is not found or if the value cannot
+     *  be converted to a long.
+     */
+    public long getLong(String key) throws JSONException {
+        Object object = this.get(key);
+        try {
+            return object instanceof Number
+                ? ((Number)object).longValue()
+                : Long.parseLong((String)object);
+        } catch (Exception e) {
+            throw new JSONException("JSONObject[" + quote(key) +
+                "] is not a long.");
+        }
+    }
+
+
+    /**
+     * Get an array of field names from a JSONObject.
+     *
+     * @return An array of field names, or null if there are no names.
+     */
+    public static String[] getNames(JSONObject jo) {
+        int length = jo.length();
+        if (length == 0) {
+            return null;
+        }
+        Iterator iterator = jo.keys();
+        String[] names = new String[length];
+        int i = 0;
+        while (iterator.hasNext()) {
+            names[i] = (String)iterator.next();
+            i += 1;
+        }
+        return names;
+    }
+
+
+    /**
+     * Get an array of field names from an Object.
+     *
+     * @return An array of field names, or null if there are no names.
+     */
+    public static String[] getNames(Object object) {
+        if (object == null) {
+            return null;
+        }
+        Class klass = object.getClass();
+        Field[] fields = klass.getFields();
+        int length = fields.length;
+        if (length == 0) {
+            return null;
+        }
+        String[] names = new String[length];
+        for (int i = 0; i < length; i += 1) {
+            names[i] = fields[i].getName();
+        }
+        return names;
+    }
+
+
+    /**
+     * Get the string associated with a key.
+     *
+     * @param key   A key string.
+     * @return      A string which is the value.
+     * @throws   JSONException if there is no string value for the key.
+     */
+    public String getString(String key) throws JSONException {
+        Object object = this.get(key);
+        if (object instanceof String) {
+            return (String)object;
+        }
+        throw new JSONException("JSONObject[" + quote(key) +
+            "] not a string.");
+    }
+
+
+    /**
+     * Determine if the JSONObject contains a specific key.
+     * @param key   A key string.
+     * @return      true if the key exists in the JSONObject.
+     */
+    public boolean has(String key) {
+        return this.map.containsKey(key);
+    }
+
+
+    /**
+     * Increment a property of a JSONObject. If there is no such property,
+     * create one with a value of 1. If there is such a property, and if
+     * it is an Integer, Long, Double, or Float, then add one to it.
+     * @param key  A key string.
+     * @return this.
+     * @throws JSONException If there is already a property with this name
+     * that is not an Integer, Long, Double, or Float.
+     */
+    public JSONObject increment(String key) throws JSONException {
+        Object value = this.opt(key);
+        if (value == null) {
+            this.put(key, 1);
+        } else if (value instanceof Integer) {
+            this.put(key, ((Integer)value).intValue() + 1);
+        } else if (value instanceof Long) {
+            this.put(key, ((Long)value).longValue() + 1);
+        } else if (value instanceof Double) {
+            this.put(key, ((Double)value).doubleValue() + 1);
+        } else if (value instanceof Float) {
+            this.put(key, ((Float)value).floatValue() + 1);
+        } else {
+            throw new JSONException("Unable to increment [" + quote(key) + "].");
+        }
+        return this;
+    }
+
+
+    /**
+     * Determine if the value associated with the key is null or if there is
+     *  no value.
+     * @param key   A key string.
+     * @return      true if there is no value associated with the key or if
+     *  the value is the JSONObject.NULL object.
+     */
+    public boolean isNull(String key) {
+        return JSONObject.NULL.equals(this.opt(key));
+    }
+
+
+    /**
+     * Get an enumeration of the keys of the JSONObject.
+     *
+     * @return An iterator of the keys.
+     */
+    public Iterator keys() {
+        return this.map.keySet().iterator();
+    }
+
+
+    /**
+     * Get the number of keys stored in the JSONObject.
+     *
+     * @return The number of keys in the JSONObject.
+     */
+    public int length() {
+        return this.map.size();
+    }
+
+
+    /**
+     * Produce a JSONArray containing the names of the elements of this
+     * JSONObject.
+     * @return A JSONArray containing the key strings, or null if the JSONObject
+     * is empty.
+     */
+    public JSONArray names() {
+        JSONArray ja = new JSONArray();
+        Iterator  keys = this.keys();
+        while (keys.hasNext()) {
+            ja.put(keys.next());
+        }
+        return ja.length() == 0 ? null : ja;
+    }
+
+    /**
+     * Produce a string from a Number.
+     * @param  number A Number
+     * @return A String.
+     * @throws JSONException If n is a non-finite number.
+     */
+    public static String numberToString(Number number)
+            throws JSONException {
+        if (number == null) {
+            throw new JSONException("Null pointer");
+        }
+        testValidity(number);
+
+// Shave off trailing zeros and decimal point, if possible.
+
+        String string = number.toString();
+        if (string.indexOf('.') > 0 && string.indexOf('e') < 0 &&
+                string.indexOf('E') < 0) {
+            while (string.endsWith("0")) {
+                string = string.substring(0, string.length() - 1);
+            }
+            if (string.endsWith(".")) {
+                string = string.substring(0, string.length() - 1);
+            }
+        }
+        return string;
+    }
+
+
+    /**
+     * Get an optional value associated with a key.
+     * @param key   A key string.
+     * @return      An object which is the value, or null if there is no value.
+     */
+    public Object opt(String key) {
+        return key == null ? null : this.map.get(key);
+    }
+
+
+    /**
+     * Get an optional boolean associated with a key.
+     * It returns false if there is no such key, or if the value is not
+     * Boolean.TRUE or the String "true".
+     *
+     * @param key   A key string.
+     * @return      The truth.
+     */
+    public boolean optBoolean(String key) {
+        return this.optBoolean(key, false);
+    }
+
+
+    /**
+     * Get an optional boolean associated with a key.
+     * It returns the defaultValue if there is no such key, or if it is not
+     * a Boolean or the String "true" or "false" (case insensitive).
+     *
+     * @param key              A key string.
+     * @param defaultValue     The default.
+     * @return      The truth.
+     */
+    public boolean optBoolean(String key, boolean defaultValue) {
+        try {
+            return this.getBoolean(key);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get an optional double associated with a key,
+     * or NaN if there is no such key or if its value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key   A string which is the key.
+     * @return      An object which is the value.
+     */
+    public double optDouble(String key) {
+        return this.optDouble(key, Double.NaN);
+    }
+
+
+    /**
+     * Get an optional double associated with a key, or the
+     * defaultValue if there is no such key or if its value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key   A key string.
+     * @param defaultValue     The default.
+     * @return      An object which is the value.
+     */
+    public double optDouble(String key, double defaultValue) {
+        try {
+            return this.getDouble(key);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get an optional int value associated with a key,
+     * or zero if there is no such key or if the value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key   A key string.
+     * @return      An object which is the value.
+     */
+    public int optInt(String key) {
+        return this.optInt(key, 0);
+    }
+
+
+    /**
+     * Get an optional int value associated with a key,
+     * or the default if there is no such key or if the value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key   A key string.
+     * @param defaultValue     The default.
+     * @return      An object which is the value.
+     */
+    public int optInt(String key, int defaultValue) {
+        try {
+            return this.getInt(key);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get an optional JSONArray associated with a key.
+     * It returns null if there is no such key, or if its value is not a
+     * JSONArray.
+     *
+     * @param key   A key string.
+     * @return      A JSONArray which is the value.
+     */
+    public JSONArray optJSONArray(String key) {
+        Object o = this.opt(key);
+        return o instanceof JSONArray ? (JSONArray)o : null;
+    }
+
+
+    /**
+     * Get an optional JSONObject associated with a key.
+     * It returns null if there is no such key, or if its value is not a
+     * JSONObject.
+     *
+     * @param key   A key string.
+     * @return      A JSONObject which is the value.
+     */
+    public JSONObject optJSONObject(String key) {
+        Object object = this.opt(key);
+        return object instanceof JSONObject ? (JSONObject)object : null;
+    }
+
+
+    /**
+     * Get an optional long value associated with a key,
+     * or zero if there is no such key or if the value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key   A key string.
+     * @return      An object which is the value.
+     */
+    public long optLong(String key) {
+        return this.optLong(key, 0);
+    }
+
+
+    /**
+     * Get an optional long value associated with a key,
+     * or the default if there is no such key or if the value is not a number.
+     * If the value is a string, an attempt will be made to evaluate it as
+     * a number.
+     *
+     * @param key          A key string.
+     * @param defaultValue The default.
+     * @return             An object which is the value.
+     */
+    public long optLong(String key, long defaultValue) {
+        try {
+            return this.getLong(key);
+        } catch (Exception e) {
+            return defaultValue;
+        }
+    }
+
+
+    /**
+     * Get an optional string associated with a key.
+     * It returns an empty string if there is no such key. If the value is not
+     * a string and is not null, then it is converted to a string.
+     *
+     * @param key   A key string.
+     * @return      A string which is the value.
+     */
+    public String optString(String key) {
+        return this.optString(key, "");
+    }
+
+
+    /**
+     * Get an optional string associated with a key.
+     * It returns the defaultValue if there is no such key.
+     *
+     * @param key   A key string.
+     * @param defaultValue     The default.
+     * @return      A string which is the value.
+     */
+    public String optString(String key, String defaultValue) {
+        Object object = this.opt(key);
+        return NULL.equals(object) ? defaultValue : object.toString();
+    }
+
+
+    private void populateMap(Object bean) {
+        Class klass = bean.getClass();
+
+// If klass is a System class then set includeSuperClass to false.
+
+        boolean includeSuperClass = klass.getClassLoader() != null;
+
+        Method[] methods = includeSuperClass
+                ? klass.getMethods()
+                : klass.getDeclaredMethods();
+        for (int i = 0; i < methods.length; i += 1) {
+            try {
+                Method method = methods[i];
+                if (Modifier.isPublic(method.getModifiers())) {
+                    String name = method.getName();
+                    String key = "";
+                    if (name.startsWith("get")) {
+                        if ("getClass".equals(name) ||
+                                "getDeclaringClass".equals(name)) {
+                            key = "";
+                        } else {
+                            key = name.substring(3);
+                        }
+                    } else if (name.startsWith("is")) {
+                        key = name.substring(2);
+                    }
+                    if (key.length() > 0 &&
+                            Character.isUpperCase(key.charAt(0)) &&
+                            method.getParameterTypes().length == 0) {
+                        if (key.length() == 1) {
+                            key = key.toLowerCase();
+                        } else if (!Character.isUpperCase(key.charAt(1))) {
+                            key = key.substring(0, 1).toLowerCase() +
+                                key.substring(1);
+                        }
+
+                        Object result = method.invoke(bean, (Object[])null);
+                        if (result != null) {
+                            this.map.put(key, wrap(result));
+                        }
+                    }
+                }
+            } catch (Exception ignore) {
+            }
+        }
+    }
+
+
+    /**
+     * Put a key/boolean pair in the JSONObject.
+     *
+     * @param key   A key string.
+     * @param value A boolean which is the value.
+     * @return this.
+     * @throws JSONException If the key is null.
+     */
+    public JSONObject put(String key, boolean value) throws JSONException {
+        this.put(key, value ? Boolean.TRUE : Boolean.FALSE);
+        return this;
+    }
+
+
+    /**
+     * Put a key/value pair in the JSONObject, where the value will be a
+     * JSONArray which is produced from a Collection.
+     * @param key   A key string.
+     * @param value A Collection value.
+     * @return      this.
+     * @throws JSONException
+     */
+    public JSONObject put(String key, Collection value) throws JSONException {
+        this.put(key, new JSONArray(value));
+        return this;
+    }
+
+
+    /**
+     * Put a key/double pair in the JSONObject.
+     *
+     * @param key   A key string.
+     * @param value A double which is the value.
+     * @return this.
+     * @throws JSONException If the key is null or if the number is invalid.
+     */
+    public JSONObject put(String key, double value) throws JSONException {
+        this.put(key, new Double(value));
+        return this;
+    }
+
+
+    /**
+     * Put a key/int pair in the JSONObject.
+     *
+     * @param key   A key string.
+     * @param value An int which is the value.
+     * @return this.
+     * @throws JSONException If the key is null.
+     */
+    public JSONObject put(String key, int value) throws JSONException {
+        this.put(key, new Integer(value));
+        return this;
+    }
+
+
+    /**
+     * Put a key/long pair in the JSONObject.
+     *
+     * @param key   A key string.
+     * @param value A long which is the value.
+     * @return this.
+     * @throws JSONException If the key is null.
+     */
+    public JSONObject put(String key, long value) throws JSONException {
+        this.put(key, new Long(value));
+        return this;
+    }
+
+
+    /**
+     * Put a key/value pair in the JSONObject, where the value will be a
+     * JSONObject which is produced from a Map.
+     * @param key   A key string.
+     * @param value A Map value.
+     * @return      this.
+     * @throws JSONException
+     */
+    public JSONObject put(String key, Map value) throws JSONException {
+        this.put(key, new JSONObject(value));
+        return this;
+    }
+
+
+    /**
+     * Put a key/value pair in the JSONObject. If the value is null,
+     * then the key will be removed from the JSONObject if it is present.
+     * @param key   A key string.
+     * @param value An object which is the value. It should be of one of these
+     *  types: Boolean, Double, Integer, JSONArray, JSONObject, Long, String,
+     *  or the JSONObject.NULL object.
+     * @return this.
+     * @throws JSONException If the value is non-finite number
+     *  or if the key is null.
+     */
+    public JSONObject put(String key, Object value) throws JSONException {
+        if (key == null) {
+            throw new JSONException("Null key.");
+        }
+        if (value != null) {
+            testValidity(value);
+            this.map.put(key, value);
+        } else {
+            this.remove(key);
+        }
+        return this;
+    }
+
+
+    /**
+     * Put a key/value pair in the JSONObject, but only if the key and the
+     * value are both non-null, and only if there is not already a member
+     * with that name.
+     * @param key
+     * @param value
+     * @return his.
+     * @throws JSONException if the key is a duplicate
+     */
+    public JSONObject putOnce(String key, Object value) throws JSONException {
+        if (key != null && value != null) {
+            if (this.opt(key) != null) {
+                throw new JSONException("Duplicate key \"" + key + "\"");
+            }
+            this.put(key, value);
+        }
+        return this;
+    }
+
+
+    /**
+     * Put a key/value pair in the JSONObject, but only if the
+     * key and the value are both non-null.
+     * @param key   A key string.
+     * @param value An object which is the value. It should be of one of these
+     *  types: Boolean, Double, Integer, JSONArray, JSONObject, Long, String,
+     *  or the JSONObject.NULL object.
+     * @return this.
+     * @throws JSONException If the value is a non-finite number.
+     */
+    public JSONObject putOpt(String key, Object value) throws JSONException {
+        if (key != null && value != null) {
+            this.put(key, value);
+        }
+        return this;
+    }
+
+
+    /**
+     * Produce a string in double quotes with backslash sequences in all the
+     * right places. A backslash will be inserted within </, producing <\/,
+     * allowing JSON text to be delivered in HTML. In JSON text, a string
+     * cannot contain a control character or an unescaped quote or backslash.
+     * @param string A String
+     * @return  A String correctly formatted for insertion in a JSON text.
+     */
+    public static String quote(String string) {
+        StringWriter sw = new StringWriter();
+        synchronized (sw.getBuffer()) {
+            try {
+                return quote(string, sw).toString();
+            } catch (IOException ignored) {
+                // will never happen - we are writing to a string writer
+                return "";
+            }
+        }
+    }
+
+    public static Writer quote(String string, Writer w) throws IOException {
+        if (string == null || string.length() == 0) {
+            w.write("\"\"");
+            return w;
+        }
+
+        char b;
+        char c = 0;
+        String hhhh;
+        int i;
+        int len = string.length();
+
+        w.write('"');
+        for (i = 0; i < len; i += 1) {
+            b = c;
+            c = string.charAt(i);
+            switch (c) {
+            case '\\':
+            case '"':
+                w.write('\\');
+                w.write(c);
+                break;
+            case '/':
+                if (b == '<') {
+                    w.write('\\');
+                }
+                w.write(c);
+                break;
+            case '\b':
+                w.write("\\b");
+                break;
+            case '\t':
+                w.write("\\t");
+                break;
+            case '\n':
+                w.write("\\n");
+                break;
+            case '\f':
+                w.write("\\f");
+                break;
+            case '\r':
+                w.write("\\r");
+                break;
+            default:
+                if (c < ' ' || (c >= '\u0080' && c < '\u00a0')
+                        || (c >= '\u2000' && c < '\u2100')) {
+                    hhhh = "000" + Integer.toHexString(c);
+                    w.write("\\u" + hhhh.substring(hhhh.length() - 4));
+                } else {
+                    w.write(c);
+                }
+            }
+        }
+        w.write('"');
+        return w;
+    }
+
+    /**
+     * Remove a name and its value, if present.
+     * @param key The name to be removed.
+     * @return The value that was associated with the name,
+     * or null if there was no value.
+     */
+    public Object remove(String key) {
+        return this.map.remove(key);
+    }
+
+    /**
+     * Try to convert a string into a number, boolean, or null. If the string
+     * can't be converted, return the string.
+     * @param string A String.
+     * @return A simple JSON value.
+     */
+    public static Object stringToValue(String string) {
+        Double d;
+        if (string.equals("")) {
+            return string;
+        }
+        if (string.equalsIgnoreCase("true")) {
+            return Boolean.TRUE;
+        }
+        if (string.equalsIgnoreCase("false")) {
+            return Boolean.FALSE;
+        }
+        if (string.equalsIgnoreCase("null")) {
+            return JSONObject.NULL;
+        }
+
+        /*
+         * If it might be a number, try converting it.
+         * If a number cannot be produced, then the value will just
+         * be a string. Note that the plus and implied string
+         * conventions are non-standard. A JSON parser may accept
+         * non-JSON forms as long as it accepts all correct JSON forms.
+         */
+
+        char b = string.charAt(0);
+        if ((b >= '0' && b <= '9') || b == '.' || b == '-' || b == '+') {
+            try {
+                if (string.indexOf('.') > -1 ||
+                        string.indexOf('e') > -1 || string.indexOf('E') > -1) {
+                    d = Double.valueOf(string);
+                    if (!d.isInfinite() && !d.isNaN()) {
+                        return d;
+                    }
+                } else {
+                    Long myLong = new Long(string);
+                    if (myLong.longValue() == myLong.intValue()) {
+                        return new Integer(myLong.intValue());
+                    } else {
+                        return myLong;
+                    }
+                }
+            }  catch (Exception ignore) {
+            }
+        }
+        return string;
+    }
+
+
+    /**
+     * Throw an exception if the object is a NaN or infinite number.
+     * @param o The object to test.
+     * @throws JSONException If o is a non-finite number.
+     */
+    public static void testValidity(Object o) throws JSONException {
+        if (o != null) {
+            if (o instanceof Double) {
+                if (((Double)o).isInfinite() || ((Double)o).isNaN()) {
+                    throw new JSONException(
+                        "JSON does not allow non-finite numbers.");
+                }
+            } else if (o instanceof Float) {
+                if (((Float)o).isInfinite() || ((Float)o).isNaN()) {
+                    throw new JSONException(
+                        "JSON does not allow non-finite numbers.");
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Produce a JSONArray containing the values of the members of this
+     * JSONObject.
+     * @param names A JSONArray containing a list of key strings. This
+     * determines the sequence of the values in the result.
+     * @return A JSONArray of values.
+     * @throws JSONException If any of the values are non-finite numbers.
+     */
+    public JSONArray toJSONArray(JSONArray names) throws JSONException {
+        if (names == null || names.length() == 0) {
+            return null;
+        }
+        JSONArray ja = new JSONArray();
+        for (int i = 0; i < names.length(); i += 1) {
+            ja.put(this.opt(names.getString(i)));
+        }
+        return ja;
+    }
+
+    /**
+     * Make a JSON text of this JSONObject. For compactness, no whitespace
+     * is added. If this would not result in a syntactically correct JSON text,
+     * then null will be returned instead.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     *
+     * @return a printable, displayable, portable, transmittable
+     *  representation of the object, beginning
+     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
+     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
+     */
+    public String toString() {
+        try {
+            return this.toString(0);
+        } catch (Exception e) {
+            return null;
+        }
+    }
+
+
+    /**
+     * Make a prettyprinted JSON text of this JSONObject.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     * @param indentFactor The number of spaces to add to each level of
+     *  indentation.
+     * @return a printable, displayable, portable, transmittable
+     *  representation of the object, beginning
+     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
+     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
+     * @throws JSONException If the object contains an invalid number.
+     */
+    public String toString(int indentFactor) throws JSONException {
+        StringWriter w = new StringWriter();
+        synchronized (w.getBuffer()) {
+            return this.write(w, indentFactor, 0).toString();
+        }
+    }
+
+    /**
+     * Make a JSON text of an Object value. If the object has an
+     * value.toJSONString() method, then that method will be used to produce
+     * the JSON text. The method is required to produce a strictly
+     * conforming text. If the object does not contain a toJSONString
+     * method (which is the most common case), then a text will be
+     * produced by other means. If the value is an array or Collection,
+     * then a JSONArray will be made from it and its toJSONString method
+     * will be called. If the value is a MAP, then a JSONObject will be made
+     * from it and its toJSONString method will be called. Otherwise, the
+     * value's toString method will be called, and the result will be quoted.
+     *
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     * @param value The value to be serialized.
+     * @return a printable, displayable, transmittable
+     *  representation of the object, beginning
+     *  with <code>{</code>&nbsp;<small>(left brace)</small> and ending
+     *  with <code>}</code>&nbsp;<small>(right brace)</small>.
+     * @throws JSONException If the value is or contains an invalid number.
+     */
+    public static String valueToString(Object value) throws JSONException {
+        if (value == null || value.equals(null)) {
+            return "null";
+        }
+        if (value instanceof JSONString) {
+            Object object;
+            try {
+                object = ((JSONString)value).toJSONString();
+            } catch (Exception e) {
+                throw new JSONException(e);
+            }
+            if (object instanceof String) {
+                return (String)object;
+            }
+            throw new JSONException("Bad value from toJSONString: " + object);
+        }
+        if (value instanceof Number) {
+            return numberToString((Number) value);
+        }
+        if (value instanceof Boolean || value instanceof JSONObject ||
+                value instanceof JSONArray) {
+            return value.toString();
+        }
+        if (value instanceof Map) {
+            return new JSONObject((Map)value).toString();
+        }
+        if (value instanceof Collection) {
+            return new JSONArray((Collection)value).toString();
+        }
+        if (value.getClass().isArray()) {
+            return new JSONArray(value).toString();
+        }
+        return quote(value.toString());
+    }
+
+     /**
+      * Wrap an object, if necessary. If the object is null, return the NULL
+      * object. If it is an array or collection, wrap it in a JSONArray. If
+      * it is a map, wrap it in a JSONObject. If it is a standard property
+      * (Double, String, et al) then it is already wrapped. Otherwise, if it
+      * comes from one of the java packages, turn it into a string. And if
+      * it doesn't, try to wrap it in a JSONObject. If the wrapping fails,
+      * then null is returned.
+      *
+      * @param object The object to wrap
+      * @return The wrapped value
+      */
+     public static Object wrap(Object object) {
+         try {
+             if (object == null) {
+                 return NULL;
+             }
+             if (object instanceof JSONObject || object instanceof JSONArray  ||
+                     NULL.equals(object)      || object instanceof JSONString ||
+                     object instanceof Byte   || object instanceof Character  ||
+                     object instanceof Short  || object instanceof Integer    ||
+                     object instanceof Long   || object instanceof Boolean    ||
+                     object instanceof Float  || object instanceof Double     ||
+                     object instanceof String || object instanceof Enum) {
+                 return object;
+             }
+
+             if (object instanceof Collection) {
+                 return new JSONArray((Collection)object);
+             }
+             if (object.getClass().isArray()) {
+                 return new JSONArray(object);
+             }
+             if (object instanceof Map) {
+                 return new JSONObject((Map)object);
+             }
+             Package objectPackage = object.getClass().getPackage();
+             String objectPackageName = objectPackage != null
+                 ? objectPackage.getName()
+                 : "";
+             if (
+                 objectPackageName.startsWith("java.") ||
+                 objectPackageName.startsWith("javax.") ||
+                 object.getClass().getClassLoader() == null
+             ) {
+                 return object.toString();
+             }
+             return new JSONObject(object);
+         } catch(Exception exception) {
+             return null;
+         }
+     }
+
+
+     /**
+      * Write the contents of the JSONObject as JSON text to a writer.
+      * For compactness, no whitespace is added.
+      * <p>
+      * Warning: This method assumes that the data structure is acyclical.
+      *
+      * @return The writer.
+      * @throws JSONException
+      */
+     public Writer write(Writer writer) throws JSONException {
+        return this.write(writer, 0, 0);
+    }
+
+
+    static final Writer writeValue(Writer writer, Object value,
+            int indentFactor, int indent) throws JSONException, IOException {
+        if (value == null || value.equals(null)) {
+            writer.write("null");
+        } else if (value instanceof JSONObject) {
+            ((JSONObject) value).write(writer, indentFactor, indent);
+        } else if (value instanceof JSONArray) {
+            ((JSONArray) value).write(writer, indentFactor, indent);
+        } else if (value instanceof Map) {
+            new JSONObject((Map) value).write(writer, indentFactor, indent);
+        } else if (value instanceof Collection) {
+            new JSONArray((Collection) value).write(writer, indentFactor,
+                    indent);
+        } else if (value.getClass().isArray()) {
+            new JSONArray(value).write(writer, indentFactor, indent);
+        } else if (value instanceof Number) {
+            writer.write(numberToString((Number) value));
+        } else if (value instanceof Boolean) {
+            writer.write(value.toString());
+        } else if (value instanceof JSONString) {
+            Object o;
+            try {
+                o = ((JSONString) value).toJSONString();
+            } catch (Exception e) {
+                throw new JSONException(e);
+            }
+            writer.write(o != null ? o.toString() : quote(value.toString()));
+        } else {
+            quote(value.toString(), writer);
+        }
+        return writer;
+    }
+
+    static final void indent(Writer writer, int indent) throws IOException {
+        for (int i = 0; i < indent; i += 1) {
+            writer.write(' ');
+        }
+    }
+
+    /**
+     * Write the contents of the JSONObject as JSON text to a writer. For
+     * compactness, no whitespace is added.
+     * <p>
+     * Warning: This method assumes that the data structure is acyclical.
+     *
+     * @return The writer.
+     * @throws JSONException
+     */
+    Writer write(Writer writer, int indentFactor, int indent)
+            throws JSONException {
+        try {
+            boolean commanate = false;
+            final int length = this.length();
+            Iterator keys = this.keys();
+            writer.write('{');
+
+            if (length == 1) {
+                Object key = keys.next();
+                writer.write(quote(key.toString()));
+                writer.write(':');
+                if (indentFactor > 0) {
+                    writer.write(' ');
+                }
+                writeValue(writer, this.map.get(key), indentFactor, indent);
+            } else if (length != 0) {
+                final int newindent = indent + indentFactor;
+                while (keys.hasNext()) {
+                    Object key = keys.next();
+                    if (commanate) {
+                        writer.write(',');
+                    }
+                    if (indentFactor > 0) {
+                        writer.write('\n');
+                    }
+                    indent(writer, newindent);
+                    writer.write(quote(key.toString()));
+                    writer.write(':');
+                    if (indentFactor > 0) {
+                        writer.write(' ');
+                    }
+                    writeValue(writer, this.map.get(key), indentFactor,
+                            newindent);
+                    commanate = true;
+                }
+                if (indentFactor > 0) {
+                    writer.write('\n');
+                }
+                indent(writer, indent);
+            }
+            writer.write('}');
+            return writer;
+        } catch (IOException exception) {
+            throw new JSONException(exception);
+        }
+     }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONString.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONString.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONString.java
new file mode 100644
index 0000000..f2fa2f3
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONString.java
@@ -0,0 +1,37 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+/**
+ * The <code>JSONString</code> interface allows a <code>toJSONString()</code> 
+ * method so that a class can change the behavior of 
+ * <code>JSONObject.toString()</code>, <code>JSONArray.toString()</code>,
+ * and <code>JSONWriter.value(</code>Object<code>)</code>. The 
+ * <code>toJSONString</code> method will be used instead of the default behavior 
+ * of using the Object's <code>toString()</code> method and quoting the result.
+ */
+public interface JSONString {
+    /**
+     * The <code>toJSONString</code> method allows a class to produce its own JSON 
+     * serialization. 
+     * 
+     * @return A strictly syntactically correct JSON text.
+     */
+    String toJSONString();
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONStringer.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONStringer.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONStringer.java
new file mode 100644
index 0000000..55c1230
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONStringer.java
@@ -0,0 +1,73 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.io.StringWriter;
+
+/**
+ * JSONStringer provides a quick and convenient way of producing JSON text.
+ * The texts produced strictly conform to JSON syntax rules. No whitespace is
+ * added, so the results are ready for transmission or storage. Each instance of
+ * JSONStringer can produce one JSON text.
+ * <p>
+ * A JSONStringer instance provides a <code>value</code> method for appending
+ * values to the
+ * text, and a <code>key</code>
+ * method for adding keys before values in objects. There are <code>array</code>
+ * and <code>endArray</code> methods that make and bound array values, and
+ * <code>object</code> and <code>endObject</code> methods which make and bound
+ * object values. All of these methods return the JSONWriter instance,
+ * permitting cascade style. For example, <pre>
+ * myString = new JSONStringer()
+ *     .object()
+ *         .key("JSON")
+ *         .value("Hello, World!")
+ *     .endObject()
+ *     .toString();</pre> which produces the string <pre>
+ * {"JSON":"Hello, World!"}</pre>
+ * <p>
+ * The first method called must be <code>array</code> or <code>object</code>.
+ * There are no methods for adding commas or colons. JSONStringer adds them for
+ * you. Objects and arrays can be nested up to 20 levels deep.
+ * <p>
+ * This can sometimes be easier than using a JSONObject to build a string.
+ * @author JSON.org
+ * @version 2008-09-18
+ */
+public class JSONStringer extends JSONWriter {
+    /**
+     * Make a fresh JSONStringer. It can be used to build one JSON text.
+     */
+    public JSONStringer() {
+        super(new StringWriter());
+    }
+
+    /**
+     * Return the JSON text. This method is used to obtain the product of the
+     * JSONStringer instance. It will return <code>null</code> if there was a
+     * problem in the construction of the JSON text (such as the calls to
+     * <code>array</code> were not properly balanced with calls to
+     * <code>endArray</code>).
+     * @return The JSON text.
+     */
+    public String toString() {
+        return this.mode == 'd' ? this.writer.toString() : null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONTokener.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONTokener.java
new file mode 100644
index 0000000..9050fb2
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONTokener.java
@@ -0,0 +1,441 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.io.BufferedReader;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.InputStreamReader;
+import java.io.Reader;
+import java.io.StringReader;
+
+/**
+ * A JSONTokener takes a source string and extracts characters and tokens from
+ * it. It is used by the JSONObject and JSONArray constructors to parse
+ * JSON source strings.
+ * @author JSON.org
+ * @version 2012-02-16
+ */
+public class JSONTokener {
+
+    private long    character;
+    private boolean eof;
+    private long    index;
+    private long    line;
+    private char    previous;
+    private Reader  reader;
+    private boolean usePrevious;
+
+
+    /**
+     * Construct a JSONTokener from a Reader.
+     *
+     * @param reader     A reader.
+     */
+    public JSONTokener(Reader reader) {
+        this.reader = reader.markSupported()
+            ? reader
+            : new BufferedReader(reader);
+        this.eof = false;
+        this.usePrevious = false;
+        this.previous = 0;
+        this.index = 0;
+        this.character = 1;
+        this.line = 1;
+    }
+
+
+    /**
+     * Construct a JSONTokener from an InputStream.
+     */
+    public JSONTokener(InputStream inputStream) throws JSONException {
+        this(new InputStreamReader(inputStream));
+    }
+
+
+    /**
+     * Construct a JSONTokener from a string.
+     *
+     * @param s     A source string.
+     */
+    public JSONTokener(String s) {
+        this(new StringReader(s));
+    }
+
+
+    /**
+     * Back up one character. This provides a sort of lookahead capability,
+     * so that you can test for a digit or letter before attempting to parse
+     * the next number or identifier.
+     */
+    public void back() throws JSONException {
+        if (this.usePrevious || this.index <= 0) {
+            throw new JSONException("Stepping back two steps is not supported");
+        }
+        this.index -= 1;
+        this.character -= 1;
+        this.usePrevious = true;
+        this.eof = false;
+    }
+
+
+    /**
+     * Get the hex value of a character (base16).
+     * @param c A character between '0' and '9' or between 'A' and 'F' or
+     * between 'a' and 'f'.
+     * @return  An int between 0 and 15, or -1 if c was not a hex digit.
+     */
+    public static int dehexchar(char c) {
+        if (c >= '0' && c <= '9') {
+            return c - '0';
+        }
+        if (c >= 'A' && c <= 'F') {
+            return c - ('A' - 10);
+        }
+        if (c >= 'a' && c <= 'f') {
+            return c - ('a' - 10);
+        }
+        return -1;
+    }
+
+    public boolean end() {
+        return this.eof && !this.usePrevious;
+    }
+
+
+    /**
+     * Determine if the source string still contains characters that next()
+     * can consume.
+     * @return true if not yet at the end of the source.
+     */
+    public boolean more() throws JSONException {
+        this.next();
+        if (this.end()) {
+            return false;
+        }
+        this.back();
+        return true;
+    }
+
+
+    /**
+     * Get the next character in the source string.
+     *
+     * @return The next character, or 0 if past the end of the source string.
+     */
+    public char next() throws JSONException {
+        int c;
+        if (this.usePrevious) {
+            this.usePrevious = false;
+            c = this.previous;
+        } else {
+            try {
+                c = this.reader.read();
+            } catch (IOException exception) {
+                throw new JSONException(exception);
+            }
+
+            if (c <= 0) { // End of stream
+                this.eof = true;
+                c = 0;
+            }
+        }
+        this.index += 1;
+        if (this.previous == '\r') {
+            this.line += 1;
+            this.character = c == '\n' ? 0 : 1;
+        } else if (c == '\n') {
+            this.line += 1;
+            this.character = 0;
+        } else {
+            this.character += 1;
+        }
+        this.previous = (char) c;
+        return this.previous;
+    }
+
+
+    /**
+     * Consume the next character, and check that it matches a specified
+     * character.
+     * @param c The character to match.
+     * @return The character.
+     * @throws JSONException if the character does not match.
+     */
+    public char next(char c) throws JSONException {
+        char n = this.next();
+        if (n != c) {
+            throw this.syntaxError("Expected '" + c + "' and instead saw '" +
+                    n + "'");
+        }
+        return n;
+    }
+
+
+    /**
+     * Get the next n characters.
+     *
+     * @param n     The number of characters to take.
+     * @return      A string of n characters.
+     * @throws JSONException
+     *   Substring bounds error if there are not
+     *   n characters remaining in the source string.
+     */
+     public String next(int n) throws JSONException {
+         if (n == 0) {
+             return "";
+         }
+
+         char[] chars = new char[n];
+         int pos = 0;
+
+         while (pos < n) {
+             chars[pos] = this.next();
+             if (this.end()) {
+                 throw this.syntaxError("Substring bounds error");
+             }
+             pos += 1;
+         }
+         return new String(chars);
+     }
+
+
+    /**
+     * Get the next char in the string, skipping whitespace.
+     * @throws JSONException
+     * @return  A character, or 0 if there are no more characters.
+     */
+    public char nextClean() throws JSONException {
+        for (;;) {
+            char c = this.next();
+            if (c == 0 || c > ' ') {
+                return c;
+            }
+        }
+    }
+
+
+    /**
+     * Return the characters up to the next close quote character.
+     * Backslash processing is done. The formal JSON format does not
+     * allow strings in single quotes, but an implementation is allowed to
+     * accept them.
+     * @param quote The quoting character, either
+     *      <code>"</code>&nbsp;<small>(double quote)</small> or
+     *      <code>'</code>&nbsp;<small>(single quote)</small>.
+     * @return      A String.
+     * @throws JSONException Unterminated string.
+     */
+    public String nextString(char quote) throws JSONException {
+        char c;
+        StringBuffer sb = new StringBuffer();
+        for (;;) {
+            c = this.next();
+            switch (c) {
+            case 0:
+            case '\n':
+            case '\r':
+                throw this.syntaxError("Unterminated string");
+            case '\\':
+                c = this.next();
+                switch (c) {
+                case 'b':
+                    sb.append('\b');
+                    break;
+                case 't':
+                    sb.append('\t');
+                    break;
+                case 'n':
+                    sb.append('\n');
+                    break;
+                case 'f':
+                    sb.append('\f');
+                    break;
+                case 'r':
+                    sb.append('\r');
+                    break;
+                case 'u':
+                    sb.append((char)Integer.parseInt(this.next(4), 16));
+                    break;
+                case '"':
+                case '\'':
+                case '\\':
+                case '/':
+                    sb.append(c);
+                    break;
+                default:
+                    throw this.syntaxError("Illegal escape.");
+                }
+                break;
+            default:
+                if (c == quote) {
+                    return sb.toString();
+                }
+                sb.append(c);
+            }
+        }
+    }
+
+
+    /**
+     * Get the text up but not including the specified character or the
+     * end of line, whichever comes first.
+     * @param  delimiter A delimiter character.
+     * @return   A string.
+     */
+    public String nextTo(char delimiter) throws JSONException {
+        StringBuffer sb = new StringBuffer();
+        for (;;) {
+            char c = this.next();
+            if (c == delimiter || c == 0 || c == '\n' || c == '\r') {
+                if (c != 0) {
+                    this.back();
+                }
+                return sb.toString().trim();
+            }
+            sb.append(c);
+        }
+    }
+
+
+    /**
+     * Get the text up but not including one of the specified delimiter
+     * characters or the end of line, whichever comes first.
+     * @param delimiters A set of delimiter characters.
+     * @return A string, trimmed.
+     */
+    public String nextTo(String delimiters) throws JSONException {
+        char c;
+        StringBuffer sb = new StringBuffer();
+        for (;;) {
+            c = this.next();
+            if (delimiters.indexOf(c) >= 0 || c == 0 ||
+                    c == '\n' || c == '\r') {
+                if (c != 0) {
+                    this.back();
+                }
+                return sb.toString().trim();
+            }
+            sb.append(c);
+        }
+    }
+
+
+    /**
+     * Get the next value. The value can be a Boolean, Double, Integer,
+     * JSONArray, JSONObject, Long, or String, or the JSONObject.NULL object.
+     * @throws JSONException If syntax error.
+     *
+     * @return An object.
+     */
+    public Object nextValue() throws JSONException {
+        char c = this.nextClean();
+        String string;
+
+        switch (c) {
+            case '"':
+            case '\'':
+                return this.nextString(c);
+            case '{':
+                this.back();
+                return new JSONObject(this);
+            case '[':
+                this.back();
+                return new JSONArray(this);
+        }
+
+        /*
+         * Handle unquoted text. This could be the values true, false, or
+         * null, or it can be a number. An implementation (such as this one)
+         * is allowed to also accept non-standard forms.
+         *
+         * Accumulate characters until we reach the end of the text or a
+         * formatting character.
+         */
+
+        StringBuffer sb = new StringBuffer();
+        while (c >= ' ' && ",:]}/\\\"[{;=#".indexOf(c) < 0) {
+            sb.append(c);
+            c = this.next();
+        }
+        this.back();
+
+        string = sb.toString().trim();
+        if ("".equals(string)) {
+            throw this.syntaxError("Missing value");
+        }
+        return JSONObject.stringToValue(string);
+    }
+
+
+    /**
+     * Skip characters until the next character is the requested character.
+     * If the requested character is not found, no characters are skipped.
+     * @param to A character to skip to.
+     * @return The requested character, or zero if the requested character
+     * is not found.
+     */
+    public char skipTo(char to) throws JSONException {
+        char c;
+        try {
+            long startIndex = this.index;
+            long startCharacter = this.character;
+            long startLine = this.line;
+            this.reader.mark(1000000);
+            do {
+                c = this.next();
+                if (c == 0) {
+                    this.reader.reset();
+                    this.index = startIndex;
+                    this.character = startCharacter;
+                    this.line = startLine;
+                    return c;
+                }
+            } while (c != to);
+        } catch (IOException exc) {
+            throw new JSONException(exc);
+        }
+
+        this.back();
+        return c;
+    }
+
+
+    /**
+     * Make a JSONException to signal a syntax error.
+     *
+     * @param message The error message.
+     * @return  A JSONException object, suitable for throwing
+     */
+    public JSONException syntaxError(String message) {
+        return new JSONException(message + this.toString());
+    }
+
+
+    /**
+     * Make a printable string of this JSONTokener.
+     *
+     * @return " at {index} [character {character} line {line}]"
+     */
+    public String toString() {
+        return " at " + this.index + " [character " + this.character + " line " +
+            this.line + "]";
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONWriter.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONWriter.java
new file mode 100644
index 0000000..2399d4d
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/JSONWriter.java
@@ -0,0 +1,322 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.io.IOException;
+import java.io.Writer;
+
+/**
+ * JSONWriter provides a quick and convenient way of producing JSON text.
+ * The texts produced strictly conform to JSON syntax rules. No whitespace is
+ * added, so the results are ready for transmission or storage. Each instance of
+ * JSONWriter can produce one JSON text.
+ * <p>
+ * A JSONWriter instance provides a <code>value</code> method for appending
+ * values to the
+ * text, and a <code>key</code>
+ * method for adding keys before values in objects. There are <code>array</code>
+ * and <code>endArray</code> methods that make and bound array values, and
+ * <code>object</code> and <code>endObject</code> methods which make and bound
+ * object values. All of these methods return the JSONWriter instance,
+ * permitting a cascade style. For example, <pre>
+ * new JSONWriter(myWriter)
+ *     .object()
+ *         .key("JSON")
+ *         .value("Hello, World!")
+ *     .endObject();</pre> which writes <pre>
+ * {"JSON":"Hello, World!"}</pre>
+ * <p>
+ * The first method called must be <code>array</code> or <code>object</code>.
+ * There are no methods for adding commas or colons. JSONWriter adds them for
+ * you. Objects and arrays can be nested up to 20 levels deep.
+ * <p>
+ * This can sometimes be easier than using a JSONObject to build a string.
+ * @author JSON.org
+ * @version 2011-11-24
+ */
+public class JSONWriter {
+    private static final int maxdepth = 200;
+
+    /**
+     * The comma flag determines if a comma should be output before the next
+     * value.
+     */
+    private boolean comma;
+
+    /**
+     * The current mode. Values:
+     * 'a' (array),
+     * 'd' (done),
+     * 'i' (initial),
+     * 'k' (key),
+     * 'o' (object).
+     */
+    protected char mode;
+
+    /**
+     * The object/array stack.
+     */
+    private final JSONObject stack[];
+
+    /**
+     * The stack top index. A value of 0 indicates that the stack is empty.
+     */
+    private int top;
+
+    /**
+     * The writer that will receive the output.
+     */
+    protected Writer writer;
+
+    /**
+     * Make a fresh JSONWriter. It can be used to build one JSON text.
+     */
+    public JSONWriter(Writer w) {
+        this.comma = false;
+        this.mode = 'i';
+        this.stack = new JSONObject[maxdepth];
+        this.top = 0;
+        this.writer = w;
+    }
+
+    /**
+     * Append a value.
+     * @param string A string value.
+     * @return this
+     * @throws JSONException If the value is out of sequence.
+     */
+    private JSONWriter append(String string) throws JSONException {
+        if (string == null) {
+            throw new JSONException("Null pointer");
+        }
+        if (this.mode == 'o' || this.mode == 'a') {
+            try {
+                if (this.comma && this.mode == 'a') {
+                    this.writer.write(',');
+                }
+                this.writer.write(string);
+            } catch (IOException e) {
+                throw new JSONException(e);
+            }
+            if (this.mode == 'o') {
+                this.mode = 'k';
+            }
+            this.comma = true;
+            return this;
+        }
+        throw new JSONException("Value out of sequence.");
+    }
+
+    /**
+     * Begin appending a new array. All values until the balancing
+     * <code>endArray</code> will be appended to this array. The
+     * <code>endArray</code> method must be called to mark the array's end.
+     * @return this
+     * @throws JSONException If the nesting is too deep, or if the object is
+     * started in the wrong place (for example as a key or after the end of the
+     * outermost array or object).
+     */
+    public JSONWriter array() throws JSONException {
+        if (this.mode == 'i' || this.mode == 'o' || this.mode == 'a') {
+            this.push(null);
+            this.append("[");
+            this.comma = false;
+            return this;
+        }
+        throw new JSONException("Misplaced array.");
+    }
+
+    /**
+     * End something.
+     * @param mode Mode
+     * @param c Closing character
+     * @return this
+     * @throws JSONException If unbalanced.
+     */
+    private JSONWriter end(char mode, char c) throws JSONException {
+        if (this.mode != mode) {
+            throw new JSONException(mode == 'a'
+                ? "Misplaced endArray."
+                : "Misplaced endObject.");
+        }
+        this.pop(mode);
+        try {
+            this.writer.write(c);
+        } catch (IOException e) {
+            throw new JSONException(e);
+        }
+        this.comma = true;
+        return this;
+    }
+
+    /**
+     * End an array. This method most be called to balance calls to
+     * <code>array</code>.
+     * @return this
+     * @throws JSONException If incorrectly nested.
+     */
+    public JSONWriter endArray() throws JSONException {
+        return this.end('a', ']');
+    }
+
+    /**
+     * End an object. This method most be called to balance calls to
+     * <code>object</code>.
+     * @return this
+     * @throws JSONException If incorrectly nested.
+     */
+    public JSONWriter endObject() throws JSONException {
+        return this.end('k', '}');
+    }
+
+    /**
+     * Append a key. The key will be associated with the next value. In an
+     * object, every value must be preceded by a key.
+     * @param string A key string.
+     * @return this
+     * @throws JSONException If the key is out of place. For example, keys
+     *  do not belong in arrays or if the key is null.
+     */
+    public JSONWriter key(String string) throws JSONException {
+        if (string == null) {
+            throw new JSONException("Null key.");
+        }
+        if (this.mode == 'k') {
+            try {
+                this.stack[this.top - 1].putOnce(string, Boolean.TRUE);
+                if (this.comma) {
+                    this.writer.write(',');
+                }
+                this.writer.write(JSONObject.quote(string));
+                this.writer.write(':');
+                this.comma = false;
+                this.mode = 'o';
+                return this;
+            } catch (IOException e) {
+                throw new JSONException(e);
+            }
+        }
+        throw new JSONException("Misplaced key.");
+    }
+
+
+    /**
+     * Begin appending a new object. All keys and values until the balancing
+     * <code>endObject</code> will be appended to this object. The
+     * <code>endObject</code> method must be called to mark the object's end.
+     * @return this
+     * @throws JSONException If the nesting is too deep, or if the object is
+     * started in the wrong place (for example as a key or after the end of the
+     * outermost array or object).
+     */
+    public JSONWriter object() throws JSONException {
+        if (this.mode == 'i') {
+            this.mode = 'o';
+        }
+        if (this.mode == 'o' || this.mode == 'a') {
+            this.append("{");
+            this.push(new JSONObject());
+            this.comma = false;
+            return this;
+        }
+        throw new JSONException("Misplaced object.");
+
+    }
+
+
+    /**
+     * Pop an array or object scope.
+     * @param c The scope to close.
+     * @throws JSONException If nesting is wrong.
+     */
+    private void pop(char c) throws JSONException {
+        if (this.top <= 0) {
+            throw new JSONException("Nesting error.");
+        }
+        char m = this.stack[this.top - 1] == null ? 'a' : 'k';
+        if (m != c) {
+            throw new JSONException("Nesting error.");
+        }
+        this.top -= 1;
+        this.mode = this.top == 0
+            ? 'd'
+            : this.stack[this.top - 1] == null
+            ? 'a'
+            : 'k';
+    }
+
+    /**
+     * Push an array or object scope.
+     * @param jo The scope to open.
+     * @throws JSONException If nesting is too deep.
+     */
+    private void push(JSONObject jo) throws JSONException {
+        if (this.top >= maxdepth) {
+            throw new JSONException("Nesting too deep.");
+        }
+        this.stack[this.top] = jo;
+        this.mode = jo == null ? 'a' : 'k';
+        this.top += 1;
+    }
+
+
+    /**
+     * Append either the value <code>true</code> or the value
+     * <code>false</code>.
+     * @param b A boolean.
+     * @return this
+     * @throws JSONException
+     */
+    public JSONWriter value(boolean b) throws JSONException {
+        return this.append(b ? "true" : "false");
+    }
+
+    /**
+     * Append a double value.
+     * @param d A double.
+     * @return this
+     * @throws JSONException If the number is not finite.
+     */
+    public JSONWriter value(double d) throws JSONException {
+        return this.value(new Double(d));
+    }
+
+    /**
+     * Append a long value.
+     * @param l A long.
+     * @return this
+     * @throws JSONException
+     */
+    public JSONWriter value(long l) throws JSONException {
+        return this.append(Long.toString(l));
+    }
+
+
+    /**
+     * Append an object value.
+     * @param object The object to append. It can be null, or a Boolean, Number,
+     *   String, JSONObject, or JSONArray, or an object that implements JSONString.
+     * @return this
+     * @throws JSONException If the value is out of sequence.
+     */
+    public JSONWriter value(Object object) throws JSONException {
+        return this.append(JSONObject.valueToString(object));
+    }
+}


[82/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/app/OrdersCacheListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/app/OrdersCacheListener.java b/geode-core/src/test/java/org/company/app/OrdersCacheListener.java
deleted file mode 100755
index ec91dcb..0000000
--- a/geode-core/src/test/java/org/company/app/OrdersCacheListener.java
+++ /dev/null
@@ -1,51 +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 com.company.app;
-
-import org.apache.geode.cache.*;
-
-/**
- * com.company.app.OrdersCacheListener. Cache listener impl for CacheXmlxxTest
- *
- * @since GemFire 5.0
- */
-public class OrdersCacheListener implements CacheListener, Declarable {
-
-  public OrdersCacheListener() {}
-
-  public void afterCreate(EntryEvent event) {}
-
-  public void afterUpdate(EntryEvent event) {}
-
-  public void afterInvalidate(EntryEvent event) {}
-
-  public void afterDestroy(EntryEvent event) {}
-
-  public void afterRegionInvalidate(RegionEvent event) {}
-
-  public void afterRegionDestroy(RegionEvent event) {}
-
-  public void afterRegionClear(RegionEvent event) {}
-  
-  public void afterRegionCreate(RegionEvent event) {}
-  
-  public void afterRegionLive(RegionEvent event) {}
-  
-  public void close() {}
-  
-  public void init(java.util.Properties props) {}
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/data/DatabaseLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/data/DatabaseLoader.java b/geode-core/src/test/java/org/company/data/DatabaseLoader.java
deleted file mode 100644
index 84b1c70..0000000
--- a/geode-core/src/test/java/org/company/data/DatabaseLoader.java
+++ /dev/null
@@ -1,42 +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 com.company.data;
-
-import org.apache.geode.cache.*;
-
-/**
- * A <code>CacheLoader</code> that is <code>Declarable</code>
- *
- * @since GemFire 3.2.1
- */
-public class DatabaseLoader implements CacheLoader, Declarable {
-
-  public Object load(LoaderHelper helper)
-    throws CacheLoaderException {
-
-    throw new UnsupportedOperationException("I do NOTHING");
-  }
-
-  public void init(java.util.Properties props) {
-
-  }
-
-  public void close() {
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/data/MyDeclarable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/data/MyDeclarable.java b/geode-core/src/test/java/org/company/data/MyDeclarable.java
deleted file mode 100644
index 0545c26..0000000
--- a/geode-core/src/test/java/org/company/data/MyDeclarable.java
+++ /dev/null
@@ -1,32 +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 com.company.data;
-
-import org.apache.geode.cache.*;
-
-/**
- * A <code>Declarable</code> object
- *
- * @since GemFire 3.2.1
- */
-public class MyDeclarable implements Declarable {
-
-  public void init(java.util.Properties props) {
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/data/MySizer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/data/MySizer.java b/geode-core/src/test/java/org/company/data/MySizer.java
deleted file mode 100644
index 30e5e16..0000000
--- a/geode-core/src/test/java/org/company/data/MySizer.java
+++ /dev/null
@@ -1,39 +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 com.company.data;
-/**
- * A <code>Declarable</code> <code>ObjectSizer</code> for used for XML testing
- *
- * @since GemFire 5.0
- */
-import java.util.Properties;
-
-import org.apache.geode.cache.Declarable;
-import org.apache.geode.cache.util.ObjectSizer;
-
-public class MySizer implements ObjectSizer, Declarable {
-
-  String name;
-
-  public int sizeof( Object o ) {
-    return ObjectSizer.DEFAULT.sizeof(o);
-  }
-
-  public void init(Properties props) {
-      this.name = props.getProperty("name", "defaultName");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/company/data/MyTransactionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/company/data/MyTransactionListener.java b/geode-core/src/test/java/org/company/data/MyTransactionListener.java
deleted file mode 100644
index 074e12d..0000000
--- a/geode-core/src/test/java/org/company/data/MyTransactionListener.java
+++ /dev/null
@@ -1,38 +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 com.company.data;
-
-import org.apache.geode.cache.*;
-
-/**
- * A <code>TransactionListener</code> that is <code>Declarable</code>
- *
- * @since GemFire 4.0
- */
-public class MyTransactionListener implements TransactionListener, Declarable {
-
-  public void afterCommit(TransactionEvent event) {}
-    
-  public void afterFailedCommit(TransactionEvent event) {}
-
-  public void afterRollback(TransactionEvent event) {}
-
-  public void init(java.util.Properties props) {}
-
-  public void close() {}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/LinkNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/LinkNode.java b/geode-core/src/test/java/org/examples/LinkNode.java
deleted file mode 100644
index 97a0438..0000000
--- a/geode-core/src/test/java/org/examples/LinkNode.java
+++ /dev/null
@@ -1,77 +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 com.examples;
-
-/**
- * A node in a linked list that is used to test that serializing
- * non-<code>Serializable</code> objects handle back references
- * correctly. 
- *
- *
- * @since GemFire 3.5
- */
-public class LinkNode {
-
-  /** The value of this LinkNode */
-  private int value;
-
-  /** An object value in this LinkNode */
-  public Object object;
-
-  /** The next node in the chain */
-  public LinkNode next;
-
-  /**
-   * Creates a new <code>LinkNode</code> with the given value
-   */
-  public LinkNode(int value) {
-    this.value = value;
-  }
-
-  /**
-   * Two <code>LinkNode</code>s are equal if they have the same
-   * <code>value</code> and their <code>next</code> node have the same
-   * value.
-   */
-  public boolean equals(Object o) {
-    if (!(o instanceof LinkNode)) {
-      return false;
-    }
-
-    LinkNode other = (LinkNode) o;
-    if (this.value != other.value) {
-      return false;
-
-    } else if (this.next == null) {
-      return other.next == null;
-
-    } else if (other.next == null) {
-      return this.next == null;
-
-    } else if (other.next.value != this.next.value) {
-      return false;
-
-    } else if (this.object != null) {
-      return this.object.equals(other.object);
-
-    } else {
-      return other.object == null;
-    }
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/SuperClass.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/SuperClass.java b/geode-core/src/test/java/org/examples/SuperClass.java
deleted file mode 100644
index 6c6076f..0000000
--- a/geode-core/src/test/java/org/examples/SuperClass.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 com.examples;
-
-import java.util.*;
-
-/**
- * The super class of another class.  Neither is
- * <code>Serializable</code>. 
- *
- *
- * @since GemFire 3.5
- */
-public class SuperClass {
-
-  protected int intValue;
-  protected HashMap map;
-
-  /**
-   * Creates a new <code>SuperClass</code>
-   */
-  protected SuperClass() {
-    this.intValue = 42;
-    this.map = new HashMap();
-    map.put("one", new Integer(1));
-    map.put("two", new Integer(2));
-    map.put("three", new Integer(3));
-    map.put("four", new Integer(4));
-  }
-
-
-  public static class SubClass extends SuperClass {
-
-    protected Map anotherMap;
-    protected long longValue;
-
-    /**
-     * Creates a new <code>SubClass</code>
-     */
-    public SubClass() {
-      super();
-
-      this.longValue = 28L;
-      this.anotherMap = new HashMap();
-      this.anotherMap.put("five", new Integer(5));
-      this.anotherMap.put("six", new Integer(6));
-      this.anotherMap.put("seven", new Integer(7));
-      this.anotherMap.put("eight", new Integer(8));
-    }
-
-    public boolean equals(Object o) {
-      if (!(o instanceof SubClass)) {
-        return false;
-      }
-
-      SubClass other = (SubClass) o;
-      if (this.intValue != other.intValue) {
-        return false;
-
-      } else if (!this.map.equals(other.map)) {
-        return false;
-
-      } else if (this.longValue != other.longValue) {
-        return false;
-
-      } else if (!this.anotherMap.equals(other.anotherMap)) {
-        return false;
-
-      } else {
-        return true;
-      }
-    }
-
-  }
-
-
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/TestObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/TestObject.java b/geode-core/src/test/java/org/examples/TestObject.java
deleted file mode 100644
index 9b871a7..0000000
--- a/geode-core/src/test/java/org/examples/TestObject.java
+++ /dev/null
@@ -1,54 +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 com.examples;
-
-/**
- * A simple test object used by the 
- * org.apache.geode.internal.enhancer.serializer.SerializingStreamPerfTest 
- * (this test no longer exists?) 
- * that must be in a non-<code>org.apache</code> package.
- *
- *
- * @since GemFire 3.5
- */
-public class TestObject {
-
-  private int intField;
-  private String stringField;
-  private Object objectField;
-
-  /**
-   * Creates a new <code>TestObject</code>
-   */
-  public TestObject() {
-    this.intField = 42;
-    this.stringField = "123456789012345678901234567890";
-    this.objectField = new Integer(67);
-  }
-
-  //////////////////////  Inner Classes  //////////////////////
-
-  /**
-   * A <code>Serializable</code> object that is serialized
-   */
-  public static class SerializableTestObject extends TestObject
-    implements java.io.Serializable {
-    
-  }
-  
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/Address.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/Address.java b/geode-core/src/test/java/org/examples/ds/Address.java
deleted file mode 100644
index 5a82531..0000000
--- a/geode-core/src/test/java/org/examples/ds/Address.java
+++ /dev/null
@@ -1,23 +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 com.examples.ds;
-
-import java.io.Serializable;
-
-public class Address implements Serializable {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/Company.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/Company.java b/geode-core/src/test/java/org/examples/ds/Company.java
deleted file mode 100644
index 6fc93ee..0000000
--- a/geode-core/src/test/java/org/examples/ds/Company.java
+++ /dev/null
@@ -1,43 +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 com.examples.ds;
-
-public class Company {
-
-  /** The name of this company */
-  private String name;
-
-  /** The address of this company */
-  private Address address;
-
-  /**
-   * Creates a new company
-   */
-  public Company(String name, Address address) {
-    this.name = name;
-    this.address = address;
-  }
-
-  public String getName() {
-    return this.name;
-  }
-
-  public Address getAddress() {
-    return this.address;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/CompanySerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/CompanySerializer.java b/geode-core/src/test/java/org/examples/ds/CompanySerializer.java
deleted file mode 100644
index 9d69083..0000000
--- a/geode-core/src/test/java/org/examples/ds/CompanySerializer.java
+++ /dev/null
@@ -1,67 +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 com.examples.ds;
-
-import org.apache.geode.DataSerializer;
-import java.io.*;
-
-public class CompanySerializer extends DataSerializer {
-
-  static {
-    DataSerializer.register(CompanySerializer.class);
-  }
-
-  /**
-   * May be invoked reflectively if instances of Company are
-   * distributed to other VMs.
-   */
-  public CompanySerializer() {
-
-  }
-
-  public int getId() {
-    return 42;
-  }
-  
-  public Class[] getSupportedClasses() {
-    return new Class[] { Company.class };
-  }
-
-  public boolean toData(Object o, DataOutput out)
-    throws IOException {
-    if (o instanceof Company) {
-      Company company = (Company) o;
-      out.writeUTF(company.getName());
-
-      // Let's assume that Address is java.io.Serializable
-      Address address = company.getAddress();
-      writeObject(address, out);
-      return true;
-
-    } else {
-      return false;
-    }
-  }
-
-  public Object fromData(DataInput in)
-    throws IOException, ClassNotFoundException {
-
-    String name = in.readUTF();
-    Address address = (Address) readObject(in);
-    return new Company(name, address);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/Employee.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/Employee.java b/geode-core/src/test/java/org/examples/ds/Employee.java
deleted file mode 100644
index 9165e34..0000000
--- a/geode-core/src/test/java/org/examples/ds/Employee.java
+++ /dev/null
@@ -1,53 +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 com.examples.ds;
-
-import org.apache.geode.DataSerializable;
-import org.apache.geode.DataSerializer;
-import java.io.*;
-import java.util.Date;
-
-public class Employee implements DataSerializable {
-  private int id;
-  private String name;
-  private Date birthday;
-  private Company employer;
-
-  public Employee(int id, String name, Date birthday,
-                  Company employer){
-    this.id = id;
-    this.name = name;
-    this.birthday = birthday;
-    this.employer = employer;
-  }
-
-  public void toData(DataOutput out) throws IOException {
-    out.writeInt(this.id);
-    out.writeUTF(this.name);
-    DataSerializer.writeDate(this.birthday, out);
-    DataSerializer.writeObject(this.employer, out);
-  }
-
-  public void fromData(DataInput in) 
-    throws IOException, ClassNotFoundException {
-
-    this.id = in.readInt();
-    this.name = in.readUTF();
-    this.birthday = DataSerializer.readDate(in);
-    this.employer = (Company) DataSerializer.readObject(in);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/PutDataSerializables.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/PutDataSerializables.java b/geode-core/src/test/java/org/examples/ds/PutDataSerializables.java
deleted file mode 100644
index 162ce5a..0000000
--- a/geode-core/src/test/java/org/examples/ds/PutDataSerializables.java
+++ /dev/null
@@ -1,54 +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 com.examples.ds;
-
-import org.apache.geode.cache.*;
-import org.apache.geode.distributed.DistributedSystem;
-import java.util.Date;
-import java.util.Properties;
-
-/**
- * Places various objects that use {@link org.apache.geode.DataSerializer}s 
- * and {@link org.apache.geode.Instantiator}s into a cache {@link Region}.  
- * Among other things, this is used to test bug 31573.
- *
- * @since GemFire 3.5
- */
-public class PutDataSerializables {
-
-  public static void main(String[] args) throws Throwable {
-    Properties props = new Properties();
-    DistributedSystem system = DistributedSystem.connect(props);
-    Cache cache = CacheFactory.create(system);
-    AttributesFactory factory = new AttributesFactory();
-    Region region =
-      cache.createRegion("DataSerializable",
-                           factory.create());
-    region.put("User", new User("Fred", 42));
-
-    new CompanySerializer();
-    Address address = new Address();
-    Company company = new Company("My Company", address);
-
-    region.put("Company", company);
-    region.put("Employee",
-               new Employee(43, "Bob", new Date(), company));
-
-    Thread.sleep(60 * 1000);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/ds/User.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/ds/User.java b/geode-core/src/test/java/org/examples/ds/User.java
deleted file mode 100644
index 4bf4531..0000000
--- a/geode-core/src/test/java/org/examples/ds/User.java
+++ /dev/null
@@ -1,58 +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 com.examples.ds;
-
-import org.apache.geode.DataSerializable;
-import org.apache.geode.Instantiator;
-import java.io.*;
-
-public class User implements DataSerializable {
-  private String name;
-  private int userId;
-
-  static {
-    Instantiator.register(new Instantiator(User.class, (byte) 45) {
-        public DataSerializable newInstance() {
-          return new User();
-        }
-      });
-  }
-
-  public User(String name, int userId) {
-    this.name = name;
-    this.userId = userId;
-  }
-
-  /**
-   * Creates an "empty" User whose contents are filled in by
-   * invoking its toData() method
-   */
-  protected User() {
-
-  }
-
-  public void toData(DataOutput out) throws IOException {
-    out.writeUTF(this.name);
-    out.writeInt(this.userId);
-  }
-
-  public void fromData(DataInput in)
-    throws IOException, ClassNotFoundException {
-    this.name = in.readUTF();
-    this.userId = in.readInt();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyDataSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyDataSerializer.java b/geode-core/src/test/java/org/examples/snapshot/MyDataSerializer.java
deleted file mode 100644
index 0b8d9e6..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyDataSerializer.java
+++ /dev/null
@@ -1,63 +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 com.examples.snapshot;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.io.IOException;
-
-import org.apache.geode.DataSerializer;
-
-public class MyDataSerializer extends DataSerializer {
-  @Override
-  public Class<?>[] getSupportedClasses() {
-    return new Class[] { MyObjectDataSerializable2.class};
-  }
-
-  @Override
-  public boolean toData(Object o, DataOutput out) throws IOException {
-    MyObject obj = (MyObject) o;
-    out.writeLong(obj.f1);
-    out.writeUTF(obj.f2);
-    
-    return true;
-  }
-
-  @Override
-  public Object fromData(DataInput in) throws IOException,
-      ClassNotFoundException {
-    MyObjectDataSerializable2 obj = new MyObjectDataSerializable2();
-    obj.f1 = in.readLong();
-    obj.f2 = in.readUTF();
-    
-    return obj;
-  }
-
-  @Override
-  public int getId() {
-    return 8892;
-  }
-  
-  public static class MyObjectDataSerializable2 extends MyObject {
-    public MyObjectDataSerializable2() {
-    }
-
-    public MyObjectDataSerializable2(long number, String s) {
-      super(number, s);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyObject.java b/geode-core/src/test/java/org/examples/snapshot/MyObject.java
deleted file mode 100644
index aaada9d..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyObject.java
+++ /dev/null
@@ -1,68 +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 com.examples.snapshot;
-
-import java.io.Serializable;
-
-import org.apache.geode.pdx.PdxInstance;
-
-/**
- * Data class for testing snapshots, cannot be located in org.apache.*.
- * 
- */
-public class MyObject implements Serializable {
-  protected long f1;
-  protected String f2;
-  
-  public MyObject() {
-  }
-
-  public MyObject(long number, String s) {
-    f1 = number;
-    f2 = s;
-  }
-  
-  public long getF1() {
-    return f1;
-  }
-  
-  public String getF2() {
-    return f2;
-  }
-  
-  @Override
-  public boolean equals(Object o) {
-    if (o instanceof MyObject) {
-      MyObject obj = (MyObject) o;
-      return f1 == obj.f1 && f2.equals(obj.f2);
-
-    } else if (o instanceof PdxInstance) {
-      PdxInstance pdx = (PdxInstance) o;
-      return pdx.getField("f1").equals(f1) && pdx.getField("f2").equals(f2);
-    }
-    return false;
-  }
-  
-  @Override
-  public int hashCode() {
-    return (int) (17 * f1 ^ f2.hashCode());
-  }
-  
-  public String toString() {
-    return f1 + "-" + f2;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyObjectDataSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyObjectDataSerializable.java b/geode-core/src/test/java/org/examples/snapshot/MyObjectDataSerializable.java
deleted file mode 100644
index 1582744..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyObjectDataSerializable.java
+++ /dev/null
@@ -1,45 +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 com.examples.snapshot;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.io.IOException;
-
-import org.apache.geode.DataSerializable;
-
-public class MyObjectDataSerializable extends MyObject implements DataSerializable {
-  public MyObjectDataSerializable() {
-  }
-
-  public MyObjectDataSerializable(long number, String s) {
-    super(number, s);
-  }
-  
-  @Override
-  public void toData(DataOutput out) throws IOException {
-    out.writeLong(f1);
-    out.writeUTF(f2);
-  }
-
-  @Override
-  public void fromData(DataInput in) throws IOException,
-      ClassNotFoundException {
-    f1 = in.readLong();
-    f2 = in.readUTF();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyObjectPdx.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyObjectPdx.java b/geode-core/src/test/java/org/examples/snapshot/MyObjectPdx.java
deleted file mode 100644
index 396049d..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyObjectPdx.java
+++ /dev/null
@@ -1,33 +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 com.examples.snapshot;
-
-public class MyObjectPdx extends MyObject {
-  public enum MyEnumPdx {
-    const1, const2, const3, const4, const5;
-  }
-  
-  private MyEnumPdx enumVal;
-  
-  public MyObjectPdx() {
-  }
-
-  public MyObjectPdx(long number, String s, MyEnumPdx enumVal) {
-    super(number, s);
-    this.enumVal = enumVal;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyObjectPdxSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyObjectPdxSerializable.java b/geode-core/src/test/java/org/examples/snapshot/MyObjectPdxSerializable.java
deleted file mode 100644
index 3929db4..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyObjectPdxSerializable.java
+++ /dev/null
@@ -1,42 +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 com.examples.snapshot;
-
-import org.apache.geode.pdx.PdxReader;
-import org.apache.geode.pdx.PdxSerializable;
-import org.apache.geode.pdx.PdxWriter;
-
-public class MyObjectPdxSerializable extends MyObject implements PdxSerializable {
-  public MyObjectPdxSerializable() {
-  }
-
-  public MyObjectPdxSerializable(long number, String s) {
-    super(number, s);
-  }
-
-  @Override
-  public void toData(PdxWriter writer) {
-    writer.writeLong("f1", f1);
-    writer.writeString("f2", f2);
-  }
-
-  @Override
-  public void fromData(PdxReader reader) {
-    f1 = reader.readLong("f1");
-    f2 = reader.readString("f2");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/examples/snapshot/MyPdxSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/examples/snapshot/MyPdxSerializer.java b/geode-core/src/test/java/org/examples/snapshot/MyPdxSerializer.java
deleted file mode 100644
index 710e445..0000000
--- a/geode-core/src/test/java/org/examples/snapshot/MyPdxSerializer.java
+++ /dev/null
@@ -1,64 +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 com.examples.snapshot;
-
-import java.util.Properties;
-
-import org.apache.geode.cache.Declarable;
-import org.apache.geode.pdx.PdxReader;
-import org.apache.geode.pdx.PdxSerializer;
-import org.apache.geode.pdx.PdxWriter;
-import org.apache.geode.pdx.ReflectionBasedAutoSerializer;
-
-public class MyPdxSerializer implements PdxSerializer, Declarable {
-  private final PdxSerializer auto = new ReflectionBasedAutoSerializer("com.examples.snapshot.My.*Pdx");
-  
-  @Override
-  public void init(Properties props) {
-  }
-  @Override
-  public boolean toData(Object o, PdxWriter out) {
-    if (o instanceof MyObjectPdx2) {
-      MyObjectPdx2 obj = (MyObjectPdx2) o;
-      out.writeLong("f1", obj.f1);
-      out.writeString("f2", obj.f2);
-      return true;
-    }
-    return auto.toData(o, out);
-  }
-
-  @Override
-  public Object fromData(Class<?> clazz, PdxReader in) {
-    if (clazz == MyObjectPdx2.class) {
-      MyObjectPdx2 obj = new MyObjectPdx2();
-      obj.f1 = in.readLong("f1");
-      obj.f2 = in.readString("f2");
-      
-      return obj;
-    }
-    return auto.fromData(clazz, in);
-  }
-  
-  public static class MyObjectPdx2 extends MyObject {
-    public MyObjectPdx2() {
-    }
-
-    public MyObjectPdx2(long number, String s) {
-      super(number, s);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/main/MyDistributedSystemListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/main/MyDistributedSystemListener.java b/geode-core/src/test/java/org/main/MyDistributedSystemListener.java
deleted file mode 100644
index 6206441..0000000
--- a/geode-core/src/test/java/org/main/MyDistributedSystemListener.java
+++ /dev/null
@@ -1,114 +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 com.main;
-
-import java.io.IOException;
-
-import org.apache.geode.cache.Cache;
-import org.apache.geode.cache.CacheClosedException;
-import org.apache.geode.cache.CacheFactory;
-import org.apache.geode.cache.Region;
-import org.apache.geode.cache.wan.GatewayReceiver;
-import org.apache.geode.cache.wan.GatewaySender;
-import org.apache.geode.internal.cache.wan.DistributedSystemListener;
-
-/**
- * This is an implementation of DistributedSystemListener. When a
- * addedDistributedSystem is called a Region is created on both sites and
- * GatewaySender and GatewayReciever is started on site 1 and site 2
- * respectively.
- * 
- * When a removedDistributedSystem is called, GatewaySender and GatewayReceiver
- * is stopped on site1 and site2 respectively.
- * 
- * 
- */
-public class MyDistributedSystemListener implements DistributedSystemListener {
-
-  Cache cache;
-  
-  public MyDistributedSystemListener() {
-  }
-  
-  /**
-   * Please note that dynamic addition of the sender id to region is not yet available.  
-   */
-  public void addedDistributedSystem(int remoteDsId) {
-    cache = CacheFactory.getAnyInstance();
-    
-    //When a site with distributed-system-id = 2 joins, create a region and a gatewaysender with remoteDsId = 2 
-    if (remoteDsId == 2) {
-      if (cache != null) {
-        GatewaySender serialSender= cache
-            .createGatewaySenderFactory()
-            .setManualStart(true)
-            .setPersistenceEnabled(false)
-            .setDiskStoreName("LN_" + remoteDsId)
-            .create("LN_"+ remoteDsId, remoteDsId);
-        System.out.println("Sender Created : " + serialSender.getId());
-        
-        Region region= cache.createRegionFactory()
-                       //.addSerialGatewaySenderId("LN_" + remoteDsId)
-                       .create("MyRegion");
-        System.out.println("Created Region : " + region.getName());
-        
-        try {
-          serialSender.start();
-          System.out.println("Sender Started: " + serialSender.getId());
-        }
-        catch (Exception e) {
-          e.printStackTrace();
-        }
-      }
-      else {
-        throw new CacheClosedException("Cache is not initialized here");
-      }
-    }else{ //When a site with distributed-system-id = 1 joins, create a region and a gatewayReceiver with  
-      if (cache != null) {
-        Region region = cache.createRegionFactory().create("MyRegion");
-        System.out.println("Created Region :" +  region.getName());
-
-        GatewayReceiver receiver= cache.createGatewayReceiverFactory()
-                                 .setStartPort(12345)
-                                 .setManualStart(true)
-                                 .create();
-        System.out.println("Created GatewayReceiver : " + receiver);
-        try {
-          receiver.start();
-          System.out.println("GatewayReceiver Started.");
-        }
-        catch (IOException e) {
-          e.printStackTrace();
-        }
-      }
-    }
-  }
-
-  public void removedDistributedSystem(int remoteDsId) {
-    cache = CacheFactory.getAnyInstance();
-    if (remoteDsId == 2) { //When a site with distributed-system-id = -2 joins, stop gatewaysender with remoteDsId = 2 
-      if (cache != null) {
-        GatewaySender sender = cache.getGatewaySender("LN_"+2);
-        sender.stop();
-      }
-    }
-    else{ // When a site with distributed-system-id = -1 joins, stop gatewayReceiver
-      GatewayReceiver receiver = cache.getGatewayReceivers().iterator().next();
-      receiver.stop();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Add.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Add.java b/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Add.java
deleted file mode 100644
index 9d4bbfc..0000000
--- a/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Add.java
+++ /dev/null
@@ -1,122 +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 com.main;
-
-import org.apache.geode.cache.Cache;
-import org.apache.geode.cache.CacheFactory;
-import org.apache.geode.cache.Region;
-import org.apache.geode.cache.wan.GatewaySender;
-import org.apache.geode.distributed.internal.DistributionConfig;
-
-import java.util.Set;
-
-import static org.apache.geode.distributed.ConfigurationProperties.*;
-
-/**
- * This is a member representing site 1 who wants to send data to site 2
- * 
- * On this member a locator with distributed-system-id = 1 is created. On this
- * member a cache is created.
- * 
- * A Region and a GatewaySender is created on this member through
- * MyDistributedSustemListener#addedDistributedSystemConnection 
- * (When a remote locator with distributed-system-id = 2 connects to this site,
- * MyDistributedSustemListener's addedDistributedSystemConnection will be
- * invoked who will create a region and a GatewaySender.)
- * 
- * This member does put for 100 keys on the region. (We have to check that this
- * data for 100 entries are sent to remote site)
- * 
- * This member also check for the sender's running status.
- * 
- * A GatewaySender will be stopped through
- * MyDistributedSustemListener#removedDistributedSystem 
- * (When a remote locator with distributed-system-id = -2 connects to this site,
- * MyDistributedSustemListener's removedDistributedSystem will be invoked who
- * will stop a GatewaySender.)
- * 
- * 
- */
-
-public class WANBootStrapping_Site1_Add {
-
-  public static void main(String[] args) {
-
-    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
-        "com.main.MyDistributedSystemListener");
-
-    // Create a locator and a cache
-    System.out.println("Creating cache ...It will take some time..");
-    Cache cache = new CacheFactory().set(MCAST_PORT,
-        "0").set(DISTRIBUTED_SYSTEM_ID, "" + 1).set(
-        LOCATORS, "localhost[" + 10101 + "]").set(
-        START_LOCATOR,
-        "localhost[" + 10101
-            + "],server=true,peer=true,hostname-for-clients=localhost").set(
-        LOG_LEVEL, "warning").create();
-    System.out.println("Cache Created");
-
-    // to create region and a gateway sender ask to run
-    // WANBootStrapping_Site2_Add program
-    System.out.println("Run WANBootStrapping_Site2_Add");
-
-    // get the region
-    Region region = cache.getRegion("MyRegion");
-    while (region == null) {
-      region = cache.getRegion("MyRegion");
-      try {
-        Thread.sleep(5000);
-      }
-      catch (InterruptedException e) {
-        e.printStackTrace();
-      }
-    }
-
-    // put data in region
-    for (int i = 0; i < 100; i++) {
-      System.out.println("Create Entry : key_" + i + ", value_" + i);
-      region.put("key_" + i, "value_" + i);
-    }
-
-    System.out.println("Entry Create Operation completed");
-
-    Set<GatewaySender> gatewaySenders = cache.getGatewaySenders();
-    GatewaySender sender = gatewaySenders.iterator().next();
-
-    // make sure that gateway sender is running
-    if (sender.isRunning()) {
-      System.out.println("Sender " + sender.getId() + " is running");
-    }
-
-    // to stop gateway sender ask to run WANBootStrapping_Site2_Remove program
-    while (sender.isRunning()) {
-      System.out
-          .println("Waitng for sender to stop through DistributedSystemListener");
-      System.out.println("Start WANBootStrapping_Site2_Remove");
-      try {
-        Thread.sleep(5000);
-      }
-      catch (InterruptedException e) {
-        e.printStackTrace();
-      }
-    }
-    
-    System.out.println("Sender " + sender.getId() + " is stopped");
-
-    System.exit(0);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Remove.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Remove.java b/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Remove.java
deleted file mode 100644
index 6920d7e..0000000
--- a/geode-core/src/test/java/org/main/WANBootStrapping_Site1_Remove.java
+++ /dev/null
@@ -1,78 +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 com.main;
-
-import static org.apache.geode.distributed.ConfigurationProperties.*;
-
-import org.apache.geode.distributed.Locator;
-import org.apache.geode.distributed.internal.DistributionConfig;
-
-import java.io.IOException;
-import java.util.Properties;
-
-import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
-
-/**
- * This is a stand alone locator with a distributed-system-id = -1
- * 
- * This locator is started so that the locator information regarding the site 1
- * is removed from site 2's locator and at the same time
- * MyDistributedSystemListener's removeDistributedSystem is invoked on site 2's locator which will stop the GatewayReceiver
- * 
- * 
- */
-public class WANBootStrapping_Site1_Remove {
-
-
-  public static void main(String[] args) {
-    
-    //On this locator, I am not expecting a listener to take any action, so a empty listener is a passed
-    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
-    "");
-    
-    System.out.println("Starting a locator with negative ds id -1");
-    
-    //start a stand alone locator with distributed-system-is = -1
-    Properties properties = new Properties();
-    properties.setProperty(MCAST_PORT, "0");
-    properties.setProperty(DISTRIBUTED_SYSTEM_ID, ""+ (-1));
-    properties.setProperty(REMOTE_LOCATORS, "localhost[" + 20202 + "]");
-    properties.setProperty(LOG_LEVEL, "warning");
-    Locator locator = null;
-    try {
-      locator = Locator.startLocatorAndDS(40445, null, properties);
-    }
-    catch (IOException e) {
-      e.printStackTrace();
-    }
-    
-    try {
-      Thread.sleep(1000);
-    }
-    catch (InterruptedException e) {
-      e.printStackTrace();
-    }
-    
-    //stop locator
-    System.out.println("Stoping locator");    
-    locator.stop();
-    System.out.println("Locator stopped ");
-    
-    System.exit(0);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Add.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Add.java b/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Add.java
deleted file mode 100644
index f5abf5d..0000000
--- a/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Add.java
+++ /dev/null
@@ -1,108 +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 com.main;
-
-import org.apache.geode.cache.Cache;
-import org.apache.geode.cache.CacheFactory;
-import org.apache.geode.cache.Region;
-import org.apache.geode.cache.wan.GatewayReceiver;
-import org.apache.geode.distributed.internal.DistributionConfig;
-
-import static org.apache.geode.distributed.ConfigurationProperties.*;
-
-/**
- * This is a member representing site 2 who wants to receive data from site 1
- * 
- * On this member a locator with distributed-system-id = 2 is created. 
- * On this member a cache is created.
- * 
- * A Region and a GatewayReceiver is created on this member through
- * MyDistributedSustemListener#addedDistributedSystemConnection
- *  
- * (When this locator gets the locator information from the site 1,
- * MyDistributedSustemListener's addedDistributedSystemConnection will be
- * invoked who will create a region and a GatewayReceiver.)
- * 
- * This member expects region size to be 100. (this site received this data from site1)
- * 
- * This member also check for the receiver's running status.
- * 
- * A GatewayReceiver will be stopped through
- * MyDistributedSustemListener#removedDistributedSystem 
- * (When a remote locator with distributed-system-id = -1 connects to this site,
- * MyDistributedSustemListener's removedDistributedSystem will be invoked who
- * will stop a GatewayReceiver.)
- * 
- * 
- */
-
-public class WANBootStrapping_Site2_Add {
-
-  public static void main(String[] args) {
-
-    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
-        "com.main.MyDistributedSystemListener");
-    
-    //create a locator and a cache
-    System.out.println("Creating cache ...It will take some time..");
-    Cache cache = new CacheFactory()
-        .set(MCAST_PORT, "0")
-    .set(DISTRIBUTED_SYSTEM_ID, ""+2)
-        .set(LOCATORS, "localhost[" + 20202 + "]")
-        .set(START_LOCATOR, "localhost[" + 20202 + "],server=true,peer=true,hostname-for-clients=localhost")
-    .set(REMOTE_LOCATORS, "localhost[" + 10101 + "]")
-    .set(LOG_LEVEL, "warning")
-    .create();
-    System.out.println("Cache Created");
-    
-    //get the region whose size should be 100 
-    Region region = cache.getRegion("MyRegion");
-    while(region == null){
-      region = cache.getRegion("MyRegion");
-      try {
-        Thread.sleep(5000);
-      }
-      catch (InterruptedException e) {
-        e.printStackTrace();
-      }
-    }
-    
-    //region size should be 100. This is the data which will recieve from remote site
-    while(region.size()!= 100){
-      continue;
-    }
-    System.out.println("Checked region size : " + region.size());
-
-    GatewayReceiver receiver = cache.getGatewayReceivers().iterator().next();
-    
-     // to stop gateway receiver ask to run WANBootStrapping_Site1_Remove program
-    while (receiver.isRunning()) {
-      System.out
-          .println("Waitng for receiver to stop through DistributedSystemListener");
-      System.out.println("Start WANBootStrapping_Site1_Remove ");  
-      try {
-        Thread.sleep(2000);
-      }
-      catch (InterruptedException e) {
-        e.printStackTrace();
-      }
-    }
-
-    System.out.println("GatewayReciver " + receiver + " is stopped") ;
-    System.exit(0);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Remove.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Remove.java b/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Remove.java
deleted file mode 100644
index 30e0a22..0000000
--- a/geode-core/src/test/java/org/main/WANBootStrapping_Site2_Remove.java
+++ /dev/null
@@ -1,74 +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 com.main;
-
-import org.apache.geode.distributed.Locator;
-import org.apache.geode.distributed.internal.DistributionConfig;
-
-import java.io.IOException;
-import java.util.Properties;
-
-import static org.apache.geode.distributed.ConfigurationProperties.*;
-
-/**
- * This is a stand alone locator with a distributed-system-id = -2
- * 
- * This locator is started so that the locator information regarding the site 2
- * is removed from site 1's locator and at the same time
- * MyDistributedSystemListener's removeDistributedSystem is invoked on site 1's locator which will stop the GatewaySender
- * 
- * 
- */
-
-public class WANBootStrapping_Site2_Remove {
-
-  public static void main(String[] args) {
-    
-    // On this locator, I am not expecting a listener to take any action, so a
-    // empty listener is a passed
-    System.setProperty(DistributionConfig.GEMFIRE_PREFIX + "DistributedSystemListener",
-    "");
-    
-    System.out.println("Starting a locator with negative ds id -2");
-    Properties properties = new Properties();
-    properties.setProperty(MCAST_PORT, "0");
-    properties.setProperty(DISTRIBUTED_SYSTEM_ID, ""+ (-2));
-    properties.setProperty(REMOTE_LOCATORS, "localhost[" + 10101 + "]");
-    properties.setProperty(LOG_LEVEL, "warning");
-    Locator locator = null;
-    try {
-      locator = Locator.startLocatorAndDS(30445, null, properties);
-    }
-    catch (IOException e) {
-      e.printStackTrace();
-    }
-    
-    try {
-      Thread.sleep(1000);
-    }
-    catch (InterruptedException e) {
-      e.printStackTrace();
-    }
-    System.out.println("Stoping locator");    
-    locator.stop();
-    System.out.println("Locator stopped ");
-    
-    System.exit(0);
-  }
-
-  
-}


[23/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/DSFIDFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DSFIDFactory.java b/geode-core/src/main/java/org/apache/geode/internal/DSFIDFactory.java
index ab76d5c..d8c0223 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DSFIDFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DSFIDFactory.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 
 
-import com.gemstone.gemfire.distributed.internal.membership.gms.messages.*;
+import org.apache.geode.distributed.internal.membership.gms.messages.*;
 import it.unimi.dsi.fastutil.ints.Int2ObjectOpenHashMap;
 
 import java.io.DataInput;
@@ -29,388 +29,388 @@ import java.io.NotSerializableException;
 import java.lang.reflect.Constructor;
 import java.lang.reflect.InvocationTargetException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.admin.internal.FinishBackupRequest;
-import com.gemstone.gemfire.admin.internal.FinishBackupResponse;
-import com.gemstone.gemfire.admin.internal.FlushToDiskRequest;
-import com.gemstone.gemfire.admin.internal.FlushToDiskResponse;
-import com.gemstone.gemfire.admin.internal.PrepareBackupRequest;
-import com.gemstone.gemfire.admin.internal.PrepareBackupResponse;
-import com.gemstone.gemfire.admin.internal.SystemMemberCacheEventProcessor;
-import com.gemstone.gemfire.admin.jmx.internal.StatAlertNotification;
-import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.client.internal.CacheServerLoadMessage;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.ClientReplacementRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.GetAllServersResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorListResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorStatusRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.LocatorStatusResponse;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionRequest;
-import com.gemstone.gemfire.cache.client.internal.locator.QueueConnectionResponse;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.internal.CqEntry;
-import com.gemstone.gemfire.cache.query.internal.CumulativeNonDistinctResults;
-import com.gemstone.gemfire.cache.query.internal.LinkedResultSet;
-import com.gemstone.gemfire.cache.query.internal.LinkedStructSet;
-import com.gemstone.gemfire.cache.query.internal.NWayMergeResults;
-import com.gemstone.gemfire.cache.query.internal.NullToken;
-import com.gemstone.gemfire.cache.query.internal.PRQueryTraceInfo;
-import com.gemstone.gemfire.cache.query.internal.ResultsBag;
-import com.gemstone.gemfire.cache.query.internal.ResultsCollectionWrapper;
-import com.gemstone.gemfire.cache.query.internal.ResultsSet;
-import com.gemstone.gemfire.cache.query.internal.SortedResultSet;
-import com.gemstone.gemfire.cache.query.internal.SortedStructSet;
-import com.gemstone.gemfire.cache.query.internal.StructBag;
-import com.gemstone.gemfire.cache.query.internal.StructImpl;
-import com.gemstone.gemfire.cache.query.internal.StructSet;
-import com.gemstone.gemfire.cache.query.internal.Undefined;
-import com.gemstone.gemfire.cache.query.internal.index.IndexCreationData;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager;
-import com.gemstone.gemfire.cache.query.internal.types.CollectionTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.MapTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.internal.types.StructTypeImpl;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.HighPriorityAckedMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.SerialAckedMessage;
-import com.gemstone.gemfire.distributed.internal.ShutdownMessage;
-import com.gemstone.gemfire.distributed.internal.StartupMessage;
-import com.gemstone.gemfire.distributed.internal.StartupResponseMessage;
-import com.gemstone.gemfire.distributed.internal.StartupResponseWithVersionMessage;
-import com.gemstone.gemfire.distributed.internal.WaitForViewInstallation;
-import com.gemstone.gemfire.distributed.internal.locks.DLockQueryProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRecoverGrantorProcessor.DLockRecoverGrantorMessage;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRecoverGrantorProcessor.DLockRecoverGrantorReplyMessage;
-import com.gemstone.gemfire.distributed.internal.locks.DLockReleaseProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRemoteToken;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRequestProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.locks.DeposeGrantorProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.ElderInitProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.GrantorRequestProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.NonGrantorDestroyedProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.NonGrantorDestroyedProcessor.NonGrantorDestroyedReplyMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.NetView;
-import com.gemstone.gemfire.distributed.internal.membership.gms.GMSMember;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.GetViewRequest;
-import com.gemstone.gemfire.distributed.internal.membership.gms.locator.GetViewResponse;
-import com.gemstone.gemfire.distributed.internal.streaming.StreamingOperation.StreamingReplyMessage;
-import com.gemstone.gemfire.internal.admin.ClientMembershipMessage;
-import com.gemstone.gemfire.internal.admin.remote.AddHealthListenerRequest;
-import com.gemstone.gemfire.internal.admin.remote.AddHealthListenerResponse;
-import com.gemstone.gemfire.internal.admin.remote.AddStatListenerRequest;
-import com.gemstone.gemfire.internal.admin.remote.AddStatListenerResponse;
-import com.gemstone.gemfire.internal.admin.remote.AdminConsoleDisconnectMessage;
-import com.gemstone.gemfire.internal.admin.remote.AdminConsoleMessage;
-import com.gemstone.gemfire.internal.admin.remote.AdminFailureResponse;
-import com.gemstone.gemfire.internal.admin.remote.AlertLevelChangeMessage;
-import com.gemstone.gemfire.internal.admin.remote.AlertListenerMessage;
-import com.gemstone.gemfire.internal.admin.remote.AlertsNotificationMessage;
-import com.gemstone.gemfire.internal.admin.remote.AppCacheSnapshotMessage;
-import com.gemstone.gemfire.internal.admin.remote.BridgeServerRequest;
-import com.gemstone.gemfire.internal.admin.remote.BridgeServerResponse;
-import com.gemstone.gemfire.internal.admin.remote.CacheConfigRequest;
-import com.gemstone.gemfire.internal.admin.remote.CacheConfigResponse;
-import com.gemstone.gemfire.internal.admin.remote.CacheInfoRequest;
-import com.gemstone.gemfire.internal.admin.remote.CacheInfoResponse;
-import com.gemstone.gemfire.internal.admin.remote.CancelStatListenerRequest;
-import com.gemstone.gemfire.internal.admin.remote.CancelStatListenerResponse;
-import com.gemstone.gemfire.internal.admin.remote.CancellationMessage;
-import com.gemstone.gemfire.internal.admin.remote.ChangeRefreshIntervalMessage;
-import com.gemstone.gemfire.internal.admin.remote.ClientHealthStats;
-import com.gemstone.gemfire.internal.admin.remote.CompactRequest;
-import com.gemstone.gemfire.internal.admin.remote.CompactResponse;
-import com.gemstone.gemfire.internal.admin.remote.DestroyEntryMessage;
-import com.gemstone.gemfire.internal.admin.remote.DestroyRegionMessage;
-import com.gemstone.gemfire.internal.admin.remote.DurableClientInfoRequest;
-import com.gemstone.gemfire.internal.admin.remote.DurableClientInfoResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchDistLockInfoRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchDistLockInfoResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchHealthDiagnosisRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchHealthDiagnosisResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchHostRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchHostResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchResourceAttributesRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchResourceAttributesResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchStatsRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchStatsResponse;
-import com.gemstone.gemfire.internal.admin.remote.FetchSysCfgRequest;
-import com.gemstone.gemfire.internal.admin.remote.FetchSysCfgResponse;
-import com.gemstone.gemfire.internal.admin.remote.FlushAppCacheSnapshotMessage;
-import com.gemstone.gemfire.internal.admin.remote.HealthListenerMessage;
-import com.gemstone.gemfire.internal.admin.remote.LicenseInfoRequest;
-import com.gemstone.gemfire.internal.admin.remote.LicenseInfoResponse;
-import com.gemstone.gemfire.internal.admin.remote.MissingPersistentIDsRequest;
-import com.gemstone.gemfire.internal.admin.remote.MissingPersistentIDsResponse;
-import com.gemstone.gemfire.internal.admin.remote.ObjectDetailsRequest;
-import com.gemstone.gemfire.internal.admin.remote.ObjectDetailsResponse;
-import com.gemstone.gemfire.internal.admin.remote.ObjectNamesRequest;
-import com.gemstone.gemfire.internal.admin.remote.ObjectNamesResponse;
-import com.gemstone.gemfire.internal.admin.remote.PrepareRevokePersistentIDRequest;
-import com.gemstone.gemfire.internal.admin.remote.RefreshMemberSnapshotRequest;
-import com.gemstone.gemfire.internal.admin.remote.RefreshMemberSnapshotResponse;
-import com.gemstone.gemfire.internal.admin.remote.RegionAttributesRequest;
-import com.gemstone.gemfire.internal.admin.remote.RegionAttributesResponse;
-import com.gemstone.gemfire.internal.admin.remote.RegionRequest;
-import com.gemstone.gemfire.internal.admin.remote.RegionResponse;
-import com.gemstone.gemfire.internal.admin.remote.RegionSizeRequest;
-import com.gemstone.gemfire.internal.admin.remote.RegionSizeResponse;
-import com.gemstone.gemfire.internal.admin.remote.RegionStatisticsRequest;
-import com.gemstone.gemfire.internal.admin.remote.RegionStatisticsResponse;
-import com.gemstone.gemfire.internal.admin.remote.RegionSubRegionSizeRequest;
-import com.gemstone.gemfire.internal.admin.remote.RegionSubRegionsSizeResponse;
-import com.gemstone.gemfire.internal.admin.remote.RemoveHealthListenerRequest;
-import com.gemstone.gemfire.internal.admin.remote.RemoveHealthListenerResponse;
-import com.gemstone.gemfire.internal.admin.remote.ResetHealthStatusRequest;
-import com.gemstone.gemfire.internal.admin.remote.ResetHealthStatusResponse;
-import com.gemstone.gemfire.internal.admin.remote.RevokePersistentIDRequest;
-import com.gemstone.gemfire.internal.admin.remote.RevokePersistentIDResponse;
-import com.gemstone.gemfire.internal.admin.remote.RootRegionRequest;
-import com.gemstone.gemfire.internal.admin.remote.RootRegionResponse;
-import com.gemstone.gemfire.internal.admin.remote.ShutdownAllGatewayHubsRequest;
-import com.gemstone.gemfire.internal.admin.remote.ShutdownAllRequest;
-import com.gemstone.gemfire.internal.admin.remote.ShutdownAllResponse;
-import com.gemstone.gemfire.internal.admin.remote.SnapshotResultMessage;
-import com.gemstone.gemfire.internal.admin.remote.StatAlertsManagerAssignMessage;
-import com.gemstone.gemfire.internal.admin.remote.StatListenerMessage;
-import com.gemstone.gemfire.internal.admin.remote.StoreSysCfgRequest;
-import com.gemstone.gemfire.internal.admin.remote.StoreSysCfgResponse;
-import com.gemstone.gemfire.internal.admin.remote.SubRegionRequest;
-import com.gemstone.gemfire.internal.admin.remote.SubRegionResponse;
-import com.gemstone.gemfire.internal.admin.remote.TailLogRequest;
-import com.gemstone.gemfire.internal.admin.remote.TailLogResponse;
-import com.gemstone.gemfire.internal.admin.remote.UpdateAlertDefinitionMessage;
-import com.gemstone.gemfire.internal.admin.remote.VersionInfoRequest;
-import com.gemstone.gemfire.internal.admin.remote.VersionInfoResponse;
-import com.gemstone.gemfire.internal.admin.statalerts.GaugeThresholdDecoratorImpl;
-import com.gemstone.gemfire.internal.admin.statalerts.NumberThresholdDecoratorImpl;
-import com.gemstone.gemfire.internal.cache.AddCacheServerProfileMessage;
-import com.gemstone.gemfire.internal.cache.ClientRegionEventImpl;
-import com.gemstone.gemfire.internal.cache.CacheServerAdvisor.CacheServerProfile;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor;
-import com.gemstone.gemfire.internal.cache.CloseCacheMessage;
-import com.gemstone.gemfire.internal.cache.ControllerAdvisor.ControllerProfile;
-import com.gemstone.gemfire.internal.cache.CreateRegionProcessor;
-import com.gemstone.gemfire.internal.cache.DestroyOperation;
-import com.gemstone.gemfire.internal.cache.DestroyPartitionedRegionMessage;
-import com.gemstone.gemfire.internal.cache.DestroyRegionOperation;
-import com.gemstone.gemfire.internal.cache.DistTXPrecommitMessage;
-import com.gemstone.gemfire.internal.cache.DistTXCommitMessage;
-import com.gemstone.gemfire.internal.cache.DistTXRollbackMessage;
-import com.gemstone.gemfire.internal.cache.DistributedClearOperation.ClearRegionMessage;
-import com.gemstone.gemfire.internal.cache.DistributedClearOperation.ClearRegionWithContextMessage;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.EntryVersionsList;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllMessage;
-import com.gemstone.gemfire.internal.cache.DistributedRegionFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.cache.DistributedRemoveAllOperation.RemoveAllMessage;
-import com.gemstone.gemfire.internal.cache.DistributedTombstoneOperation.TombstoneMessage;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.FilterProfile;
-import com.gemstone.gemfire.internal.cache.FindDurableQueueProcessor.FindDurableQueueMessage;
-import com.gemstone.gemfire.internal.cache.FindDurableQueueProcessor.FindDurableQueueReply;
-import com.gemstone.gemfire.internal.cache.FindRemoteTXMessage;
-import com.gemstone.gemfire.internal.cache.FindRemoteTXMessage.FindRemoteTXMessageReply;
-import com.gemstone.gemfire.internal.cache.FindVersionTagOperation.FindVersionTagMessage;
-import com.gemstone.gemfire.internal.cache.FindVersionTagOperation.VersionTagReply;
-import com.gemstone.gemfire.internal.cache.FunctionStreamingOrderedReplyMessage;
-import com.gemstone.gemfire.internal.cache.FunctionStreamingReplyMessage;
-import com.gemstone.gemfire.internal.cache.HARegion;
-import com.gemstone.gemfire.internal.cache.InitialImageFlowControl.FlowControlPermitMessage;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.InitialImageVersionedEntryList;
-import com.gemstone.gemfire.internal.cache.InvalidateOperation;
-import com.gemstone.gemfire.internal.cache.InvalidatePartitionedRegionMessage;
-import com.gemstone.gemfire.internal.cache.InvalidateRegionOperation.InvalidateRegionMessage;
-import com.gemstone.gemfire.internal.cache.JtaAfterCompletionMessage;
-import com.gemstone.gemfire.internal.cache.JtaBeforeCompletionMessage;
-import com.gemstone.gemfire.internal.cache.MemberFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.cache.Node;
-import com.gemstone.gemfire.internal.cache.PRQueryProcessor;
-import com.gemstone.gemfire.internal.cache.PartitionRegionConfig;
-import com.gemstone.gemfire.internal.cache.PreferBytesCachedDeserializable;
-import com.gemstone.gemfire.internal.cache.RegionEventImpl;
-import com.gemstone.gemfire.internal.cache.ReleaseClearLockMessage;
-import com.gemstone.gemfire.internal.cache.RemoteContainsKeyValueMessage;
-import com.gemstone.gemfire.internal.cache.RemoteDestroyMessage;
-import com.gemstone.gemfire.internal.cache.RemoteFetchEntryMessage;
-import com.gemstone.gemfire.internal.cache.RemoteFetchVersionMessage;
-import com.gemstone.gemfire.internal.cache.RemoteGetMessage;
-import com.gemstone.gemfire.internal.cache.RemoteInvalidateMessage;
-import com.gemstone.gemfire.internal.cache.RemotePutAllMessage;
-import com.gemstone.gemfire.internal.cache.RemotePutMessage;
-import com.gemstone.gemfire.internal.cache.RemoteRegionOperation;
-import com.gemstone.gemfire.internal.cache.RemoteRegionOperation.RemoteRegionOperationReplyMessage;
-import com.gemstone.gemfire.internal.cache.RemoteRemoveAllMessage;
-import com.gemstone.gemfire.internal.cache.RoleEventImpl;
-import com.gemstone.gemfire.internal.cache.SearchLoadAndWriteProcessor;
-import com.gemstone.gemfire.internal.cache.SendQueueOperation.SendQueueMessage;
-import com.gemstone.gemfire.internal.cache.ServerPingMessage;
-import com.gemstone.gemfire.internal.cache.StateFlushOperation.StateMarkerMessage;
-import com.gemstone.gemfire.internal.cache.StateFlushOperation.StateStabilizationMessage;
-import com.gemstone.gemfire.internal.cache.StateFlushOperation.StateStabilizedMessage;
-import com.gemstone.gemfire.internal.cache.StoreAllCachedDeserializable;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage.CommitProcessForLockIdMessage;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage.CommitProcessForTXIdMessage;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage.CommitProcessQueryMessage;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage.CommitProcessQueryReplyMessage;
-import com.gemstone.gemfire.internal.cache.TXEntryState;
-import com.gemstone.gemfire.internal.cache.TXId;
-import com.gemstone.gemfire.internal.cache.TXManagerImpl;
-import com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage;
-import com.gemstone.gemfire.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage;
-import com.gemstone.gemfire.internal.cache.TXRemoteRollbackMessage;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.cache.UpdateAttributesProcessor;
-import com.gemstone.gemfire.internal.cache.UpdateEntryVersionOperation.UpdateEntryVersionMessage;
-import com.gemstone.gemfire.internal.cache.UpdateOperation;
-import com.gemstone.gemfire.internal.cache.VMCachedDeserializable;
-import com.gemstone.gemfire.internal.cache.compression.SnappyCompressedCachedDeserializable;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
-import com.gemstone.gemfire.internal.cache.control.ResourceAdvisor.ResourceProfileMessage;
-import com.gemstone.gemfire.internal.cache.ha.HARegionQueue.DispatchedAndCurrentEvents;
-import com.gemstone.gemfire.internal.cache.ha.QueueRemovalMessage;
-import com.gemstone.gemfire.internal.cache.locks.TXLockBatch;
-import com.gemstone.gemfire.internal.cache.locks.TXLockIdImpl;
-import com.gemstone.gemfire.internal.cache.locks.TXLockUpdateParticipantsMessage;
-import com.gemstone.gemfire.internal.cache.locks.TXLockUpdateParticipantsMessage.TXLockUpdateParticipantsReplyMessage;
-import com.gemstone.gemfire.internal.cache.locks.TXOriginatorRecoveryProcessor.TXOriginatorRecoveryMessage;
-import com.gemstone.gemfire.internal.cache.locks.TXOriginatorRecoveryProcessor.TXOriginatorRecoveryReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.AllBucketProfilesUpdateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BecomePrimaryBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BecomePrimaryBucketMessage.BecomePrimaryBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketBackupMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketCountLoadProbe;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketProfileUpdateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketSizeMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.BucketSizeMessage.BucketSizeReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ContainsKeyValueMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.CreateBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.CreateBucketMessage.CreateBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DeposePrimaryBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DeposePrimaryBucketMessage.DeposePrimaryBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DestroyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DestroyRegionOnDataStoreMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DumpAllPRConfigMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DumpB2NRegion;
-import com.gemstone.gemfire.internal.cache.partitioned.DumpB2NRegion.DumpB2NReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.DumpBucketsMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.EndBucketCreationMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchBulkEntriesMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchBulkEntriesMessage.FetchBulkEntriesReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntriesMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntriesMessage.FetchEntriesReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntryMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchEntryMessage.FetchEntryReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchKeysMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchKeysMessage.FetchKeysReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchPartitionDetailsMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FetchPartitionDetailsMessage.FetchPartitionDetailsReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.FlushMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.GetMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.GetMessage.GetReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.IdentityRequestMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.IdentityRequestMessage.IdentityReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.IdentityUpdateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.IndexCreationMsg;
-import com.gemstone.gemfire.internal.cache.partitioned.IndexCreationMsg.IndexCreationReplyMsg;
-import com.gemstone.gemfire.internal.cache.partitioned.InterestEventMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.InterestEventMessage.InterestEventReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.InvalidateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ManageBackupBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ManageBackupBucketMessage.ManageBackupBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.ManageBucketMessage.ManageBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.MoveBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.MoveBucketMessage.MoveBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PRSanityCheckMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PRTombstoneMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PRUpdateEntryVersionMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PrimaryRequestMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PrimaryRequestMessage.PrimaryRequestReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage.PutAllReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PutMessage.PutReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.QueryMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RegionAdvisor;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoteFetchKeysMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoteSizeMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveBucketMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveBucketMessage.RemoveBucketReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveIndexesMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveIndexesMessage.RemoveIndexesReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.SizeMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.SizeMessage.SizeReplyMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.SizedBasedLoadProbe;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.persistence.MembershipFlushRequest;
-import com.gemstone.gemfire.internal.cache.persistence.MembershipViewRequest;
-import com.gemstone.gemfire.internal.cache.persistence.MembershipViewRequest.MembershipViewReplyMessage;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentStateQueryMessage;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentStateQueryMessage.PersistentStateQueryReplyMessage;
-import com.gemstone.gemfire.internal.cache.persistence.PrepareNewPersistentMemberMessage;
-import com.gemstone.gemfire.internal.cache.persistence.RemovePersistentMemberMessage;
-import com.gemstone.gemfire.internal.cache.snapshot.FlowController.FlowControlAbortMessage;
-import com.gemstone.gemfire.internal.cache.snapshot.FlowController.FlowControlAckMessage;
-import com.gemstone.gemfire.internal.cache.snapshot.SnapshotPacket;
-import com.gemstone.gemfire.internal.cache.snapshot.SnapshotPacket.SnapshotRecord;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier.ServerInterestRegistrationMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientBlacklistProcessor.ClientBlacklistMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientDataSerializerMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientInstantiatorMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientInterestMessageImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientMarkerMessageImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientPingMessageImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientTombstoneMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientUpdateMessageImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.HAEventWrapper;
-import com.gemstone.gemfire.internal.cache.tier.sockets.InterestResultPolicyImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ObjectPartList;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ObjectPartList651;
-import com.gemstone.gemfire.internal.cache.tier.sockets.RemoveClientFromBlacklistMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.SerializedObjectPartList;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.cache.versions.DiskRegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VMRegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VMVersionTag;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderAdvisor;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventCallbackArgument;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelQueueBatchRemovalMessage;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelQueueBatchRemovalMessage.BatchRemovalReplyMessage;
-import com.gemstone.gemfire.internal.cache.wan.parallel.ParallelQueueRemovalMessage;
-import com.gemstone.gemfire.internal.cache.wan.serial.BatchDestroyOperation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.management.internal.JmxManagerAdvisor.JmxManagerProfile;
-import com.gemstone.gemfire.management.internal.JmxManagerAdvisor.JmxManagerProfileMessage;
-import com.gemstone.gemfire.management.internal.JmxManagerLocatorRequest;
-import com.gemstone.gemfire.management.internal.JmxManagerLocatorResponse;
-import com.gemstone.gemfire.management.internal.ManagerStartupMessage;
-import com.gemstone.gemfire.management.internal.cli.functions.CliFunctionResult;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationRequest;
-import com.gemstone.gemfire.management.internal.configuration.messages.ConfigurationResponse;
-import com.gemstone.gemfire.pdx.internal.CheckTypeRegistryState;
-import com.gemstone.gemfire.pdx.internal.EnumId;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.admin.internal.FinishBackupRequest;
+import org.apache.geode.admin.internal.FinishBackupResponse;
+import org.apache.geode.admin.internal.FlushToDiskRequest;
+import org.apache.geode.admin.internal.FlushToDiskResponse;
+import org.apache.geode.admin.internal.PrepareBackupRequest;
+import org.apache.geode.admin.internal.PrepareBackupResponse;
+import org.apache.geode.admin.internal.SystemMemberCacheEventProcessor;
+import org.apache.geode.admin.jmx.internal.StatAlertNotification;
+import org.apache.geode.cache.InterestResultPolicy;
+import org.apache.geode.cache.client.internal.CacheServerLoadMessage;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.ClientConnectionResponse;
+import org.apache.geode.cache.client.internal.locator.ClientReplacementRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersRequest;
+import org.apache.geode.cache.client.internal.locator.GetAllServersResponse;
+import org.apache.geode.cache.client.internal.locator.LocatorListRequest;
+import org.apache.geode.cache.client.internal.locator.LocatorListResponse;
+import org.apache.geode.cache.client.internal.locator.LocatorStatusRequest;
+import org.apache.geode.cache.client.internal.locator.LocatorStatusResponse;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionRequest;
+import org.apache.geode.cache.client.internal.locator.QueueConnectionResponse;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.internal.CqEntry;
+import org.apache.geode.cache.query.internal.CumulativeNonDistinctResults;
+import org.apache.geode.cache.query.internal.LinkedResultSet;
+import org.apache.geode.cache.query.internal.LinkedStructSet;
+import org.apache.geode.cache.query.internal.NWayMergeResults;
+import org.apache.geode.cache.query.internal.NullToken;
+import org.apache.geode.cache.query.internal.PRQueryTraceInfo;
+import org.apache.geode.cache.query.internal.ResultsBag;
+import org.apache.geode.cache.query.internal.ResultsCollectionWrapper;
+import org.apache.geode.cache.query.internal.ResultsSet;
+import org.apache.geode.cache.query.internal.SortedResultSet;
+import org.apache.geode.cache.query.internal.SortedStructSet;
+import org.apache.geode.cache.query.internal.StructBag;
+import org.apache.geode.cache.query.internal.StructImpl;
+import org.apache.geode.cache.query.internal.StructSet;
+import org.apache.geode.cache.query.internal.Undefined;
+import org.apache.geode.cache.query.internal.index.IndexCreationData;
+import org.apache.geode.cache.query.internal.index.IndexManager;
+import org.apache.geode.cache.query.internal.types.CollectionTypeImpl;
+import org.apache.geode.cache.query.internal.types.MapTypeImpl;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.internal.types.StructTypeImpl;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.HighPriorityAckedMessage;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.SerialAckedMessage;
+import org.apache.geode.distributed.internal.ShutdownMessage;
+import org.apache.geode.distributed.internal.StartupMessage;
+import org.apache.geode.distributed.internal.StartupResponseMessage;
+import org.apache.geode.distributed.internal.StartupResponseWithVersionMessage;
+import org.apache.geode.distributed.internal.WaitForViewInstallation;
+import org.apache.geode.distributed.internal.locks.DLockQueryProcessor;
+import org.apache.geode.distributed.internal.locks.DLockRecoverGrantorProcessor.DLockRecoverGrantorMessage;
+import org.apache.geode.distributed.internal.locks.DLockRecoverGrantorProcessor.DLockRecoverGrantorReplyMessage;
+import org.apache.geode.distributed.internal.locks.DLockReleaseProcessor;
+import org.apache.geode.distributed.internal.locks.DLockRemoteToken;
+import org.apache.geode.distributed.internal.locks.DLockRequestProcessor;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.locks.DeposeGrantorProcessor;
+import org.apache.geode.distributed.internal.locks.ElderInitProcessor;
+import org.apache.geode.distributed.internal.locks.GrantorRequestProcessor;
+import org.apache.geode.distributed.internal.locks.NonGrantorDestroyedProcessor;
+import org.apache.geode.distributed.internal.locks.NonGrantorDestroyedProcessor.NonGrantorDestroyedReplyMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.membership.NetView;
+import org.apache.geode.distributed.internal.membership.gms.GMSMember;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorRequest;
+import org.apache.geode.distributed.internal.membership.gms.locator.FindCoordinatorResponse;
+import org.apache.geode.distributed.internal.membership.gms.locator.GetViewRequest;
+import org.apache.geode.distributed.internal.membership.gms.locator.GetViewResponse;
+import org.apache.geode.distributed.internal.streaming.StreamingOperation.StreamingReplyMessage;
+import org.apache.geode.internal.admin.ClientMembershipMessage;
+import org.apache.geode.internal.admin.remote.AddHealthListenerRequest;
+import org.apache.geode.internal.admin.remote.AddHealthListenerResponse;
+import org.apache.geode.internal.admin.remote.AddStatListenerRequest;
+import org.apache.geode.internal.admin.remote.AddStatListenerResponse;
+import org.apache.geode.internal.admin.remote.AdminConsoleDisconnectMessage;
+import org.apache.geode.internal.admin.remote.AdminConsoleMessage;
+import org.apache.geode.internal.admin.remote.AdminFailureResponse;
+import org.apache.geode.internal.admin.remote.AlertLevelChangeMessage;
+import org.apache.geode.internal.admin.remote.AlertListenerMessage;
+import org.apache.geode.internal.admin.remote.AlertsNotificationMessage;
+import org.apache.geode.internal.admin.remote.AppCacheSnapshotMessage;
+import org.apache.geode.internal.admin.remote.BridgeServerRequest;
+import org.apache.geode.internal.admin.remote.BridgeServerResponse;
+import org.apache.geode.internal.admin.remote.CacheConfigRequest;
+import org.apache.geode.internal.admin.remote.CacheConfigResponse;
+import org.apache.geode.internal.admin.remote.CacheInfoRequest;
+import org.apache.geode.internal.admin.remote.CacheInfoResponse;
+import org.apache.geode.internal.admin.remote.CancelStatListenerRequest;
+import org.apache.geode.internal.admin.remote.CancelStatListenerResponse;
+import org.apache.geode.internal.admin.remote.CancellationMessage;
+import org.apache.geode.internal.admin.remote.ChangeRefreshIntervalMessage;
+import org.apache.geode.internal.admin.remote.ClientHealthStats;
+import org.apache.geode.internal.admin.remote.CompactRequest;
+import org.apache.geode.internal.admin.remote.CompactResponse;
+import org.apache.geode.internal.admin.remote.DestroyEntryMessage;
+import org.apache.geode.internal.admin.remote.DestroyRegionMessage;
+import org.apache.geode.internal.admin.remote.DurableClientInfoRequest;
+import org.apache.geode.internal.admin.remote.DurableClientInfoResponse;
+import org.apache.geode.internal.admin.remote.FetchDistLockInfoRequest;
+import org.apache.geode.internal.admin.remote.FetchDistLockInfoResponse;
+import org.apache.geode.internal.admin.remote.FetchHealthDiagnosisRequest;
+import org.apache.geode.internal.admin.remote.FetchHealthDiagnosisResponse;
+import org.apache.geode.internal.admin.remote.FetchHostRequest;
+import org.apache.geode.internal.admin.remote.FetchHostResponse;
+import org.apache.geode.internal.admin.remote.FetchResourceAttributesRequest;
+import org.apache.geode.internal.admin.remote.FetchResourceAttributesResponse;
+import org.apache.geode.internal.admin.remote.FetchStatsRequest;
+import org.apache.geode.internal.admin.remote.FetchStatsResponse;
+import org.apache.geode.internal.admin.remote.FetchSysCfgRequest;
+import org.apache.geode.internal.admin.remote.FetchSysCfgResponse;
+import org.apache.geode.internal.admin.remote.FlushAppCacheSnapshotMessage;
+import org.apache.geode.internal.admin.remote.HealthListenerMessage;
+import org.apache.geode.internal.admin.remote.LicenseInfoRequest;
+import org.apache.geode.internal.admin.remote.LicenseInfoResponse;
+import org.apache.geode.internal.admin.remote.MissingPersistentIDsRequest;
+import org.apache.geode.internal.admin.remote.MissingPersistentIDsResponse;
+import org.apache.geode.internal.admin.remote.ObjectDetailsRequest;
+import org.apache.geode.internal.admin.remote.ObjectDetailsResponse;
+import org.apache.geode.internal.admin.remote.ObjectNamesRequest;
+import org.apache.geode.internal.admin.remote.ObjectNamesResponse;
+import org.apache.geode.internal.admin.remote.PrepareRevokePersistentIDRequest;
+import org.apache.geode.internal.admin.remote.RefreshMemberSnapshotRequest;
+import org.apache.geode.internal.admin.remote.RefreshMemberSnapshotResponse;
+import org.apache.geode.internal.admin.remote.RegionAttributesRequest;
+import org.apache.geode.internal.admin.remote.RegionAttributesResponse;
+import org.apache.geode.internal.admin.remote.RegionRequest;
+import org.apache.geode.internal.admin.remote.RegionResponse;
+import org.apache.geode.internal.admin.remote.RegionSizeRequest;
+import org.apache.geode.internal.admin.remote.RegionSizeResponse;
+import org.apache.geode.internal.admin.remote.RegionStatisticsRequest;
+import org.apache.geode.internal.admin.remote.RegionStatisticsResponse;
+import org.apache.geode.internal.admin.remote.RegionSubRegionSizeRequest;
+import org.apache.geode.internal.admin.remote.RegionSubRegionsSizeResponse;
+import org.apache.geode.internal.admin.remote.RemoveHealthListenerRequest;
+import org.apache.geode.internal.admin.remote.RemoveHealthListenerResponse;
+import org.apache.geode.internal.admin.remote.ResetHealthStatusRequest;
+import org.apache.geode.internal.admin.remote.ResetHealthStatusResponse;
+import org.apache.geode.internal.admin.remote.RevokePersistentIDRequest;
+import org.apache.geode.internal.admin.remote.RevokePersistentIDResponse;
+import org.apache.geode.internal.admin.remote.RootRegionRequest;
+import org.apache.geode.internal.admin.remote.RootRegionResponse;
+import org.apache.geode.internal.admin.remote.ShutdownAllGatewayHubsRequest;
+import org.apache.geode.internal.admin.remote.ShutdownAllRequest;
+import org.apache.geode.internal.admin.remote.ShutdownAllResponse;
+import org.apache.geode.internal.admin.remote.SnapshotResultMessage;
+import org.apache.geode.internal.admin.remote.StatAlertsManagerAssignMessage;
+import org.apache.geode.internal.admin.remote.StatListenerMessage;
+import org.apache.geode.internal.admin.remote.StoreSysCfgRequest;
+import org.apache.geode.internal.admin.remote.StoreSysCfgResponse;
+import org.apache.geode.internal.admin.remote.SubRegionRequest;
+import org.apache.geode.internal.admin.remote.SubRegionResponse;
+import org.apache.geode.internal.admin.remote.TailLogRequest;
+import org.apache.geode.internal.admin.remote.TailLogResponse;
+import org.apache.geode.internal.admin.remote.UpdateAlertDefinitionMessage;
+import org.apache.geode.internal.admin.remote.VersionInfoRequest;
+import org.apache.geode.internal.admin.remote.VersionInfoResponse;
+import org.apache.geode.internal.admin.statalerts.GaugeThresholdDecoratorImpl;
+import org.apache.geode.internal.admin.statalerts.NumberThresholdDecoratorImpl;
+import org.apache.geode.internal.cache.AddCacheServerProfileMessage;
+import org.apache.geode.internal.cache.ClientRegionEventImpl;
+import org.apache.geode.internal.cache.CacheServerAdvisor.CacheServerProfile;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor;
+import org.apache.geode.internal.cache.CloseCacheMessage;
+import org.apache.geode.internal.cache.ControllerAdvisor.ControllerProfile;
+import org.apache.geode.internal.cache.CreateRegionProcessor;
+import org.apache.geode.internal.cache.DestroyOperation;
+import org.apache.geode.internal.cache.DestroyPartitionedRegionMessage;
+import org.apache.geode.internal.cache.DestroyRegionOperation;
+import org.apache.geode.internal.cache.DistTXPrecommitMessage;
+import org.apache.geode.internal.cache.DistTXCommitMessage;
+import org.apache.geode.internal.cache.DistTXRollbackMessage;
+import org.apache.geode.internal.cache.DistributedClearOperation.ClearRegionMessage;
+import org.apache.geode.internal.cache.DistributedClearOperation.ClearRegionWithContextMessage;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.EntryVersionsList;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllMessage;
+import org.apache.geode.internal.cache.DistributedRegionFunctionStreamingMessage;
+import org.apache.geode.internal.cache.DistributedRemoveAllOperation.RemoveAllMessage;
+import org.apache.geode.internal.cache.DistributedTombstoneOperation.TombstoneMessage;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.FilterProfile;
+import org.apache.geode.internal.cache.FindDurableQueueProcessor.FindDurableQueueMessage;
+import org.apache.geode.internal.cache.FindDurableQueueProcessor.FindDurableQueueReply;
+import org.apache.geode.internal.cache.FindRemoteTXMessage;
+import org.apache.geode.internal.cache.FindRemoteTXMessage.FindRemoteTXMessageReply;
+import org.apache.geode.internal.cache.FindVersionTagOperation.FindVersionTagMessage;
+import org.apache.geode.internal.cache.FindVersionTagOperation.VersionTagReply;
+import org.apache.geode.internal.cache.FunctionStreamingOrderedReplyMessage;
+import org.apache.geode.internal.cache.FunctionStreamingReplyMessage;
+import org.apache.geode.internal.cache.HARegion;
+import org.apache.geode.internal.cache.InitialImageFlowControl.FlowControlPermitMessage;
+import org.apache.geode.internal.cache.InitialImageOperation;
+import org.apache.geode.internal.cache.InitialImageOperation.InitialImageVersionedEntryList;
+import org.apache.geode.internal.cache.InvalidateOperation;
+import org.apache.geode.internal.cache.InvalidatePartitionedRegionMessage;
+import org.apache.geode.internal.cache.InvalidateRegionOperation.InvalidateRegionMessage;
+import org.apache.geode.internal.cache.JtaAfterCompletionMessage;
+import org.apache.geode.internal.cache.JtaBeforeCompletionMessage;
+import org.apache.geode.internal.cache.MemberFunctionStreamingMessage;
+import org.apache.geode.internal.cache.Node;
+import org.apache.geode.internal.cache.PRQueryProcessor;
+import org.apache.geode.internal.cache.PartitionRegionConfig;
+import org.apache.geode.internal.cache.PreferBytesCachedDeserializable;
+import org.apache.geode.internal.cache.RegionEventImpl;
+import org.apache.geode.internal.cache.ReleaseClearLockMessage;
+import org.apache.geode.internal.cache.RemoteContainsKeyValueMessage;
+import org.apache.geode.internal.cache.RemoteDestroyMessage;
+import org.apache.geode.internal.cache.RemoteFetchEntryMessage;
+import org.apache.geode.internal.cache.RemoteFetchVersionMessage;
+import org.apache.geode.internal.cache.RemoteGetMessage;
+import org.apache.geode.internal.cache.RemoteInvalidateMessage;
+import org.apache.geode.internal.cache.RemotePutAllMessage;
+import org.apache.geode.internal.cache.RemotePutMessage;
+import org.apache.geode.internal.cache.RemoteRegionOperation;
+import org.apache.geode.internal.cache.RemoteRegionOperation.RemoteRegionOperationReplyMessage;
+import org.apache.geode.internal.cache.RemoteRemoveAllMessage;
+import org.apache.geode.internal.cache.RoleEventImpl;
+import org.apache.geode.internal.cache.SearchLoadAndWriteProcessor;
+import org.apache.geode.internal.cache.SendQueueOperation.SendQueueMessage;
+import org.apache.geode.internal.cache.ServerPingMessage;
+import org.apache.geode.internal.cache.StateFlushOperation.StateMarkerMessage;
+import org.apache.geode.internal.cache.StateFlushOperation.StateStabilizationMessage;
+import org.apache.geode.internal.cache.StateFlushOperation.StateStabilizedMessage;
+import org.apache.geode.internal.cache.StoreAllCachedDeserializable;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.cache.TXCommitMessage.CommitProcessForLockIdMessage;
+import org.apache.geode.internal.cache.TXCommitMessage.CommitProcessForTXIdMessage;
+import org.apache.geode.internal.cache.TXCommitMessage.CommitProcessQueryMessage;
+import org.apache.geode.internal.cache.TXCommitMessage.CommitProcessQueryReplyMessage;
+import org.apache.geode.internal.cache.TXEntryState;
+import org.apache.geode.internal.cache.TXId;
+import org.apache.geode.internal.cache.TXManagerImpl;
+import org.apache.geode.internal.cache.TXRemoteCommitMessage;
+import org.apache.geode.internal.cache.TXRemoteCommitMessage.TXRemoteCommitReplyMessage;
+import org.apache.geode.internal.cache.TXRemoteRollbackMessage;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.cache.UpdateAttributesProcessor;
+import org.apache.geode.internal.cache.UpdateEntryVersionOperation.UpdateEntryVersionMessage;
+import org.apache.geode.internal.cache.UpdateOperation;
+import org.apache.geode.internal.cache.VMCachedDeserializable;
+import org.apache.geode.internal.cache.compression.SnappyCompressedCachedDeserializable;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceManagerProfile;
+import org.apache.geode.internal.cache.control.ResourceAdvisor.ResourceProfileMessage;
+import org.apache.geode.internal.cache.ha.HARegionQueue.DispatchedAndCurrentEvents;
+import org.apache.geode.internal.cache.ha.QueueRemovalMessage;
+import org.apache.geode.internal.cache.locks.TXLockBatch;
+import org.apache.geode.internal.cache.locks.TXLockIdImpl;
+import org.apache.geode.internal.cache.locks.TXLockUpdateParticipantsMessage;
+import org.apache.geode.internal.cache.locks.TXLockUpdateParticipantsMessage.TXLockUpdateParticipantsReplyMessage;
+import org.apache.geode.internal.cache.locks.TXOriginatorRecoveryProcessor.TXOriginatorRecoveryMessage;
+import org.apache.geode.internal.cache.locks.TXOriginatorRecoveryProcessor.TXOriginatorRecoveryReplyMessage;
+import org.apache.geode.internal.cache.partitioned.AllBucketProfilesUpdateMessage;
+import org.apache.geode.internal.cache.partitioned.BecomePrimaryBucketMessage;
+import org.apache.geode.internal.cache.partitioned.BecomePrimaryBucketMessage.BecomePrimaryBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.BucketBackupMessage;
+import org.apache.geode.internal.cache.partitioned.BucketCountLoadProbe;
+import org.apache.geode.internal.cache.partitioned.BucketProfileUpdateMessage;
+import org.apache.geode.internal.cache.partitioned.BucketSizeMessage;
+import org.apache.geode.internal.cache.partitioned.BucketSizeMessage.BucketSizeReplyMessage;
+import org.apache.geode.internal.cache.partitioned.ContainsKeyValueMessage;
+import org.apache.geode.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueReplyMessage;
+import org.apache.geode.internal.cache.partitioned.CreateBucketMessage;
+import org.apache.geode.internal.cache.partitioned.CreateBucketMessage.CreateBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.DeposePrimaryBucketMessage;
+import org.apache.geode.internal.cache.partitioned.DeposePrimaryBucketMessage.DeposePrimaryBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.DestroyMessage;
+import org.apache.geode.internal.cache.partitioned.DestroyRegionOnDataStoreMessage;
+import org.apache.geode.internal.cache.partitioned.DumpAllPRConfigMessage;
+import org.apache.geode.internal.cache.partitioned.DumpB2NRegion;
+import org.apache.geode.internal.cache.partitioned.DumpB2NRegion.DumpB2NReplyMessage;
+import org.apache.geode.internal.cache.partitioned.DumpBucketsMessage;
+import org.apache.geode.internal.cache.partitioned.EndBucketCreationMessage;
+import org.apache.geode.internal.cache.partitioned.FetchBulkEntriesMessage;
+import org.apache.geode.internal.cache.partitioned.FetchBulkEntriesMessage.FetchBulkEntriesReplyMessage;
+import org.apache.geode.internal.cache.partitioned.FetchEntriesMessage;
+import org.apache.geode.internal.cache.partitioned.FetchEntriesMessage.FetchEntriesReplyMessage;
+import org.apache.geode.internal.cache.partitioned.FetchEntryMessage;
+import org.apache.geode.internal.cache.partitioned.FetchEntryMessage.FetchEntryReplyMessage;
+import org.apache.geode.internal.cache.partitioned.FetchKeysMessage;
+import org.apache.geode.internal.cache.partitioned.FetchKeysMessage.FetchKeysReplyMessage;
+import org.apache.geode.internal.cache.partitioned.FetchPartitionDetailsMessage;
+import org.apache.geode.internal.cache.partitioned.FetchPartitionDetailsMessage.FetchPartitionDetailsReplyMessage;
+import org.apache.geode.internal.cache.partitioned.FlushMessage;
+import org.apache.geode.internal.cache.partitioned.GetMessage;
+import org.apache.geode.internal.cache.partitioned.GetMessage.GetReplyMessage;
+import org.apache.geode.internal.cache.partitioned.IdentityRequestMessage;
+import org.apache.geode.internal.cache.partitioned.IdentityRequestMessage.IdentityReplyMessage;
+import org.apache.geode.internal.cache.partitioned.IdentityUpdateMessage;
+import org.apache.geode.internal.cache.partitioned.IndexCreationMsg;
+import org.apache.geode.internal.cache.partitioned.IndexCreationMsg.IndexCreationReplyMsg;
+import org.apache.geode.internal.cache.partitioned.InterestEventMessage;
+import org.apache.geode.internal.cache.partitioned.InterestEventMessage.InterestEventReplyMessage;
+import org.apache.geode.internal.cache.partitioned.InvalidateMessage;
+import org.apache.geode.internal.cache.partitioned.ManageBackupBucketMessage;
+import org.apache.geode.internal.cache.partitioned.ManageBackupBucketMessage.ManageBackupBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.ManageBucketMessage;
+import org.apache.geode.internal.cache.partitioned.ManageBucketMessage.ManageBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.MoveBucketMessage;
+import org.apache.geode.internal.cache.partitioned.MoveBucketMessage.MoveBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.PRSanityCheckMessage;
+import org.apache.geode.internal.cache.partitioned.PRTombstoneMessage;
+import org.apache.geode.internal.cache.partitioned.PRUpdateEntryVersionMessage;
+import org.apache.geode.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
+import org.apache.geode.internal.cache.partitioned.PrimaryRequestMessage;
+import org.apache.geode.internal.cache.partitioned.PrimaryRequestMessage.PrimaryRequestReplyMessage;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage.PutAllReplyMessage;
+import org.apache.geode.internal.cache.partitioned.PutMessage;
+import org.apache.geode.internal.cache.partitioned.PutMessage.PutReplyMessage;
+import org.apache.geode.internal.cache.partitioned.QueryMessage;
+import org.apache.geode.internal.cache.partitioned.RegionAdvisor;
+import org.apache.geode.internal.cache.partitioned.RemoteFetchKeysMessage;
+import org.apache.geode.internal.cache.partitioned.RemoteSizeMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveBucketMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveBucketMessage.RemoveBucketReplyMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveIndexesMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveIndexesMessage.RemoveIndexesReplyMessage;
+import org.apache.geode.internal.cache.partitioned.SizeMessage;
+import org.apache.geode.internal.cache.partitioned.SizeMessage.SizeReplyMessage;
+import org.apache.geode.internal.cache.partitioned.SizedBasedLoadProbe;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.persistence.MembershipFlushRequest;
+import org.apache.geode.internal.cache.persistence.MembershipViewRequest;
+import org.apache.geode.internal.cache.persistence.MembershipViewRequest.MembershipViewReplyMessage;
+import org.apache.geode.internal.cache.persistence.PersistentStateQueryMessage;
+import org.apache.geode.internal.cache.persistence.PersistentStateQueryMessage.PersistentStateQueryReplyMessage;
+import org.apache.geode.internal.cache.persistence.PrepareNewPersistentMemberMessage;
+import org.apache.geode.internal.cache.persistence.RemovePersistentMemberMessage;
+import org.apache.geode.internal.cache.snapshot.FlowController.FlowControlAbortMessage;
+import org.apache.geode.internal.cache.snapshot.FlowController.FlowControlAckMessage;
+import org.apache.geode.internal.cache.snapshot.SnapshotPacket;
+import org.apache.geode.internal.cache.snapshot.SnapshotPacket.SnapshotRecord;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier.ServerInterestRegistrationMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientBlacklistProcessor.ClientBlacklistMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientDataSerializerMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientInstantiatorMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientInterestMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientMarkerMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientPingMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.ClientTombstoneMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientUpdateMessageImpl;
+import org.apache.geode.internal.cache.tier.sockets.HAEventWrapper;
+import org.apache.geode.internal.cache.tier.sockets.InterestResultPolicyImpl;
+import org.apache.geode.internal.cache.tier.sockets.ObjectPartList;
+import org.apache.geode.internal.cache.tier.sockets.ObjectPartList651;
+import org.apache.geode.internal.cache.tier.sockets.RemoveClientFromBlacklistMessage;
+import org.apache.geode.internal.cache.tier.sockets.SerializedObjectPartList;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.cache.versions.DiskRegionVersionVector;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VMRegionVersionVector;
+import org.apache.geode.internal.cache.versions.VMVersionTag;
+import org.apache.geode.internal.cache.wan.GatewaySenderAdvisor;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventCallbackArgument;
+import org.apache.geode.internal.cache.wan.GatewaySenderEventImpl;
+import org.apache.geode.internal.cache.wan.parallel.ParallelQueueBatchRemovalMessage;
+import org.apache.geode.internal.cache.wan.parallel.ParallelQueueBatchRemovalMessage.BatchRemovalReplyMessage;
+import org.apache.geode.internal.cache.wan.parallel.ParallelQueueRemovalMessage;
+import org.apache.geode.internal.cache.wan.serial.BatchDestroyOperation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.management.internal.JmxManagerAdvisor.JmxManagerProfile;
+import org.apache.geode.management.internal.JmxManagerAdvisor.JmxManagerProfileMessage;
+import org.apache.geode.management.internal.JmxManagerLocatorRequest;
+import org.apache.geode.management.internal.JmxManagerLocatorResponse;
+import org.apache.geode.management.internal.ManagerStartupMessage;
+import org.apache.geode.management.internal.cli.functions.CliFunctionResult;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationRequest;
+import org.apache.geode.management.internal.configuration.messages.ConfigurationResponse;
+import org.apache.geode.pdx.internal.CheckTypeRegistryState;
+import org.apache.geode.pdx.internal.EnumId;
+import org.apache.geode.pdx.internal.EnumInfo;
 
 /**
  * Factory for instances of DataSerializableFixedID instances.
@@ -1010,11 +1010,11 @@ public final class DSFIDFactory implements DataSerializableFixedID {
     registerDSFID(FLOW_CONTROL_ACK, FlowControlAckMessage.class);
     registerDSFID(FLOW_CONTROL_ABORT, FlowControlAbortMessage.class);
     registerDSFID(MGMT_COMPACT_REQUEST,
-        com.gemstone.gemfire.management.internal.messages.CompactRequest.class);
+        org.apache.geode.management.internal.messages.CompactRequest.class);
     registerDSFID(MGMT_COMPACT_RESPONSE,
-        com.gemstone.gemfire.management.internal.messages.CompactResponse.class);
+        org.apache.geode.management.internal.messages.CompactResponse.class);
     registerDSFID(MGMT_FEDERATION_COMPONENT,
-        com.gemstone.gemfire.management.internal.FederationComponent.class);
+        org.apache.geode.management.internal.FederationComponent.class);
     registerDSFID(LOCATOR_STATUS_REQUEST, LocatorStatusRequest.class);
     registerDSFID(LOCATOR_STATUS_RESPONSE, LocatorStatusResponse.class);
     registerDSFID(R_FETCH_VERSION_MESSAGE, RemoteFetchVersionMessage.class);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/DSFIDNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DSFIDNotFoundException.java b/geode-core/src/main/java/org/apache/geode/internal/DSFIDNotFoundException.java
index 895ddb9..f73965d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DSFIDNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DSFIDNotFoundException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.NotSerializableException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java b/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
index d3e4846..d4829d0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.*;
+import org.apache.geode.*;
 
 import java.io.*;
 
@@ -531,10 +531,10 @@ public interface DataSerializableFixedID extends SerializationVersions {
   // Token.EndOfStream
   public static final byte END_OF_STREAM_TOKEN = 124;
 
-  /** {@link com.gemstone.gemfire.internal.cache.partitioned.GetMessage.GetReplyMessage} */
+  /** {@link org.apache.geode.internal.cache.partitioned.GetMessage.GetReplyMessage} */
   public static final byte PR_GET_REPLY_MESSAGE = 125;
 
-  /** {@link com.gemstone.gemfire.internal.cache.Node} */
+  /** {@link org.apache.geode.internal.cache.Node} */
   public static final byte PR_NODE = 126;
 
   /** A header byte meaning that the next element in the stream is a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/DistributionLocator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DistributionLocator.java b/geode-core/src/main/java/org/apache/geode/internal/DistributionLocator.java
index 2549c7a..8c10e91 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DistributionLocator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DistributionLocator.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
-
-import com.gemstone.gemfire.SystemFailure;
-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.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+package org.apache.geode.internal;
+
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.InternalLocator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;
@@ -33,7 +33,7 @@ import java.util.Properties;
 
 /**
  * This class is used to work with a managed VM that hosts a {@link
- * com.gemstone.gemfire.distributed.Locator}.
+ * org.apache.geode.distributed.Locator}.
  *
  * @since GemFire 2.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ExternalizableDSFID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ExternalizableDSFID.java b/geode-core/src/main/java/org/apache/geode/internal/ExternalizableDSFID.java
index 13a86d3..009df2e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ExternalizableDSFID.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ExternalizableDSFID.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/FileUtil.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/FileUtil.java b/geode-core/src/main/java/org/apache/geode/internal/FileUtil.java
index 276f6aa..8ac9a21 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/FileUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/FileUtil.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.io.*;
 import java.net.URL;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/GemFireVersion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/GemFireVersion.java b/geode-core/src/main/java/org/apache/geode/internal/GemFireVersion.java
index d8fa21b..ea6b16d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/GemFireVersion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/GemFireVersion.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.File;
 import java.io.InputStream;
@@ -28,9 +28,9 @@ import java.util.Properties;
 import java.util.StringTokenizer;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This class provides build and version information about GemFire.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/GfeConsoleReaderFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/GfeConsoleReaderFactory.java b/geode-core/src/main/java/org/apache/geode/internal/GfeConsoleReaderFactory.java
index 2ad94a6..b3ee75b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/GfeConsoleReaderFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/GfeConsoleReaderFactory.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.Console;
 
-import com.gemstone.gemfire.management.internal.cli.CliUtil;
-import com.gemstone.gemfire.management.internal.cli.LogWrapper;
-import com.gemstone.gemfire.management.internal.cli.util.GfshConsoleReader;
+import org.apache.geode.management.internal.cli.CliUtil;
+import org.apache.geode.management.internal.cli.LogWrapper;
+import org.apache.geode.management.internal.cli.util.GfshConsoleReader;
 
 /**
  * Factory for Console Reader Utility.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/HeapDataOutputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/HeapDataOutputStream.java b/geode-core/src/main/java/org/apache/geode/internal/HeapDataOutputStream.java
index eaad26e..f45193d 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/HeapDataOutputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/HeapDataOutputStream.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.BytesAndBitsForCompactor;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.tcp.ByteBufferInputStream.ByteSource;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.BytesAndBitsForCompactor;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.tcp.ByteBufferInputStream.ByteSource;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/HistogramStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/HistogramStats.java b/geode-core/src/main/java/org/apache/geode/internal/HistogramStats.java
index eeff10a..7636db2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/HistogramStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/HistogramStats.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
 
 
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/InternalDataSerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/InternalDataSerializer.java b/geode-core/src/main/java/org/apache/geode/internal/InternalDataSerializer.java
index 730fe6f..6e7aa55 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/InternalDataSerializer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/InternalDataSerializer.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.util.concurrent.CopyOnWriteHashMap;
-import com.gemstone.gemfire.pdx.NonPortableClassException;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializable;
-import com.gemstone.gemfire.pdx.PdxSerializer;
-import com.gemstone.gemfire.pdx.internal.*;
-import com.gemstone.gemfire.pdx.internal.AutoSerializableManager.AutoClassInfo;
+package org.apache.geode.internal;
+
+import org.apache.geode.*;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.cache.EnumListenerEvent;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PoolManagerImpl;
+import org.apache.geode.internal.cache.tier.sockets.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.util.concurrent.CopyOnWriteHashMap;
+import org.apache.geode.pdx.NonPortableClassException;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializable;
+import org.apache.geode.pdx.PdxSerializer;
+import org.apache.geode.pdx.internal.*;
+import org.apache.geode.pdx.internal.AutoSerializableManager.AutoClassInfo;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
@@ -1566,7 +1566,7 @@ public abstract class InternalDataSerializer extends DataSerializer implements D
    */
   private static boolean isGemfireObject(Object o) {
     return ((o instanceof Function) // fixes 43691
-            || o.getClass().getName().startsWith("com.gemstone.")
+            || o.getClass().getName().startsWith("org.apache.")
              || o.getClass().getName().startsWith("org.apache.geode"))
       && !(o instanceof PdxSerializerObject);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/InternalEntity.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/InternalEntity.java b/geode-core/src/main/java/org/apache/geode/internal/InternalEntity.java
index 2b76546..0a41064 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/InternalEntity.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/InternalEntity.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /**
  * A marker interface to identify internal objects that are stored in the Cache at the same place that user objects

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java b/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
index 0398787..bb15097 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -29,29 +29,29 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.Instantiator;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.PoolManagerImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientNotifier;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheClientUpdater;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CacheServerHelper;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientInstantiatorMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.Part;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.i18n.StringId;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.Instantiator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.internal.cache.EnumListenerEvent;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.PoolManagerImpl;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientNotifier;
+import org.apache.geode.internal.cache.tier.sockets.CacheClientUpdater;
+import org.apache.geode.internal.cache.tier.sockets.CacheServerHelper;
+import org.apache.geode.internal.cache.tier.sockets.ClientInstantiatorMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.Part;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.i18n.StringId;
 
 /**
- * Contains the implementation of {@link com.gemstone.gemfire.Instantiator}
+ * Contains the implementation of {@link org.apache.geode.Instantiator}
  * registration and distribution messaging (and shared memory management).
  *
  * @since GemFire 3.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/InternalStatisticsDisabledException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/InternalStatisticsDisabledException.java b/geode-core/src/main/java/org/apache/geode/internal/InternalStatisticsDisabledException.java
index 09a474a..9382989 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/InternalStatisticsDisabledException.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/InternalStatisticsDisabledException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.GemFireCheckedException;
+import org.apache.geode.GemFireCheckedException;
 
 /**
  * Thrown if statistics are requested when statistics are disabled on the
@@ -25,10 +25,10 @@ import com.gemstone.gemfire.GemFireCheckedException;
  *
  *
  *
- * @see com.gemstone.gemfire.cache.AttributesFactory#setStatisticsEnabled(boolean)
- * @see com.gemstone.gemfire.cache.RegionAttributes#getStatisticsEnabled
- * @see com.gemstone.gemfire.cache.Region#getStatistics
- * @see com.gemstone.gemfire.cache.Region.Entry#getStatistics
+ * @see org.apache.geode.cache.AttributesFactory#setStatisticsEnabled(boolean)
+ * @see org.apache.geode.cache.RegionAttributes#getStatisticsEnabled
+ * @see org.apache.geode.cache.Region#getStatistics
+ * @see org.apache.geode.cache.Region.Entry#getStatistics
  * @since GemFire 3.0
  */
 public class InternalStatisticsDisabledException extends GemFireCheckedException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/JarClassLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/JarClassLoader.java b/geode-core/src/main/java/org/apache/geode/internal/JarClassLoader.java
index 183a477..f261400 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/JarClassLoader.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/JarClassLoader.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
@@ -46,14 +46,14 @@ import java.util.jar.JarInputStream;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.pdx.internal.TypeRegistry;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.pdx.internal.TypeRegistry;
 
 /**
  * ClassLoader for a single JAR file.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/JarDeployer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/JarDeployer.java b/geode-core/src/main/java/org/apache/geode/internal/JarDeployer.java
index 020d429..28026db 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/JarDeployer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/JarDeployer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.BufferedInputStream;
 import java.io.ByteArrayOutputStream;
@@ -42,8 +42,8 @@ import java.util.regex.Pattern;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.logging.LogService;
 
 public class JarDeployer implements Serializable {
   private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ManagerInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ManagerInfo.java b/geode-core/src/main/java/org/apache/geode/internal/ManagerInfo.java
index ed18275..3a9db41 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ManagerInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ManagerInfo.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/MigrationClient.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/MigrationClient.java b/geode-core/src/main/java/org/apache/geode/internal/MigrationClient.java
index 2c81e90..6be14ee 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/MigrationClient.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/MigrationClient.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
-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.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 import java.io.*;
 import java.net.InetAddress;
@@ -33,8 +33,8 @@ import java.net.Socket;
 import java.net.SocketAddress;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_PORT;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
 
 /**
  * MigrationClient is used to retrieve all of the data for a region from


[17/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegion.java
index 3f511f0..e4dfdcc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegion.java
@@ -14,27 +14,27 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.EnumSet;
 import java.util.Map;
 import java.util.concurrent.atomic.AtomicInteger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.compression.Compressor;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.cache.DiskInitFile.DiskRegionFlag;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl.AsyncDiskEntry;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIIStatus;
-import com.gemstone.gemfire.internal.cache.LocalRegion.RegionEntryCallback;
-import com.gemstone.gemfire.internal.cache.persistence.BytesAndBits;
-import com.gemstone.gemfire.internal.cache.persistence.DiskExceptionHandler;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.cache.persistence.DiskStoreID;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionStamp;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.compression.Compressor;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskInitFile.DiskRegionFlag;
+import org.apache.geode.internal.cache.DiskStoreImpl.AsyncDiskEntry;
+import org.apache.geode.internal.cache.InitialImageOperation.GIIStatus;
+import org.apache.geode.internal.cache.LocalRegion.RegionEntryCallback;
+import org.apache.geode.internal.cache.persistence.BytesAndBits;
+import org.apache.geode.internal.cache.persistence.DiskExceptionHandler;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.cache.persistence.DiskStoreID;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
 import joptsimple.internal.Strings;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegionStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegionStats.java
index 014fd6f..7d9c0ad 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegionStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskRegionStats.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * GemFire statistics about a {@link DiskRegion}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreAttributes.java
index 451a907..ea2a35d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreAttributes.java
@@ -17,14 +17,14 @@
 /**
  *
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.File;
 import java.io.Serializable;
 import java.util.UUID;
 
-import com.gemstone.gemfire.cache.DiskStore;
-import com.gemstone.gemfire.cache.DiskStoreFactory;
+import org.apache.geode.cache.DiskStore;
+import org.apache.geode.cache.DiskStoreFactory;
 
 /**
  * Creates an attribute object for DiskStore.
@@ -73,28 +73,28 @@ public class DiskStoreAttributes implements Serializable, DiskStore {
   }
 
   /* (non-Javadoc)
-  * @see com.gemstone.gemfire.cache.DiskStore#getAllowForceCompaction()
+  * @see org.apache.geode.cache.DiskStore#getAllowForceCompaction()
   */
   public boolean getAllowForceCompaction() {
     return this.allowForceCompaction;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getAutoCompact()
+   * @see org.apache.geode.cache.DiskStore#getAutoCompact()
    */
   public boolean getAutoCompact() {
     return this.autoCompact;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getCompactionThreshold()
+   * @see org.apache.geode.cache.DiskStore#getCompactionThreshold()
    */
   public int getCompactionThreshold() {
     return this.compactionThreshold;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getDiskDirSizes()
+   * @see org.apache.geode.cache.DiskStore#getDiskDirSizes()
    */
   public int[] getDiskDirSizes() {
     int[] result = new int[this.diskDirSizes.length];
@@ -103,7 +103,7 @@ public class DiskStoreAttributes implements Serializable, DiskStore {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getDiskDirs()
+   * @see org.apache.geode.cache.DiskStore#getDiskDirs()
    */
   public File[] getDiskDirs() {
     File[] result = new File[this.diskDirs.length];
@@ -112,7 +112,7 @@ public class DiskStoreAttributes implements Serializable, DiskStore {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getMaxOplogSize()
+   * @see org.apache.geode.cache.DiskStore#getMaxOplogSize()
    */
   public long getMaxOplogSize() {
     // TODO Auto-generated method stub
@@ -127,28 +127,28 @@ public class DiskStoreAttributes implements Serializable, DiskStore {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getName()
+   * @see org.apache.geode.cache.DiskStore#getName()
    */
   public String getName() {
     return this.name;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getQueueSize()
+   * @see org.apache.geode.cache.DiskStore#getQueueSize()
    */
   public int getQueueSize() {
     return this.queueSize;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getTimeInterval()
+   * @see org.apache.geode.cache.DiskStore#getTimeInterval()
    */
   public long getTimeInterval() {
     return this.timeInterval;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.cache.DiskStore#getWriteBufferSize()
+   * @see org.apache.geode.cache.DiskStore#getWriteBufferSize()
    */
   public int getWriteBufferSize() {
     return this.writeBufferSize;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreBackup.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreBackup.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreBackup.java
index aacec8c..5de7b1a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreBackup.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreBackup.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.File;
 import java.util.Arrays;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.cache.persistence.BackupInspector;
+import org.apache.geode.internal.cache.persistence.BackupInspector;
 
 /**
  * This class manages the state of the backup of an individual disk store. It
  * holds the list of oplogs that still need to be backed up, along with the
  * lists of oplog files that should be deleted when the oplog is backed up. See
- * {@link DiskStoreImpl#startBackup(File, BackupInspector, com.gemstone.gemfire.internal.cache.persistence.RestoreScript)}
+ * {@link DiskStoreImpl#startBackup(File, BackupInspector, org.apache.geode.internal.cache.persistence.RestoreScript)}
  * 
  * 
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreFactoryImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreFactoryImpl.java
index 1c57db9..b3482d0 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreFactoryImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreFactoryImpl.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 import java.io.File;
 import java.io.IOException;
 import java.util.Arrays;
 
-import com.gemstone.gemfire.GemFireIOException;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.DiskStoreFactory;
-import com.gemstone.gemfire.cache.DiskStore;
-import com.gemstone.gemfire.distributed.internal.ResourceEvent;
-import com.gemstone.gemfire.internal.cache.DiskStoreAttributes;
-import com.gemstone.gemfire.internal.cache.persistence.BackupManager;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheCreation;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
-import com.gemstone.gemfire.internal.cache.xmlcache.DiskStoreAttributesCreation;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.TypeRegistry;
+import org.apache.geode.GemFireIOException;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.DiskStoreFactory;
+import org.apache.geode.cache.DiskStore;
+import org.apache.geode.distributed.internal.ResourceEvent;
+import org.apache.geode.internal.cache.DiskStoreAttributes;
+import org.apache.geode.internal.cache.persistence.BackupManager;
+import org.apache.geode.internal.cache.xmlcache.CacheCreation;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.cache.xmlcache.DiskStoreAttributesCreation;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.TypeRegistry;
 
 /**
  * Implementation of DiskStoreFactory 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreImpl.java
index 0aabda0..921d2b1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreImpl.java
@@ -14,44 +14,44 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-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.i18n.StringId;
-import com.gemstone.gemfire.internal.FileUtil;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.DiskEntry.Helper.ValueWrapper;
-import com.gemstone.gemfire.internal.cache.DiskEntry.RecoveredEntry;
-import com.gemstone.gemfire.internal.cache.ExportDiskRegion.ExportWriter;
-import com.gemstone.gemfire.internal.cache.lru.LRUAlgorithm;
-import com.gemstone.gemfire.internal.cache.lru.LRUStatistics;
-import com.gemstone.gemfire.internal.cache.persistence.*;
-import com.gemstone.gemfire.internal.cache.snapshot.GFSnapshot;
-import com.gemstone.gemfire.internal.cache.snapshot.GFSnapshot.SnapshotWriter;
-import com.gemstone.gemfire.internal.cache.snapshot.SnapshotPacket.SnapshotRecord;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-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.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.pdx.internal.EnumInfo;
-import com.gemstone.gemfire.pdx.internal.PdxField;
-import com.gemstone.gemfire.pdx.internal.PdxType;
-import com.gemstone.gemfire.pdx.internal.PeerTypeRegistration;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.FileUtil;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.DiskEntry.Helper.ValueWrapper;
+import org.apache.geode.internal.cache.DiskEntry.RecoveredEntry;
+import org.apache.geode.internal.cache.ExportDiskRegion.ExportWriter;
+import org.apache.geode.internal.cache.lru.LRUAlgorithm;
+import org.apache.geode.internal.cache.lru.LRUStatistics;
+import org.apache.geode.internal.cache.persistence.*;
+import org.apache.geode.internal.cache.snapshot.GFSnapshot;
+import org.apache.geode.internal.cache.snapshot.GFSnapshot.SnapshotWriter;
+import org.apache.geode.internal.cache.snapshot.SnapshotPacket.SnapshotRecord;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionStamp;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.pdx.internal.EnumInfo;
+import org.apache.geode.pdx.internal.PdxField;
+import org.apache.geode.pdx.internal.PdxType;
+import org.apache.geode.pdx.internal.PeerTypeRegistration;
 import it.unimi.dsi.fastutil.ints.IntOpenHashSet;
 import it.unimi.dsi.fastutil.longs.LongOpenHashSet;
 import org.apache.logging.log4j.Logger;
@@ -72,7 +72,7 @@ import java.util.concurrent.locks.ReentrantReadWriteLock.WriteLock;
 import java.util.regex.Matcher;
 import java.util.regex.Pattern;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 /**
  * Represents a (disk-based) persistent store for region data. Used for both
@@ -4360,9 +4360,9 @@ public class DiskStoreImpl implements DiskStore {
     props.setProperty(CACHE_XML_FILE, "");
     DistributedSystem ds = DistributedSystem.connect(props);
     offlineDS = ds;
-    Cache c = com.gemstone.gemfire.cache.CacheFactory.create(ds);
+    Cache c = org.apache.geode.cache.CacheFactory.create(ds);
     offlineCache = c;
-    com.gemstone.gemfire.cache.DiskStoreFactory dsf = c
+    org.apache.geode.cache.DiskStoreFactory dsf = c
         .createDiskStoreFactory();
     dsf.setDiskDirs(dsDirs);
     if (offlineCompacting && maxOplogSize != -1L) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreMonitor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreMonitor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreMonitor.java
index b81142b..110872a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreMonitor.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 import org.apache.logging.log4j.Logger;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreObserver.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreObserver.java
index a756e98..14c8328 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreObserver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Map;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreStats.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreStats.java
index e5f4bb2..3e5aefb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreStats.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreStats.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.*;
+//import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
 
 /**
  * GemFire statistics about a {@link DiskStoreImpl}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreTask.java
index f593731..208a31a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskStoreTask.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DiskWriteAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskWriteAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskWriteAttributesImpl.java
index 3e005cb..61b16b1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DiskWriteAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DiskWriteAttributesImpl.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.*;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.File;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistPeerTXStateStub.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistPeerTXStateStub.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistPeerTXStateStub.java
index 5c53df1..5cdbc45 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistPeerTXStateStub.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistPeerTXStateStub.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -22,16 +22,16 @@ import java.util.HashSet;
 import java.util.Set;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * DistPeerTXStateStub lives on the transaction coordinator for a distributed
@@ -152,7 +152,7 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateStub#putEntry(com.gemstone.gemfire
+   * org.apache.geode.internal.cache.TXStateStub#putEntry(org.apache.geode
    * .internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object,
    * boolean, long, boolean)
    */
@@ -176,7 +176,7 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#putEntryOnRemote(com
+   * org.apache.geode.internal.cache.InternalDataView#putEntryOnRemote(com
    * .gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean,
    * java.lang.Object, boolean, long, boolean)
    */
@@ -201,8 +201,8 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateInterface#destroyExistingEntry
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean,
+   * org.apache.geode.internal.cache.TXStateInterface#destroyExistingEntry
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean,
    * java.lang.Object)
    */
   public void destroyExistingEntry(EntryEventImpl event, boolean cacheWrite,
@@ -216,8 +216,8 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#destroyOnRemote(java
-   * .lang.Integer, com.gemstone.gemfire.internal.cache.EntryEventImpl,
+   * org.apache.geode.internal.cache.InternalDataView#destroyOnRemote(java
+   * .lang.Integer, org.apache.geode.internal.cache.EntryEventImpl,
    * java.lang.Object)
    */
   public void destroyOnRemote(EntryEventImpl event, boolean cacheWrite,
@@ -231,8 +231,8 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateInterface#invalidateExistingEntry
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * org.apache.geode.internal.cache.TXStateInterface#invalidateExistingEntry
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(EntryEventImpl event,
       boolean invokeCallbacks, boolean forceNewEntry) {
@@ -246,8 +246,8 @@ public final class DistPeerTXStateStub extends PeerTXStateStub implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#invalidateOnRemote
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * org.apache.geode.internal.cache.InternalDataView#invalidateOnRemote
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateOnRemote(EntryEventImpl event, boolean invokeCallbacks,
       boolean forceNewEntry) throws DataLocationException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXAdjunctCommitMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXAdjunctCommitMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXAdjunctCommitMessage.java
index 12c879b..a598d6c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXAdjunctCommitMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXAdjunctCommitMessage.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 
 import java.util.Collections;
 import java.util.Iterator;
 import org.apache.logging.log4j.Logger;
-import com.gemstone.gemfire.cache.CacheRuntimeException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.CacheRuntimeException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.logging.LogService;
 
 public class DistTXAdjunctCommitMessage extends TXCommitMessage{
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCommitMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCommitMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCommitMessage.java
index 97623f8..e026a7f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCommitMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCommitMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -30,25 +30,25 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CommitIncompleteException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CommitIncompleteException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCoordinatorInterface.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCoordinatorInterface.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCoordinatorInterface.java
index 363b540..e102a52 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCoordinatorInterface.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXCoordinatorInterface.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.HashSet;
 import java.util.TreeMap;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
 
 /**
  * [DISTTX] For Distributed Transaction

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXPrecommitMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXPrecommitMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXPrecommitMessage.java
index 64429d1..0f15673 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXPrecommitMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXPrecommitMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -31,29 +31,29 @@ import java.util.TreeMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CommitIncompleteException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.cache.locks.TXLockService;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CommitIncompleteException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.cache.locks.TXLockService;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXRollbackMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXRollbackMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXRollbackMessage.java
index f5f6c31..fe7bfd7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXRollbackMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXRollbackMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -30,26 +30,26 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CommitIncompleteException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.RemoteOperationMessage.RemoteOperationResponse;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CommitIncompleteException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.TransactionDataNotColocatedException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.RemoteOperationMessage.RemoteOperationResponse;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXState.java
index ed59108..25a79c8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXState.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Iterator;
@@ -24,27 +24,27 @@ import java.util.Map.Entry;
 import java.util.Set;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TransactionDataRebalancedException;
-import com.gemstone.gemfire.cache.TransactionWriter;
-import com.gemstone.gemfire.cache.TransactionWriterException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.RemoveAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.DistTxKeyInfo;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TransactionDataRebalancedException;
+import org.apache.geode.cache.TransactionWriter;
+import org.apache.geode.cache.TransactionWriterException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.partitioned.RemoveAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.DistTxKeyInfo;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Released;
 
 /**
  * TxState on a datanode VM
@@ -154,7 +154,7 @@ public class DistTXState extends TXState {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#commit()
+   * @see org.apache.geode.internal.cache.TXStateInterface#commit()
    * 
    * Take Locks Does conflict check on primary ([DISTTX] TODO on primary only)
    * Invoke TxWriter
@@ -248,7 +248,7 @@ public class DistTXState extends TXState {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#commit()
+   * @see org.apache.geode.internal.cache.TXStateInterface#commit()
    * 
    * Apply changes release locks
    */
@@ -362,7 +362,7 @@ public class DistTXState extends TXState {
       /*
        * Handle Put Operations meant for secondary.
        * 
-       * @see com.gemstone.gemfire.internal.cache.partitioned.PutMessage.
+       * @see org.apache.geode.internal.cache.partitioned.PutMessage.
        * operateOnPartitionedRegion(DistributionManager, PartitionedRegion,
        * long)
        * 
@@ -539,9 +539,9 @@ public class DistTXState extends TXState {
    * 
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#postPutAll(com.gemstone
+   * org.apache.geode.internal.cache.InternalDataView#postPutAll(org.apache
    * .gemfire.internal.cache.DistributedPutAllOperation, java.util.Map,
-   * com.gemstone.gemfire.internal.cache.LocalRegion)
+   * org.apache.geode.internal.cache.LocalRegion)
    */
   public void postPutAll(final DistributedPutAllOperation putallOp,
       final VersionedObjectList successfulPuts, LocalRegion reg) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateOnCoordinator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateOnCoordinator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateOnCoordinator.java
index 436c637..eb028b3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateOnCoordinator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateOnCoordinator.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.HashSet;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * TxState on TX coordinator, created when coordinator is also a data node
@@ -109,7 +109,7 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateStub#putEntry(com.gemstone.gemfire
+   * org.apache.geode.internal.cache.TXStateStub#putEntry(org.apache.geode
    * .internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object,
    * boolean, long, boolean)
    */
@@ -138,7 +138,7 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#putEntryOnRemote(com
+   * org.apache.geode.internal.cache.InternalDataView#putEntryOnRemote(com
    * .gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean,
    * java.lang.Object, boolean, long, boolean)
    */
@@ -168,8 +168,8 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateInterface#destroyExistingEntry
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean,
+   * org.apache.geode.internal.cache.TXStateInterface#destroyExistingEntry
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean,
    * java.lang.Object)
    */
   public void destroyExistingEntry(EntryEventImpl event, boolean cacheWrite,
@@ -189,8 +189,8 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#destroyOnRemote(java
-   * .lang.Integer, com.gemstone.gemfire.internal.cache.EntryEventImpl,
+   * org.apache.geode.internal.cache.InternalDataView#destroyOnRemote(java
+   * .lang.Integer, org.apache.geode.internal.cache.EntryEventImpl,
    * java.lang.Object)
    */
   public void destroyOnRemote(EntryEventImpl event, boolean cacheWrite,
@@ -210,8 +210,8 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.TXStateInterface#invalidateExistingEntry
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * org.apache.geode.internal.cache.TXStateInterface#invalidateExistingEntry
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(EntryEventImpl event,
       boolean invokeCallbacks, boolean forceNewEntry) {
@@ -226,8 +226,8 @@ public final class DistTXStateOnCoordinator extends DistTXState implements
    * (non-Javadoc)
    * 
    * @see
-   * com.gemstone.gemfire.internal.cache.InternalDataView#invalidateOnRemote
-   * (com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * org.apache.geode.internal.cache.InternalDataView#invalidateOnRemote
+   * (org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateOnRemote(EntryEventImpl event, boolean invokeCallbacks,
       boolean forceNewEntry) throws DataLocationException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImpl.java
index dfa2dda..92bee16 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImpl.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnCoordinator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnCoordinator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnCoordinator.java
index df3359c..3c3bf2c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnCoordinator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnCoordinator.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -27,22 +27,22 @@ import java.util.Map.Entry;
 import java.util.Set;
 import java.util.TreeSet;
 
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.TransactionInDoubtException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.DistTXPrecommitMessage.DistTxPrecommitResponse;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllEntryData;
-import com.gemstone.gemfire.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.DistClientTXStateStub;
-import com.gemstone.gemfire.internal.cache.tx.DistTxEntryEvent;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.TransactionInDoubtException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.DistTXPrecommitMessage.DistTxPrecommitResponse;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllEntryData;
+import org.apache.geode.internal.cache.DistributedRemoveAllOperation.RemoveAllEntryData;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.DistClientTXStateStub;
+import org.apache.geode.internal.cache.tx.DistTxEntryEvent;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 public class DistTXStateProxyImplOnCoordinator extends DistTXStateProxyImpl {
 
@@ -69,7 +69,7 @@ public class DistTXStateProxyImplOnCoordinator extends DistTXStateProxyImpl {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#commit()
+   * @see org.apache.geode.internal.cache.TXStateInterface#commit()
    * 
    * [DISTTX] TODO Catch all exceptions in precommit and rollback and make sure
    * these messages reach all

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnDatanode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnDatanode.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnDatanode.java
index 93eedaa..5b5a526 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnDatanode.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistTXStateProxyImplOnDatanode.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.ArrayList;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXEntryState.DistTxThinEntryState;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXEntryState.DistTxThinEntryState;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class DistTXStateProxyImplOnDatanode extends DistTXStateProxyImpl {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedCacheOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedCacheOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedCacheOperation.java
index 4ca60f9..98cb4a9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedCacheOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedCacheOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -32,54 +32,54 @@ import java.util.Vector;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.CacheFactory;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.cache.query.internal.cq.ServerCQ;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.SerialDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.CopyOnWriteHashSet;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.DistributedPutAllOperation.PutAllMessage;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.OldValueImporter;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.UpdateOperation.UpdateMessage;
-import com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage;
-import com.gemstone.gemfire.internal.cache.persistence.PersistentMemberID;
-import com.gemstone.gemfire.internal.cache.tier.MessageType;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.sequencelog.EntryLogger;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.cache.query.internal.cq.ServerCQ;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.SerialDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.CopyOnWriteHashSet;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.DistributedPutAllOperation.PutAllMessage;
+import org.apache.geode.internal.cache.EntryEventImpl.OldValueImporter;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.UpdateOperation.UpdateMessage;
+import org.apache.geode.internal.cache.partitioned.PartitionMessage;
+import org.apache.geode.internal.cache.persistence.PersistentMemberID;
+import org.apache.geode.internal.cache.tier.MessageType;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.sequencelog.EntryLogger;
 
 /**
  * 
@@ -201,7 +201,7 @@ public abstract class DistributedCacheOperation {
   public boolean supportsDirectAck() {
     // force use of shared connection if we're already in a secondary
     // thread-owned reader thread.  See bug #49565.  Also see Connection#processNIOBuffer
-//    int dominoCount = com.gemstone.gemfire.internal.tcp.Connection.getDominoCount();
+//    int dominoCount = org.apache.geode.internal.tcp.Connection.getDominoCount();
 //    return dominoCount < 2;
     return true;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedClearOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedClearOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedClearOperation.java
index b6e1c35..8503db5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedClearOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedClearOperation.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -22,16 +22,16 @@ import java.io.IOException;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionTag;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedPutAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedPutAllOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedPutAllOperation.java
index e73ca35..6272b8c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedPutAllOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedPutAllOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import it.unimi.dsi.fastutil.objects.Object2IntOpenHashMap;
 
@@ -34,35 +34,35 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.Scope;
-import com.gemstone.gemfire.cache.persistence.PersistentReplicatesOfflineException;
-import com.gemstone.gemfire.cache.query.internal.cq.CqService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.ByteArrayDataInput;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo.FilterInfo;
-import com.gemstone.gemfire.internal.cache.ha.ThreadIdentifier;
-import com.gemstone.gemfire.internal.cache.partitioned.PutAllPRMessage;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.persistence.PersistentReplicatesOfflineException;
+import org.apache.geode.cache.query.internal.cq.CqService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.ByteArrayDataInput;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.FilterRoutingInfo.FilterInfo;
+import org.apache.geode.internal.cache.ha.ThreadIdentifier;
+import org.apache.geode.internal.cache.partitioned.PutAllPRMessage;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
 
 /**
  * Handles distribution of a Region.putall operation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegion.java
index aa74af7..303f0bd 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegion.java
@@ -15,56 +15,56 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.asyncqueue.internal.AsyncEventQueueImpl;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.ResultCollector;
-import com.gemstone.gemfire.cache.execute.ResultSender;
-import com.gemstone.gemfire.cache.persistence.PersistentReplicatesOfflineException;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.DistributedLockService;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.LockServiceDestroyedException;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.ProfileVisitor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRemoteToken;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.i18n.StringId;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.AbstractRegionMap.ARMLockTestHook;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor.CacheProfile;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation.GIIStatus;
-import com.gemstone.gemfire.internal.cache.RemoteFetchVersionMessage.FetchVersionResponse;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.execute.*;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.cache.persistence.*;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.cache.wan.AsyncEventQueueConfigurationException;
-import com.gemstone.gemfire.internal.cache.wan.GatewaySenderConfigurationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.sequencelog.RegionLogger;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.*;
+import org.apache.geode.cache.asyncqueue.internal.AsyncEventQueueImpl;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.ResultCollector;
+import org.apache.geode.cache.execute.ResultSender;
+import org.apache.geode.cache.persistence.PersistentReplicatesOfflineException;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.DistributedLockService;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.LockServiceDestroyedException;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionAdvisor.ProfileVisitor;
+import org.apache.geode.distributed.internal.locks.DLockRemoteToken;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.i18n.StringId;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.AbstractRegionMap.ARMLockTestHook;
+import org.apache.geode.internal.cache.CacheDistributionAdvisor.CacheProfile;
+import org.apache.geode.internal.cache.InitialImageOperation.GIIStatus;
+import org.apache.geode.internal.cache.RemoteFetchVersionMessage.FetchVersionResponse;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryEvent;
+import org.apache.geode.internal.cache.execute.*;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.cache.persistence.*;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.cache.wan.AsyncEventQueueConfigurationException;
+import org.apache.geode.internal.cache.wan.GatewaySenderConfigurationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.sequencelog.RegionLogger;
+import org.apache.geode.internal.util.concurrent.StoppableCountDownLatch;
 import org.apache.logging.log4j.Logger;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegionFunctionStreamingMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegionFunctionStreamingMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegionFunctionStreamingMessage.java
index a31d5e4..d1f64c4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegionFunctionStreamingMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/DistributedRegionFunctionStreamingMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,26 +25,26 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.CacheClosedException;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.cache.execute.Function;
-import com.gemstone.gemfire.cache.execute.FunctionException;
-import com.gemstone.gemfire.cache.execute.FunctionService;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.CacheClosedException;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.cache.execute.Function;
+import org.apache.geode.cache.execute.FunctionException;
+import org.apache.geode.cache.execute.FunctionService;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 public class DistributedRegionFunctionStreamingMessage extends DistributionMessage implements TransactionMessage {
 
@@ -420,14 +420,14 @@ public class DistributedRegionFunctionStreamingMessage extends DistributionMessa
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TransactionMessage#canStartRemoteTransaction()
+   * @see org.apache.geode.internal.cache.TransactionMessage#canStartRemoteTransaction()
    */
   public boolean canStartRemoteTransaction() {
     return true;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TransactionMessage#getTXUniqId()
+   * @see org.apache.geode.internal.cache.TransactionMessage#getTXUniqId()
    */
   public int getTXUniqId() {
     return txUniqId;


[22/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/MigrationServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/MigrationServer.java b/geode-core/src/main/java/org/apache/geode/internal/MigrationServer.java
index aba9f97..93423f7 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/MigrationServer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/MigrationServer.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
-import com.gemstone.gemfire.admin.internal.InetAddressUtil;
-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.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.admin.internal.InetAddressUtil;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CacheFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.net.*;
@@ -34,8 +34,8 @@ import java.util.Enumeration;
 import java.util.Iterator;
 import java.util.Properties;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.LOCATORS;
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_PORT;
+import static org.apache.geode.distributed.ConfigurationProperties.LOCATORS;
+import static org.apache.geode.distributed.ConfigurationProperties.MCAST_PORT;
 
 /**
  * MigrationServer creates a cache using a supplied cache.xml and then
@@ -60,7 +60,7 @@ import static com.gemstone.gemfire.distributed.ConfigurationProperties.MCAST_POR
  * For example,
  * <pre>
  * java -cp $MYCLASSES:migration.jar:$GEMFIRE/lib/geode-dependencies.jar \
- *   com.gemstone.gemfire.internal.MigrationServer cacheDescription.xml
+ *   org.apache.geode.internal.MigrationServer cacheDescription.xml
  * </pre><p>
  * Where the cacheDescription.xml file might look like this:
  * <pre>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/NanoTimer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/NanoTimer.java b/geode-core/src/main/java/org/apache/geode/internal/NanoTimer.java
index 110c53d..e8c1145 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/NanoTimer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/NanoTimer.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /**
  * A timer class that reports current or elapsed time in nanonseconds.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/NullDataOutputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/NullDataOutputStream.java b/geode-core/src/main/java/org/apache/geode/internal/NullDataOutputStream.java
index 153ae82..1d9ac01 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/NullDataOutputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/NullDataOutputStream.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.*;
-import com.gemstone.gemfire.DataSerializer;
+import org.apache.geode.DataSerializer;
 
 /** NullDataOutputStream is an OutputStream that also implements DataOutput
  * and does not store any data written to it.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/OSProcess.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/OSProcess.java b/geode-core/src/main/java/org/apache/geode/internal/OSProcess.java
index 66dd612..7d203fe 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/OSProcess.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/OSProcess.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.io.TeePrintStream;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.io.TeePrintStream;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
 import org.apache.logging.log4j.Logger;
 
 import java.io.*;
@@ -207,7 +207,7 @@ public class OSProcess {
 		throw new IOException(LocalizedStrings.OSProcess_COULD_NOT_CREATE_LOG_FILE_0_BECAUSE_1.toLocalizedString(new Object[] {logfile.getPath(), io.getMessage()}));
 	    }
 	}
-	String trace = System.getProperty("com.gemstone.gemfire.internal.OSProcess.trace");
+	String trace = System.getProperty("org.apache.geode.internal.OSProcess.trace");
 	if (trace != null && trace.length() > 0) {
 	    for (int i=0; i < cmdarray.length; i++) {
 		System.out.println("cmdarray[" + i + "] = "
@@ -515,7 +515,7 @@ public class OSProcess {
 	    try {
 		pids.remove(Integer.valueOf(pid));
 	    } catch (Exception ignore) {}
-	    String trace = System.getProperty("com.gemstone.gemfire.internal.OSProcess.trace");
+	    String trace = System.getProperty("org.apache.geode.internal.OSProcess.trace");
 	    if (trace != null && trace.length() > 0) {
 		System.out.println("reaped pid: " + pid);
 	    }
@@ -614,7 +614,7 @@ public class OSProcess {
                   myPid[0] = getProcessId();
                   reaperStarted = true;
                 }
-		String trace = System.getProperty("com.gemstone.gemfire.internal.OSProcess.trace");
+		String trace = System.getProperty("org.apache.geode.internal.OSProcess.trace");
 		int secondsToSleep = (1000 * 60) * 1; // one minute
 		if (trace != null && trace.length() > 0) {
 		    secondsToSleep = 1000; // every second

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ObjIdConcurrentMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ObjIdConcurrentMap.java b/geode-core/src/main/java/org/apache/geode/internal/ObjIdConcurrentMap.java
index 00e4153..11e4796 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ObjIdConcurrentMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ObjIdConcurrentMap.java
@@ -17,7 +17,7 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /*
  * Written by Doug Lea with assistance from members of JCP JSR-166

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ObjIdMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ObjIdMap.java b/geode-core/src/main/java/org/apache/geode/internal/ObjIdMap.java
index 230d57f..8e2a575 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ObjIdMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ObjIdMap.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.lang.Math;
 import java.lang.ref.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ObjToByteArraySerializer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ObjToByteArraySerializer.java b/geode-core/src/main/java/org/apache/geode/internal/ObjToByteArraySerializer.java
index 296da94..4b6c0a0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ObjToByteArraySerializer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ObjToByteArraySerializer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/OneTaskOnlyExecutor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/OneTaskOnlyExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/OneTaskOnlyExecutor.java
index 888fa93..2b8d8e1 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/OneTaskOnlyExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/OneTaskOnlyExecutor.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.util.concurrent.Callable;
 import java.util.concurrent.ScheduledExecutorService;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/PdxSerializerObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/PdxSerializerObject.java b/geode-core/src/main/java/org/apache/geode/internal/PdxSerializerObject.java
index 4f5998c..a9ff1c0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/PdxSerializerObject.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/PdxSerializerObject.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /**
  * Marker interface for object used in PdxSerializer Tests that are in the
- * com.gemstone package. If an object implements this interface, it will be
- * passed to a PdxSerializer even if it is in the com.gemstone package.
+ * org.apache package. If an object implements this interface, it will be
+ * passed to a PdxSerializer even if it is in the org.apache package.
  * 
- * This is necessary because we exclude all other objects from the com.gemstone
+ * This is necessary because we exclude all other objects from the org.apache
  * package.
- * See {@link InternalDataSerializer#writePdx(java.io.DataOutput, com.gemstone.gemfire.internal.cache.GemFireCacheImpl, Object, com.gemstone.gemfire.pdx.PdxSerializer)} 
+ * See {@link InternalDataSerializer#writePdx(java.io.DataOutput, org.apache.geode.internal.cache.GemFireCacheImpl, Object, org.apache.geode.pdx.PdxSerializer)} 
  * 
  * 
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ProcessOutputReader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ProcessOutputReader.java b/geode-core/src/main/java/org/apache/geode/internal/ProcessOutputReader.java
index 240a62d..b226217 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ProcessOutputReader.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ProcessOutputReader.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.*;
 import java.util.*;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * A ProcessOutputReader will read both stdout and stderr

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/PureJavaMode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/PureJavaMode.java b/geode-core/src/main/java/org/apache/geode/internal/PureJavaMode.java
index bba2809..e4b2385 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/PureJavaMode.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/PureJavaMode.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 /**
  * Used to determine if product should use pure java mode.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/ScheduledThreadPoolExecutorWithKeepAlive.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/ScheduledThreadPoolExecutorWithKeepAlive.java b/geode-core/src/main/java/org/apache/geode/internal/ScheduledThreadPoolExecutorWithKeepAlive.java
index 4bebe89..6bfd163 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/ScheduledThreadPoolExecutorWithKeepAlive.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/ScheduledThreadPoolExecutorWithKeepAlive.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.util.List;
 import java.util.concurrent.Callable;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/Sendable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/Sendable.java b/geode-core/src/main/java/org/apache/geode/internal/Sendable.java
index 17fa715..2add465 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/Sendable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/Sendable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataOutput;
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SerializationVersions.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SerializationVersions.java b/geode-core/src/main/java/org/apache/geode/internal/SerializationVersions.java
index 12d9898..a9964ee 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SerializationVersions.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SerializationVersions.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /**
  * This interface is extended by DataSerializableFixedID and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SetUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SetUtils.java b/geode-core/src/main/java/org/apache/geode/internal/SetUtils.java
index 883d0a3..be88a04 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SetUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SetUtils.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.util.HashSet;
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SharedLibrary.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SharedLibrary.java b/geode-core/src/main/java/org/apache/geode/internal/SharedLibrary.java
index 76d98c7..bbb4f66 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SharedLibrary.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SharedLibrary.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.lang.SystemUtils;
-import com.gemstone.gemfire.pdx.internal.unsafe.UnsafeWrapper;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.lang.SystemUtils;
+import org.apache.geode.pdx.internal.unsafe.UnsafeWrapper;
 
 import java.io.File;
 import java.net.URL;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SmHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SmHelper.java b/geode-core/src/main/java/org/apache/geode/internal/SmHelper.java
index 8cad2e0..ca7bc3a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SmHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SmHelper.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 import java.lang.reflect.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SocketCloser.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SocketCloser.java b/geode-core/src/main/java/org/apache/geode/internal/SocketCloser.java
index 8318afa..b6a516c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SocketCloser.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SocketCloser.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.IOException;
 import java.net.Socket;
@@ -30,9 +30,9 @@ import java.util.concurrent.TimeoutException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
 
 /**
  * This class allows sockets to be closed without blocking.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SocketCreator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SocketCreator.java b/geode-core/src/main/java/org/apache/geode/internal/SocketCreator.java
index fded3c3..1d24857 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/SocketCreator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SocketCreator.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.GemFireConfigException;
-import com.gemstone.gemfire.SystemConnectException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.admin.internal.InetAddressUtil;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.cache.wan.GatewayTransportFilter;
-import com.gemstone.gemfire.distributed.ClientSocketFactory;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfigImpl;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.GfeConsoleReaderFactory.GfeConsoleReader;
-import com.gemstone.gemfire.internal.cache.wan.TransportFilterServerSocket;
-import com.gemstone.gemfire.internal.cache.wan.TransportFilterSocketFactory;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.util.PasswordUtil;
+import org.apache.geode.GemFireConfigException;
+import org.apache.geode.SystemConnectException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.admin.internal.InetAddressUtil;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.cache.wan.GatewayTransportFilter;
+import org.apache.geode.distributed.ClientSocketFactory;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfigImpl;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.GfeConsoleReaderFactory.GfeConsoleReader;
+import org.apache.geode.internal.cache.wan.TransportFilterServerSocket;
+import org.apache.geode.internal.cache.wan.TransportFilterSocketFactory;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.util.PasswordUtil;
 import org.apache.logging.log4j.Logger;
 
 import javax.naming.Context;
@@ -397,7 +397,7 @@ public class SocketCreator {
             System.setProperty( "p2p.useSSL", "false" );
           }
           // make sure TCPConduit picks up p2p properties...
-          com.gemstone.gemfire.internal.tcp.TCPConduit.init();
+          org.apache.geode.internal.tcp.TCPConduit.init();
         } else if (this.useSSL && sslContext == null) {
           try {
             sslContext = createAndConfigureSSLContext(protocols, props);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SystemAdmin.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SystemAdmin.java b/geode-core/src/main/java/org/apache/geode/internal/SystemAdmin.java
index 1757d5c..daec1cc 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SystemAdmin.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SystemAdmin.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
-
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
-
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.BackupStatus;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.statistics.StatArchiveReader;
-import com.gemstone.gemfire.internal.statistics.StatArchiveReader.ResourceInst;
-import com.gemstone.gemfire.internal.statistics.StatArchiveReader.StatValue;
-import com.gemstone.gemfire.internal.admin.remote.TailLogResponse;
-import com.gemstone.gemfire.internal.cache.DiskStoreImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.DateFormatter;
-import com.gemstone.gemfire.internal.logging.MergeLogFiles;
-import com.gemstone.gemfire.internal.util.JavaCommandBuilder;
-import com.gemstone.gemfire.internal.util.PasswordUtil;
-import com.gemstone.gemfire.internal.util.PluckStacks;
-import com.gemstone.gemfire.internal.util.PluckStacks.ThreadStack;
+package org.apache.geode.internal;
+
+import static org.apache.geode.distributed.ConfigurationProperties.*;
+
+import org.apache.geode.*;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.BackupStatus;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.cache.persistence.PersistentID;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.statistics.StatArchiveReader;
+import org.apache.geode.internal.statistics.StatArchiveReader.ResourceInst;
+import org.apache.geode.internal.statistics.StatArchiveReader.StatValue;
+import org.apache.geode.internal.admin.remote.TailLogResponse;
+import org.apache.geode.internal.cache.DiskStoreImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.DateFormatter;
+import org.apache.geode.internal.logging.MergeLogFiles;
+import org.apache.geode.internal.util.JavaCommandBuilder;
+import org.apache.geode.internal.util.PasswordUtil;
+import org.apache.geode.internal.util.PluckStacks;
+import org.apache.geode.internal.util.PluckStacks.ThreadStack;
 
 import java.io.*;
 import java.net.*;
@@ -48,7 +48,7 @@ import java.util.regex.Matcher;
 import java.util.regex.Pattern;
 import java.util.zip.GZIPInputStream;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.START_LOCATOR;
+import static org.apache.geode.distributed.ConfigurationProperties.START_LOCATOR;
 
 /**
  * Provides static methods for various system administation tasks.
@@ -186,7 +186,7 @@ public class SystemAdmin {
   
   /** get the path to the distribution locator class */
   protected String getDistributionLocatorPath() {
-    return "com.gemstone.gemfire.internal.DistributionLocator";
+    return "org.apache.geode.internal.DistributionLocator";
   }
 
   /** enumerates all available local network addresses to find a match with

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SystemFailureTestHook.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SystemFailureTestHook.java b/geode-core/src/main/java/org/apache/geode/internal/SystemFailureTestHook.java
index 07c8b45..04a9d48 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SystemFailureTestHook.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SystemFailureTestHook.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 /**
  * Allows tests to expect certain exceptions without the SystemFailure watchdog getting upset.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/SystemTimer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/SystemTimer.java b/geode-core/src/main/java/org/apache/geode/internal/SystemTimer.java
index e46ad90..6451e5b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/SystemTimer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/SystemTimer.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.lang.ref.WeakReference;
 import java.text.SimpleDateFormat;
@@ -28,12 +28,12 @@ import java.util.TimerTask;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Instances of this class are like {@link Timer}, but are associated

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/UniqueIdGenerator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/UniqueIdGenerator.java b/geode-core/src/main/java/org/apache/geode/internal/UniqueIdGenerator.java
index c1b99d6..00d2281 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/UniqueIdGenerator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/UniqueIdGenerator.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /** UniqueIdGenerator is factory that will produce unique ids that fall
  * in a range between 0 and numIds-1 inclusive.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/Version.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/Version.java b/geode-core/src/main/java/org/apache/geode/internal/Version.java
index 1b8543e..eff342b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/Version.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/Version.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,9 +23,9 @@ import java.io.IOException;
 import java.io.InputStream;
 import java.nio.ByteBuffer;
 
-import com.gemstone.gemfire.cache.UnsupportedVersionException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.CommandInitializer;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.UnsupportedVersionException;
+import org.apache.geode.internal.cache.tier.sockets.CommandInitializer;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Enumerated type for client / server and p2p version.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedDataInputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataInputStream.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataInputStream.java
index 9ec4e13..284d5dd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataInputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataInputStream.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataInputStream;
 import java.io.InputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedDataOutputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataOutputStream.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataOutputStream.java
index 40b3b40..3addd85 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataOutputStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataOutputStream.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataOutputStream;
 import java.io.OutputStream;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedDataSerializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataSerializable.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataSerializable.java
index 30479e1..76a9b38 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataSerializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataSerializable.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * An extension of DataSerializable that can support multiple serialized

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedDataStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataStream.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataStream.java
index 3e8bd98..55683eb 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedDataStream.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedDataStream.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 
-import com.gemstone.gemfire.DataSerializable;
+import org.apache.geode.DataSerializable;
 
 /**
  * An extension to {@link DataOutput}, {@link DataInput} used internally in

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectInput.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectInput.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectInput.java
index e2fc450..cfed23c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectInput.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectInput.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.IOException;
 import java.io.ObjectInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectOutput.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectOutput.java b/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectOutput.java
index 39fdafe..c279197 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectOutput.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/VersionedObjectOutput.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal;
+package org.apache.geode.internal;
 
 import java.io.IOException;
 import java.io.ObjectOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/AdminBridgeServer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/AdminBridgeServer.java b/geode-core/src/main/java/org/apache/geode/internal/admin/AdminBridgeServer.java
index 9ff857e..deb5b05 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/AdminBridgeServer.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/AdminBridgeServer.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.cache.server.CacheServer;
+import org.apache.geode.cache.server.CacheServer;
 
 /**
  * A representation of <code>CacheServer</code> that is used for

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/Alert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/Alert.java b/geode-core/src/main/java/org/apache/geode/internal/admin/Alert.java
index 17da3af..50d66ab 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/Alert.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/Alert.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 /**
  * An administration alert that is issued by a member of a GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/AlertListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/AlertListener.java b/geode-core/src/main/java/org/apache/geode/internal/admin/AlertListener.java
index 8db4ad3..6f38e75 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/AlertListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/AlertListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * A listener whose callback methods are invoekd when an {@link Alert}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/ApplicationVM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/ApplicationVM.java b/geode-core/src/main/java/org/apache/geode/internal/admin/ApplicationVM.java
index c5bcb4e..6b063bd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/ApplicationVM.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/ApplicationVM.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-//import com.gemstone.gemfire.cache.Region;
+//import org.apache.geode.cache.Region;
 //import java.util.Set;
 
 /**
@@ -30,7 +30,7 @@ public interface ApplicationVM extends GemFireVM {
    * Returns whether or not this "application" VM is a dedicated cache
    * server.
    *
-   * @see com.gemstone.gemfire.internal.cache.CacheServerLauncher
+   * @see org.apache.geode.internal.cache.CacheServerLauncher
    */
   public boolean isDedicatedCacheServer();
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
index 7ae42d0..613151f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-//import com.gemstone.gemfire.internal.admin.remote.*;
-//import com.gemstone.gemfire.cache.*;
-//import com.gemstone.gemfire.GemFireCacheException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.admin.remote.*;
+//import org.apache.geode.cache.*;
+//import org.apache.geode.GemFireCacheException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
@@ -79,7 +79,7 @@ public class CacheCollector {
    * Initiates a snapshot of the all of the Cache regions in a
    * distributed system.
    *
-   * @see com.gemstone.gemfire.internal.admin.ApplicationVM#takeRegionSnapshot(String, int)
+   * @see org.apache.geode.internal.admin.ApplicationVM#takeRegionSnapshot(String, int)
    */
   public synchronized void takeSnapshot(String regionName) {
     flush();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/CacheInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheInfo.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheInfo.java
index 3faa8e8..0484ac3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheInfo.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * Describes a cache from a GemFireVM's point of view.
@@ -51,7 +51,7 @@ public interface CacheInfo {
   
   /**
    * Gets the number of seconds a cache
-   * {@link com.gemstone.gemfire.cache.Region#get(Object) get} operation
+   * {@link org.apache.geode.cache.Region#get(Object) get} operation
    * can spend searching for a value before it times out.
    * The search includes any time spent loading the object.
    * When the search times out it causes the get to fail by throwing

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/CacheSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheSnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheSnapshot.java
index 89cdec3..4795139 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheSnapshot.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * A snapshot ("segment") of a entity (either a {@linkplain

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/ClientHealthMonitoringRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientHealthMonitoringRegion.java b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientHealthMonitoringRegion.java
index 21fc2fa..247f4f6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientHealthMonitoringRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientHealthMonitoringRegion.java
@@ -14,19 +14,19 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.CacheListener;
-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.cache.util.CacheListenerAdapter;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.AttributesFactory;
+import org.apache.geode.cache.CacheListener;
+import org.apache.geode.cache.ExpirationAction;
+import org.apache.geode.cache.ExpirationAttributes;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.Scope;
+import org.apache.geode.cache.util.CacheListenerAdapter;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.InternalRegionArguments;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * This is an admin (meta) region used by the client health monitoring service

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/ClientMembershipMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientMembershipMessage.java b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientMembershipMessage.java
index 87b1d68..5132ff2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientMembershipMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientMembershipMessage.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.admin.internal.AdminDistributedSystemImpl;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * A PooledDistributionMessage for notifying admin members about changes in 
@@ -68,7 +68,7 @@ public class ClientMembershipMessage extends PooledDistributionMessage {
 
   /** 
    * 
-   * @see com.gemstone.gemfire.distributed.internal.DistributionMessage#process(com.gemstone.gemfire.distributed.internal.DistributionManager)
+   * @see org.apache.geode.distributed.internal.DistributionMessage#process(org.apache.geode.distributed.internal.DistributionManager)
    */
   @Override
   protected void process(DistributionManager dm) {
@@ -94,7 +94,7 @@ public class ClientMembershipMessage extends PooledDistributionMessage {
 
   /**
    *  
-   * @see com.gemstone.gemfire.internal.DataSerializableFixedID#getDSFID()
+   * @see org.apache.geode.internal.DataSerializableFixedID#getDSFID()
    */
   public int getDSFID() {
     return CLIENT_MEMBERSHIP_MESSAGE;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/ClientStatsManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientStatsManager.java b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientStatsManager.java
index 2db7eb1..2df0eb2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/ClientStatsManager.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/ClientStatsManager.java
@@ -14,30 +14,30 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.util.Date;
 import java.util.Iterator;
 import java.util.Map;
 import java.util.Map.Entry;
 
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.client.internal.PoolImpl;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
-import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.admin.remote.ClientHealthStats;
-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.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.management.internal.cli.CliUtil;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.client.internal.PoolImpl;
+import org.apache.geode.cache.client.internal.ServerRegionProxy;
+import org.apache.geode.cache.query.CqQuery;
+import org.apache.geode.distributed.DistributedSystemDisconnectedException;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.admin.remote.ClientHealthStats;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.management.internal.cli.CliUtil;
 
 /**
  * This class publishes the client statistics using the admin region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundEntrySnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundEntrySnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundEntrySnapshot.java
index e535d7d..3c055e0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundEntrySnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundEntrySnapshot.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
-//import com.gemstone.gemfire.cache.*;
+//import org.apache.geode.cache.*;
 
 /**
  * Presents an amalgam snapshot of all the {@linkplain
- * com.gemstone.gemfire.cache.Region.Entry regions entries} in a
+ * org.apache.geode.cache.Region.Entry regions entries} in a
  * distributed system.
  */
 public class CompoundEntrySnapshot implements EntrySnapshot {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundRegionSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundRegionSnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundRegionSnapshot.java
index af259f9..1166cc8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundRegionSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CompoundRegionSnapshot.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.util.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * Presents an amalgam snapshot of all the {@linkplain
- * com.gemstone.gemfire.cache.Region regions} in a distributed
+ * org.apache.geode.cache.Region regions} in a distributed
  * system. 
  */
 public class CompoundRegionSnapshot implements RegionSnapshot {
@@ -227,21 +227,21 @@ public class CompoundRegionSnapshot implements RegionSnapshot {
   }
 
   /**
-   * Returns an  {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.DataPolicy}
+   * Returns an  {@link java.util.Iterator} of {@link org.apache.geode.cache.DataPolicy}
    */
   public Iterator getAllDataPolicies() {
     return allDataPolicies.iterator();
   }
 
   /**
-   * Returns an {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.ExpirationAttributes}
+   * Returns an {@link java.util.Iterator} of {@link org.apache.geode.cache.ExpirationAttributes}
    */
   public Iterator getAllRegionTtl() {
     return allRegionTtl.iterator();
   }
   
   /**
-   * Returns an {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.ExpirationAttributes}
+   * Returns an {@link java.util.Iterator} of {@link org.apache.geode.cache.ExpirationAttributes}
    */
   public Iterator getAllEntryTtl() {
     return allEntryTtl.iterator();
@@ -257,7 +257,7 @@ public class CompoundRegionSnapshot implements RegionSnapshot {
   }
   
   /**
-   * Returns an {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.ExpirationAttributes}
+   * Returns an {@link java.util.Iterator} of {@link org.apache.geode.cache.ExpirationAttributes}
    */
   public Iterator getAllRegionIdleTimeout() {
     return allRegionIdleTimeout.iterator();
@@ -265,7 +265,7 @@ public class CompoundRegionSnapshot implements RegionSnapshot {
 
   
   /**
-   * Returns an {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.ExpirationAttributes}
+   * Returns an {@link java.util.Iterator} of {@link org.apache.geode.cache.ExpirationAttributes}
    */
   public Iterator getAllEntryIdleTimeout() {
     return allEntryIdleTimeout.iterator();
@@ -280,7 +280,7 @@ public class CompoundRegionSnapshot implements RegionSnapshot {
     return allCustomIdle.iterator();
   }
   /**
-   * Returns an {@link java.util.Iterator} of {@link com.gemstone.gemfire.cache.Scope}
+   * Returns an {@link java.util.Iterator} of {@link org.apache.geode.cache.Scope}
    */
   public Iterator getAllScopes() {
     return allScopes.iterator();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/DLockInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/DLockInfo.java b/geode-core/src/main/java/org/apache/geode/internal/admin/DLockInfo.java
index 7ef14a5..b988f81 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/DLockInfo.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/DLockInfo.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.io.Serializable;
 import java.util.Date;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * Represents display information about a single distributed lock

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/EntrySnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/EntrySnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/EntrySnapshot.java
index 2c1f71f..b6ecd6a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/EntrySnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/EntrySnapshot.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * A snapshot of a <code>Region</code> entry.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/EntryValueNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/EntryValueNode.java b/geode-core/src/main/java/org/apache/geode/internal/admin/EntryValueNode.java
index bb7734e..cc3b98e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/EntryValueNode.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/EntryValueNode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * Represents an arbitrary object that has been placed into a GemFire

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/GemFireVM.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/GemFireVM.java b/geode-core/src/main/java/org/apache/geode/internal/admin/GemFireVM.java
index 6c9837e..68a4a39 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/GemFireVM.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/GemFireVM.java
@@ -15,22 +15,22 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Properties;
 import java.util.Set;
 
-import com.gemstone.gemfire.admin.AdminException;
-import com.gemstone.gemfire.admin.GemFireHealth;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.admin.GemFireMemberStatus;
-import com.gemstone.gemfire.admin.RegionSubRegionSnapshot;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Config;
+import org.apache.geode.admin.AdminException;
+import org.apache.geode.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.admin.GemFireMemberStatus;
+import org.apache.geode.admin.RegionSubRegionSnapshot;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Config;
 
 /**
  * Represents one java vm connected to a GemFire distributed system
@@ -158,7 +158,7 @@ public interface GemFireVM {
   public Config getConfig();
 
   /**
-   * Returns the runtime {@link com.gemstone.gemfire.admin.GemFireMemberStatus} from the vm
+   * Returns the runtime {@link org.apache.geode.admin.GemFireMemberStatus} from the vm
    * The idea is this snapshot is similar to stats that represent the current state of a 
    * running VM. However, this is a bit higher level than a stat 
    * @since GemFire 5.7
@@ -166,7 +166,7 @@ public interface GemFireVM {
   public GemFireMemberStatus getSnapshot();
   
   /**
-   * Returns the runtime {@link com.gemstone.gemfire.admin.RegionSubRegionSnapshot} from the vm
+   * Returns the runtime {@link org.apache.geode.admin.RegionSubRegionSnapshot} from the vm
    * The idea is this snapshot is quickly salvageable to present a cache's region's info 
    * @since GemFire 5.7
    */
@@ -276,7 +276,7 @@ public interface GemFireVM {
   
   
   /**
-   * Returns the name given to the {@link com.gemstone.gemfire.GemFireConnection}
+   * Returns the name given to the {@link org.apache.geode.GemFireConnection}
    * of this process
    */
   //public String getName();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgent.java b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgent.java
index 07a368d..b1f4fcf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgent.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgent.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
 //import java.util.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentConfig.java b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentConfig.java
index 80427fd..ef77161 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentConfig.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem.DisconnectListener;
-import com.gemstone.gemfire.internal.logging.InternalLogWriter;
+import org.apache.geode.distributed.internal.InternalDistributedSystem.DisconnectListener;
+import org.apache.geode.internal.logging.InternalLogWriter;
 
 /**
  * Used to create and configure a {@link GfManagerAgent}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentFactory.java b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentFactory.java
index f836cce..62a2136 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/GfManagerAgentFactory.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.internal.admin.remote.*;
+import org.apache.geode.internal.admin.remote.*;
 
 /**
  * A factory for GfManagerAgent instances.  This is the main entry

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/GfObject.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/GfObject.java b/geode-core/src/main/java/org/apache/geode/internal/admin/GfObject.java
index 919a3c7..d836ecd 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/GfObject.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/GfObject.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * The root of our little client side administration object model

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/HealthListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/HealthListener.java b/geode-core/src/main/java/org/apache/geode/internal/admin/HealthListener.java
index b35213d..671e2c6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/HealthListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/HealthListener.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.admin.GemFireHealth;
+import org.apache.geode.admin.GemFireHealth;
 
 /**
  * Interface for those who want to be alerted of a change in a GemFireVM's
  * health.
  *
- * @see com.gemstone.gemfire.admin.GemFireHealthConfig
+ * @see org.apache.geode.admin.GemFireHealthConfig
  *
  * @since GemFire 3.5
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/JoinLeaveListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/JoinLeaveListener.java b/geode-core/src/main/java/org/apache/geode/internal/admin/JoinLeaveListener.java
index cd69544..c4ff512 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/JoinLeaveListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/JoinLeaveListener.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * Interface implemented by those who want to be alerted when a node joins or leaves a distributed GemFire system

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/ListenerIdMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/ListenerIdMap.java b/geode-core/src/main/java/org/apache/geode/internal/admin/ListenerIdMap.java
index 5d68205..a22cb08 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/ListenerIdMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/ListenerIdMap.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.lang.Math;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/RegionSnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/RegionSnapshot.java b/geode-core/src/main/java/org/apache/geode/internal/admin/RegionSnapshot.java
index aab026e..f3cc437 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/RegionSnapshot.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/RegionSnapshot.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.cache.RegionAttributes;
+import org.apache.geode.cache.RegionAttributes;
 
 /**
  * A snapshot of a GemFire <code>Region</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/SSLConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/SSLConfig.java b/geode-core/src/main/java/org/apache/geode/internal/admin/SSLConfig.java
index 36c553e..7402a52 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/SSLConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/SSLConfig.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
-import static com.gemstone.gemfire.distributed.ConfigurationProperties.*;
+import static org.apache.geode.distributed.ConfigurationProperties.*;
 
 import java.util.Iterator;
 import java.util.Properties;
@@ -110,7 +110,7 @@ public class SSLConfig {
   /**
    * Populates a <code>Properties</code> object with the SSL-related
    * configuration information used by {@link
-   * com.gemstone.gemfire.distributed.DistributedSystem#connect}.
+   * org.apache.geode.distributed.DistributedSystem#connect}.
    *
    * @since GemFire 4.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/SnapshotClient.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/SnapshotClient.java b/geode-core/src/main/java/org/apache/geode/internal/admin/SnapshotClient.java
index f1d5bcd..f2aa03e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/SnapshotClient.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/SnapshotClient.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/Stat.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/Stat.java b/geode-core/src/main/java/org/apache/geode/internal/admin/Stat.java
index 7853b71..149014b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/Stat.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/Stat.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * Interface to represent a single statistic of a <code>StatResource</code>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlert.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlert.java b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlert.java
index 8fb752d..68f6b22 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlert.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlert.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.io.Serializable;
 import java.util.Date;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertDefinition.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertDefinition.java b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertDefinition.java
index 4abba9e..9ca84ce 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertDefinition.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertDefinition.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.internal.admin.statalerts.StatisticInfo;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.internal.admin.statalerts.StatisticInfo;
 
 /**
  * Base interface that supports a StatAlertDefinition

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertsManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertsManager.java b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertsManager.java
index c1559a7..eeb6261 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertsManager.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/StatAlertsManager.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 import java.util.ArrayList;
 import java.util.Date;
@@ -27,23 +27,23 @@ import java.util.TimerTask;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.admin.jmx.internal.StatAlertsAggregator;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.SystemTimer;
-import com.gemstone.gemfire.internal.SystemTimer.SystemTimerTask;
-import com.gemstone.gemfire.internal.admin.remote.AlertsNotificationMessage;
-import com.gemstone.gemfire.internal.admin.remote.UpdateAlertDefinitionMessage;
-import com.gemstone.gemfire.internal.admin.statalerts.DummyStatisticInfoImpl;
-import com.gemstone.gemfire.internal.admin.statalerts.StatisticInfo;
-import com.gemstone.gemfire.internal.admin.statalerts.StatisticInfoImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.CancelException;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.admin.jmx.internal.StatAlertsAggregator;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.SystemTimer;
+import org.apache.geode.internal.SystemTimer.SystemTimerTask;
+import org.apache.geode.internal.admin.remote.AlertsNotificationMessage;
+import org.apache.geode.internal.admin.remote.UpdateAlertDefinitionMessage;
+import org.apache.geode.internal.admin.statalerts.DummyStatisticInfoImpl;
+import org.apache.geode.internal.admin.statalerts.StatisticInfo;
+import org.apache.geode.internal.admin.statalerts.StatisticInfoImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * The alert manager maintains the list of alert definitions (added by client
@@ -179,7 +179,7 @@ public class StatAlertsManager {
     // Get the swarm.  Currently rather UGLY.
     InternalDistributedSystem system = dm.getSystem();
     if (system == null || system.getDistributionManager() != dm) {
-      throw new com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException(
+      throw new org.apache.geode.distributed.DistributedSystemDisconnectedException(
           "This manager has been cancelled");
     }
     // start and schedule new timer

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/StatListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/StatListener.java b/geode-core/src/main/java/org/apache/geode/internal/admin/StatListener.java
index a2caeb3..80fc0b8 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/StatListener.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/StatListener.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
    
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * Interface for those who want to be alerted of a change in value of

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/StatResource.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/StatResource.java b/geode-core/src/main/java/org/apache/geode/internal/admin/StatResource.java
index dc36ce7..41c884e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/StatResource.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/StatResource.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 //import java.util.List;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/TransportConfig.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/TransportConfig.java b/geode-core/src/main/java/org/apache/geode/internal/admin/TransportConfig.java
index 0644736..ed5417b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/TransportConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/TransportConfig.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.admin;
+package org.apache.geode.internal.admin;
 
 /**
  * A simple value object to contain information needed to connect to a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/package.html b/geode-core/src/main/java/org/apache/geode/internal/admin/package.html
index 79da925..54b060a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/package.html
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/package.html
@@ -23,7 +23,7 @@ used by tools such as the GemFire Console to obtain information about
 the members of a GemFire distributed system.  This package contains
 interfaces that specify the behavior of the internal administration
 API.  The implementation of these interfaces is in the
-<a href="{@docRoot}/com/gemstone/gemfire/internal/admin/remote/package-summary.html#package_description">com.gemstone.gemfire.internal.admin.remote</a> package.</P>
+<a href="{@docRoot}/org/apache/geode/internal/admin/remote/package-summary.html#package_description">org.apache.geode.internal.admin.remote</a> package.</P>
 
 </BODY>
 </HTML>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerRequest.java
index c3a9eb4..b1cfe90 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerRequest.java
@@ -16,14 +16,14 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-import com.gemstone.gemfire.distributed.internal.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
+import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealthConfig;
+import org.apache.geode.distributed.internal.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
 import java.io.*;
 //import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerResponse.java
index 244d349..729f855 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddHealthListenerResponse.java
@@ -16,16 +16,16 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.admin.GemFireHealthConfig;
-//import com.gemstone.gemfire.internal.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+import org.apache.geode.admin.GemFireHealthConfig;
+//import org.apache.geode.internal.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
+import org.apache.geode.distributed.internal.membership.*;
 
 /**
  * The response to adding a health listener.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerRequest.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerRequest.java
index a5d9ef4..c959c65 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerRequest.java
@@ -16,13 +16,13 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-import com.gemstone.gemfire.distributed.internal.*;
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
-import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.*;
+import org.apache.geode.internal.admin.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 //import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerResponse.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerResponse.java b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerResponse.java
index 078798f..ac8dfa9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/remote/AddStatListenerResponse.java
@@ -16,15 +16,15 @@
  */
    
    
-package com.gemstone.gemfire.internal.admin.remote;
+package org.apache.geode.internal.admin.remote;
 
-//import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.admin.*;
-import com.gemstone.gemfire.distributed.internal.*;
+//import org.apache.geode.*;
+//import org.apache.geode.internal.admin.*;
+import org.apache.geode.distributed.internal.*;
 import java.io.*;
 //import java.util.*;
-import com.gemstone.gemfire.distributed.internal.membership.*;
-import com.gemstone.gemfire.internal.statistics.GemFireStatSampler;
+import org.apache.geode.distributed.internal.membership.*;
+import org.apache.geode.internal.statistics.GemFireStatSampler;
 
 /**
  * A message that is sent to a particular distribution manager to



[72/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGatewayHubService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGatewayHubService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGatewayHubService.java
deleted file mode 100644
index 932ec41..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberGatewayHubService.java
+++ /dev/null
@@ -1,149 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map;
-
-/**
- * Class MemberGatewayHubService
- * 
- * This class contains implementations of getting Gateway Receivers and Senders
- * details of Cluster Member.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberGatewayHub")
-@Scope("singleton")
-public class MemberGatewayHubService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberGatewayHub").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils
-        .makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      // get gateway receiver
-      Cluster.GatewayReceiver gatewayReceiver = clusterMember.getGatewayReceiver();
-
-      Boolean isGateway = false;
-
-      if (gatewayReceiver != null) {
-        responseJSON.put("isGatewayReceiver", true);
-        responseJSON.put("listeningPort", gatewayReceiver.getListeningPort());
-        responseJSON.put("linkTroughput", gatewayReceiver.getLinkThroughput());
-        responseJSON.put("avgBatchLatency", gatewayReceiver.getAvgBatchProcessingTime());
-      } else {
-        responseJSON.put("isGatewayReceiver", false);
-      }
-
-      // get gateway senders
-      Cluster.GatewaySender[] gatewaySenders = clusterMember.getMemberGatewaySenders();
-
-      if (gatewaySenders.length > 0) {
-        isGateway = true;
-      }
-      responseJSON.put("isGatewaySender", isGateway);
-      // Senders
-      ArrayNode gatewaySendersJsonList = mapper.createArrayNode();
-
-      for (Cluster.GatewaySender gatewaySender : gatewaySenders) {
-        ObjectNode gatewaySenderJSON = mapper.createObjectNode();
-        gatewaySenderJSON.put("id", gatewaySender.getId());
-        gatewaySenderJSON.put("queueSize", gatewaySender.getQueueSize());
-        gatewaySenderJSON.put("status", gatewaySender.getStatus());
-        gatewaySenderJSON.put("primary", gatewaySender.getPrimary());
-        gatewaySenderJSON.put("senderType", gatewaySender.getSenderType());
-        gatewaySenderJSON.put("batchSize", gatewaySender.getBatchSize());
-        gatewaySenderJSON.put("PersistenceEnabled", gatewaySender.getPersistenceEnabled());
-        gatewaySenderJSON.put("remoteDSId", gatewaySender.getRemoteDSId());
-        gatewaySenderJSON.put("eventsExceedingAlertThreshold", gatewaySender.getEventsExceedingAlertThreshold());
-
-        gatewaySendersJsonList.add(gatewaySenderJSON);
-      }
-      // senders response
-      responseJSON.put("gatewaySenders", gatewaySendersJsonList);
-
-      // async event queues
-      Cluster.AsyncEventQueue[] asyncEventQueues = clusterMember.getMemberAsyncEventQueueList();
-      ArrayNode asyncEventQueueJsonList = mapper.createArrayNode();
-
-      for (Cluster.AsyncEventQueue asyncEventQueue : asyncEventQueues) {
-        ObjectNode asyncEventQueueJSON = mapper.createObjectNode();
-        asyncEventQueueJSON.put("id", asyncEventQueue.getId());
-        asyncEventQueueJSON.put("primary", asyncEventQueue.getPrimary());
-        asyncEventQueueJSON.put("senderType", asyncEventQueue.isParallel());
-        asyncEventQueueJSON.put("batchSize", asyncEventQueue.getBatchSize());
-        asyncEventQueueJSON.put("batchTimeInterval", asyncEventQueue.getBatchTimeInterval());
-        asyncEventQueueJSON.put("batchConflationEnabled", asyncEventQueue.isBatchConflationEnabled());
-        asyncEventQueueJSON.put("asyncEventListener", asyncEventQueue.getAsyncEventListener());
-        asyncEventQueueJSON.put("queueSize", asyncEventQueue.getEventQueueSize());
-
-        asyncEventQueueJsonList.add(asyncEventQueueJSON);
-      }
-      responseJSON.put("asyncEventQueues", asyncEventQueueJsonList);
-
-      Map<String,Cluster.Region> clusterRegions = cluster.getClusterRegions();
-
-      List<Cluster.Region> clusterRegionsList = new ArrayList<Cluster.Region>();
-      clusterRegionsList.addAll(clusterRegions.values());
-
-      ArrayNode regionsList = mapper.createArrayNode();
-
-      for (Cluster.Region region : clusterRegionsList) {
-        if (region.getWanEnabled()) {
-          ObjectNode regionJSON = mapper.createObjectNode();
-          regionJSON.put("name", region.getName());
-          regionsList.add(regionJSON);
-        }
-      }
-      responseJSON.put("regionsInvolved", regionsList);
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberHeapUsageService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberHeapUsageService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberHeapUsageService.java
deleted file mode 100644
index 966b346..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberHeapUsageService.java
+++ /dev/null
@@ -1,73 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberHeapUsageService
- * 
- * This class contains implementations of getting Memeber's current Heap Usage
- * and its trend over the time.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberHeapUsage")
-@Scope("singleton")
-public class MemberHeapUsageService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // members list
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberHeapUsage").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      responseJSON.put("heapUsageTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_HEAP_USAGE_SAMPLE)));
-      responseJSON.put("currentHeapUsage", clusterMember.getCurrentHeapSize());
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberKeyStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberKeyStatisticsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberKeyStatisticsService.java
deleted file mode 100644
index 8519ad4..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberKeyStatisticsService.java
+++ /dev/null
@@ -1,76 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MemberKeyStatisticsService
- * 
- * This class contains implementations of getting Member's CPU, Memory and Read
- * Write details
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MemberKeyStatistics")
-@Scope("singleton")
-public class MemberKeyStatisticsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberKeyStatistics").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      // response
-      responseJSON.put("cpuUsageTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_CPU_USAGE_SAMPLE)));
-      responseJSON.put("memoryUsageTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_HEAP_USAGE_SAMPLE)));
-      responseJSON.put("readPerSecTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_GETS_PER_SECOND)));
-      responseJSON.put("writePerSecTrend",
-          mapper.valueToTree(clusterMember.getMemberStatisticTrend(Cluster.Member.MEMBER_STAT_PUTS_PER_SECOND)));
-    }
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberRegionsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberRegionsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberRegionsService.java
deleted file mode 100644
index ffd24d0..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MemberRegionsService.java
+++ /dev/null
@@ -1,127 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-
-/**
- * Class MemberRegionsService
- * 
- * This class contains implementations of getting Memeber's Regions details.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("MemberRegions")
-@Scope("singleton")
-public class MemberRegionsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  // String constants used for forming a json response
-  private final String NAME = "name";
-  private final String ENTRY_SIZE = "entrySize";
-  private final String DISC_STORE_NAME = "diskStoreName";
-  private final String DISC_SYNCHRONOUS = "diskSynchronous";
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    String memberName = requestDataJSON.get("MemberRegions").get("memberName").textValue();
-
-    Cluster.Member clusterMember = cluster.getMember(StringUtils.makeCompliantName(memberName));
-
-    if (clusterMember != null) {
-      responseJSON.put("memberId", clusterMember.getId());
-      responseJSON.put(this.NAME, clusterMember.getName());
-      responseJSON.put("host", clusterMember.getHost());
-
-      // member's regions
-      Cluster.Region[] memberRegions = clusterMember.getMemberRegionsList();
-      ArrayNode regionsListJson = mapper.createArrayNode();
-      for (Cluster.Region memberRegion : memberRegions) {
-        ObjectNode regionJSON = mapper.createObjectNode();
-        regionJSON.put(this.NAME, memberRegion.getName());
-
-        if (PulseConstants.PRODUCT_NAME_SQLFIRE.equalsIgnoreCase(PulseController.getPulseProductSupport())) {
-          // Convert region path to dot separated region path
-          regionJSON.put("fullPath", StringUtils.getTableNameFromRegionName(memberRegion.getFullPath()));
-        } else {
-          regionJSON.put("fullPath", memberRegion.getFullPath());
-        }
-
-        regionJSON.put("type", memberRegion.getRegionType());
-        regionJSON.put("entryCount", memberRegion.getSystemRegionEntryCount());
-        Long entrySize = memberRegion.getEntrySize();
-
-        DecimalFormat form = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN_2);
-        String entrySizeInMB = form.format(entrySize / (1024f * 1024f));
-
-        if (entrySize < 0) {
-          regionJSON.put(this.ENTRY_SIZE, this.VALUE_NA);
-        } else {
-          regionJSON.put(this.ENTRY_SIZE, entrySizeInMB);
-        }
-        regionJSON.put("scope", memberRegion.getScope());
-        String diskStoreName = memberRegion.getDiskStoreName();
-        if (StringUtils.isNotNullNotEmptyNotWhiteSpace(diskStoreName)) {
-          regionJSON.put(this.DISC_STORE_NAME, diskStoreName);
-          regionJSON.put(this.DISC_SYNCHRONOUS,
-              memberRegion.isDiskSynchronous());
-        } else {
-          regionJSON.put(this.DISC_SYNCHRONOUS, this.VALUE_NA);
-          regionJSON.put(this.DISC_STORE_NAME, "");
-        }
-        regionJSON.put("gatewayEnabled", memberRegion.getWanEnabled());
-
-        regionsListJson.add(regionJSON);
-      }
-      responseJSON.put("memberRegions", regionsListJson);
-
-      // response
-      responseJSON.put("status", "Normal");
-
-    }
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MembersListService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MembersListService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MembersListService.java
deleted file mode 100644
index 467d8c0..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/MembersListService.java
+++ /dev/null
@@ -1,75 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class MembersListService
- * 
- * This class contains implementations of getting list of Cluster Members.
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("MembersList")
-@Scope("singleton")
-public class MembersListService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // members list
-    ArrayNode memberListJson = mapper.createArrayNode();
-    Cluster.Member[] memberSet = cluster.getMembers();
-
-    for (Cluster.Member member : memberSet) {
-      ObjectNode memberJSON = mapper.createObjectNode();
-      memberJSON.put("memberId", member.getId());
-      memberJSON.put("name", member.getName());
-      memberJSON.put("host", member.getHost());
-
-      memberListJson.add(memberJSON);
-    }
-
-    // Response JSON
-    responseJSON.put("clusterMembers", memberListJson);
-    responseJSON.put("clusterName", cluster.getServerName());
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseService.java
deleted file mode 100644
index 58d9dbf..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseService.java
+++ /dev/null
@@ -1,40 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import javax.servlet.http.HttpServletRequest;
-
-import com.fasterxml.jackson.databind.node.ObjectNode;
-
-/**
- * Abstract class PulseService
- * 
- * This is a base class for all services in pulse.
- * 
- * @since GemFire version 7.5
- */
-public interface PulseService {
-
-  String VALUE_NA = "NA";
-  String VALUE_ON = "ON";
-  String VALUE_OFF = "OFF";
-
-  ObjectNode execute(HttpServletRequest httpServletRequest) throws Exception;
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseServiceFactory.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseServiceFactory.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseServiceFactory.java
deleted file mode 100644
index ead5200..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseServiceFactory.java
+++ /dev/null
@@ -1,55 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import org.springframework.beans.BeansException;
-import org.springframework.context.ApplicationContext;
-import org.springframework.context.ApplicationContextAware;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-
-/**
- * Class PulseServiceFactory
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Scope("singleton")
-public class PulseServiceFactory implements ApplicationContextAware {
-
-  static final long serialVersionUID = 02L;
-  ApplicationContext applicationContext = null;
-
-  public PulseService getPulseServiceInstance(final String servicename) {
-
-    if (applicationContext != null
-        && applicationContext.containsBean(servicename)) {
-      return (PulseService) applicationContext.getBean(servicename);
-    }
-    return null;
-  }
-
-  @Override
-  public void setApplicationContext(final ApplicationContext applicationContext)
-      throws BeansException {
-
-    this.applicationContext = applicationContext;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseVersionService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseVersionService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseVersionService.java
deleted file mode 100644
index 7b84404..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/PulseVersionService.java
+++ /dev/null
@@ -1,65 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.controllers.PulseController;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class PulseVersionService
- * 
- * This class contains implementations of getting Pulse Applications Version's
- * details (like version details, build details, source details, etc) from
- * properties file
- * 
- * @since GemFire version 7.0.Beta
- */
-
-@Component
-@Service("PulseVersion")
-@Scope("singleton")
-public class PulseVersionService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // Response
-    responseJSON.put("pulseVersion", PulseController.pulseVersion.getPulseVersion());
-    responseJSON.put("buildId", PulseController.pulseVersion.getPulseBuildId());
-    responseJSON.put("buildDate", PulseController.pulseVersion.getPulseBuildDate());
-    responseJSON.put("sourceDate", PulseController.pulseVersion.getPulseSourceDate());
-    responseJSON.put("sourceRevision", PulseController.pulseVersion.getPulseSourceRevision());
-    responseJSON.put("sourceRepository", PulseController.pulseVersion.getPulseSourceRepository());
-
-    // Send json response
-    return responseJSON;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/QueryStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/QueryStatisticsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/QueryStatisticsService.java
deleted file mode 100644
index 87f65df..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/QueryStatisticsService.java
+++ /dev/null
@@ -1,115 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import javax.servlet.http.HttpServletRequest;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-
-/**
- * Class QueryStatisticsService
- * 
- * This class returns top N queries based on pagination and filtering criteria
- * if any
- * 
- * @since GemFire version 7.5
- */
-@Component
-@Service("QueryStatistics")
-@Scope("singleton")
-public class QueryStatisticsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  @Override
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    Cluster.Statement[] stmts = cluster.getStatements();
-
-    ArrayNode queryListJson = mapper.createArrayNode();
-    for (int i = 0; i < stmts.length; ++i) {
-      ObjectNode queryJSON = mapper.createObjectNode();
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QUERYDEFINITION, stmts[i].getQueryDefinition());
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESCOMPILED,
-          mapper.valueToTree(stmts[i].getNumTimesCompiled() < 0 ? this.VALUE_NA : stmts[i].getNumTimesCompiled()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTION,
-          mapper.valueToTree(stmts[i].getNumExecution() < 0 ? this.VALUE_NA : stmts[i].getNumExecution()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMEXECUTIONSINPROGRESS,
-          mapper.valueToTree(stmts[i].getNumExecutionsInProgress() < 0 ? this.VALUE_NA : stmts[i].getNumExecutionsInProgress()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMTIMESGLOBALINDEXLOOKUP,
-          mapper.valueToTree(stmts[i].getNumTimesGlobalIndexLookup() < 0 ? this.VALUE_NA : stmts[i].getNumTimesGlobalIndexLookup()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_NUMROWSMODIFIED,
-          mapper.valueToTree(stmts[i].getNumRowsModified() < 0 ? this.VALUE_NA : stmts[i].getNumRowsModified()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_PARSETIME,
-          mapper.valueToTree(stmts[i].getParseTime() < 0 ? this.VALUE_NA : stmts[i].getParseTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_BINDTIME,
-          mapper.valueToTree(stmts[i].getBindTime() < 0 ? this.VALUE_NA : stmts[i].getBindTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_OPTIMIZETIME,
-          mapper.valueToTree(stmts[i].getOptimizeTime() < 0 ? this.VALUE_NA : stmts[i].getOptimizeTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_ROUTINGINFOTIME,
-          mapper.valueToTree(stmts[i].getRoutingInfoTime() < 0 ? this.VALUE_NA : stmts[i].getRoutingInfoTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_GENERATETIME,
-          mapper.valueToTree(stmts[i].getGenerateTime() < 1 ? this.VALUE_NA : stmts[i].getGenerateTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_TOTALCOMPILATIONTIME,
-          mapper.valueToTree(stmts[i].getTotalCompilationTime() < 0 ? this.VALUE_NA : stmts[i].getTotalCompilationTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_EXECUTIONTIME,
-          mapper.valueToTree(stmts[i].getExecutionTime() < 0 ? this.VALUE_NA : stmts[i].getExecutionTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_PROJECTIONTIME,
-          mapper.valueToTree(stmts[i].getProjectionTime() < 0 ? this.VALUE_NA : stmts[i].getProjectionTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_TOTALEXECUTIONTIME,
-          mapper.valueToTree(stmts[i].getTotalExecutionTime() < 0 ? this.VALUE_NA : stmts[i].getTotalExecutionTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_ROWSMODIFICATIONTIME,
-          mapper.valueToTree(stmts[i].getRowsModificationTime() < 0 ? this.VALUE_NA : stmts[i].getRowsModificationTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNNUMROWSSEEN,
-          mapper.valueToTree(stmts[i].getqNNumRowsSeen() < 0 ? this.VALUE_NA : stmts[i].getqNNumRowsSeen()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNMSGSENDTIME,
-          mapper.valueToTree(stmts[i].getqNMsgSendTime() < 0 ? this.VALUE_NA : stmts[i].getqNMsgSendTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNMSGSERTIME,
-          mapper.valueToTree(stmts[i].getqNMsgSerTime() < 0 ? this.VALUE_NA : stmts[i].getqNMsgSerTime()));
-      queryJSON.put(PulseConstants.MBEAN_ATTRIBUTE_QNRESPDESERTIME,
-          mapper.valueToTree(stmts[i].getqNRespDeSerTime() < 0 ? this.VALUE_NA : stmts[i].getqNRespDeSerTime()));
-      queryListJson.add(queryJSON);
-    }
-    responseJSON.put("queriesList", queryListJson);
-
-    // return jmx status
-    responseJSON.put("connectedFlag", cluster.isConnectedFlag());
-    responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
-
-    // Send json response
-    return responseJSON;
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/SystemAlertsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/SystemAlertsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/SystemAlertsService.java
deleted file mode 100644
index d21f47a..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/SystemAlertsService.java
+++ /dev/null
@@ -1,127 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.util.StringUtils;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class SystemAlertsService
- * 
- * This class contains implementations of getting system's alerts details (like
- * errors, warnings and severe errors).
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("SystemAlerts")
-@Scope("singleton")
-public class SystemAlertsService implements PulseService {
-
-  private static final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    JsonNode requestDataJSON = mapper.readTree(request.getParameter("pulseData"));
-    int pageNumber = 1; // Default
-    String strPageNumber = requestDataJSON.get("SystemAlerts").get("pageNumber").textValue();
-    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(strPageNumber)) {
-      try {
-        pageNumber = Integer.valueOf(strPageNumber);
-      } catch (NumberFormatException e) {
-      }
-    }
-
-    // cluster's Members
-    responseJSON.put("systemAlerts", getAlertsJson(cluster, pageNumber));
-    responseJSON.put("pageNumber", cluster.getNotificationPageNumber());
-    responseJSON.put("connectedFlag", cluster.isConnectedFlag());
-    responseJSON.put("connectedErrorMsg", cluster.getConnectionErrorMsg());
-
-    // Send json response
-    return responseJSON;
-  }
-
-  /**
-   * function used for getting all members details in format of JSON Object
-   * array defined under a cluster
-   * 
-   * @param cluster
-   * @return JSONObject Array list
-   */
-  public static ObjectNode getAlertsJson(Cluster cluster, int pageNumber) {
-    // getting list of all types of alerts
-    Cluster.Alert[] alertsList = cluster.getAlertsList();
-
-    // create alerts json
-    ObjectNode alertsJsonObject = mapper.createObjectNode();
-
-    if ((alertsList != null) && (alertsList.length > 0)) {
-      ArrayNode errorJsonArray = mapper.createArrayNode();
-      ArrayNode severeJsonArray = mapper.createArrayNode();
-      ArrayNode warningJsonArray = mapper.createArrayNode();
-      ArrayNode infoJsonArray = mapper.createArrayNode();
-
-      cluster.setNotificationPageNumber(pageNumber);
-      for (Cluster.Alert alert : alertsList) {
-        ObjectNode objAlertJson = mapper.createObjectNode();
-        objAlertJson.put("description", alert.getDescription());
-        objAlertJson.put("memberName", alert.getMemberName());
-        objAlertJson.put("severity", alert.getSeverity());
-        objAlertJson.put("isAcknowledged", alert.isAcknowledged());
-        objAlertJson.put("timestamp", alert.getTimestamp().toString());
-        objAlertJson.put("iso8601Ts", alert.getIso8601Ts());
-        objAlertJson.put("id", alert.getId());
-
-        if (alert.getSeverity() == Cluster.Alert.SEVERE) {
-          severeJsonArray.add(objAlertJson);
-        } else if (alert.getSeverity() == Cluster.Alert.ERROR) {
-          errorJsonArray.add(objAlertJson);
-        } else if (alert.getSeverity() == Cluster.Alert.WARNING) {
-          warningJsonArray.add(objAlertJson);
-        } else {
-          infoJsonArray.add(objAlertJson);
-        }
-      }
-      alertsJsonObject.put("info", infoJsonArray);
-      alertsJsonObject.put("warnings", warningJsonArray);
-      alertsJsonObject.put("errors", errorJsonArray);
-      alertsJsonObject.put("severe", severeJsonArray);
-    }
-    return alertsJsonObject;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/ConnectionUtil.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/ConnectionUtil.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/ConnectionUtil.java
deleted file mode 100644
index 9bbed8a..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/ConnectionUtil.java
+++ /dev/null
@@ -1,46 +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 com.vmware.geode.tools.pulse.internal.util;
-
-import java.io.IOException;
-
-import javax.net.SocketFactory;
-import javax.net.ssl.SSLSocketFactory;
-
-
-/**
- * 
- *
- */
-public class ConnectionUtil {
-
-  
-  
-  public static SocketFactory getSocketFactory(boolean usessl)
-    throws IOException
-  {
-    if(usessl){
-      return (SSLSocketFactory)SSLSocketFactory.getDefault();
-    }else{
-      return SocketFactory.getDefault();
-    }    
-  }
-  
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/IPAddressUtil.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/IPAddressUtil.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/IPAddressUtil.java
deleted file mode 100644
index 8cb6036..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/IPAddressUtil.java
+++ /dev/null
@@ -1,65 +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 com.vmware.geode.tools.pulse.internal.util;
-
-import java.util.regex.Matcher;
-import java.util.regex.Pattern;
-import java.util.regex.PatternSyntaxException;
-
-/* [ NOTE: 
- * This class supposed to be removed, if required, after discussing with 
- * VMware team ]
- */
-/**
- * Class IPAddressUtil This is utility class for checking whether ip address is
- * versions i.e. IPv4 or IPv6 address
- * 
- * 
- * @since GemFire version 7.0.1
- */
-public class IPAddressUtil {
-
-  private static Pattern VALID_IPV4_PATTERN = null;
-  private static Pattern VALID_IPV6_PATTERN = null;
-  private static final String ipv4Pattern = "(([01]?\\d\\d?|2[0-4]\\d|25[0-5])\\.){3}([01]?\\d\\d?|2[0-4]\\d|25[0-5])";
-  private static final String ipv6Pattern = "([0-9a-f]{1,4}:){7}([0-9a-f]){1,4}";
-
-  static {
-    try {
-      VALID_IPV4_PATTERN = Pattern.compile(ipv4Pattern,
-          Pattern.CASE_INSENSITIVE);
-      VALID_IPV6_PATTERN = Pattern.compile(ipv6Pattern,
-          Pattern.CASE_INSENSITIVE);
-    } catch (PatternSyntaxException e) {
-
-    }
-  }
-
-  public static Boolean isIPv4LiteralAddress(String IPAddress) {
-    Matcher matcher = IPAddressUtil.VALID_IPV4_PATTERN.matcher(IPAddress);
-    return matcher.matches();
-  }
-
-  public static Boolean isIPv6LiteralAddress(String IPAddress) {
-
-    Matcher matcher = IPAddressUtil.VALID_IPV6_PATTERN.matcher(IPAddress);
-    return matcher.matches();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/StringUtils.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/StringUtils.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/StringUtils.java
deleted file mode 100644
index 64f2731..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/StringUtils.java
+++ /dev/null
@@ -1,85 +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 com.vmware.geode.tools.pulse.internal.util;
-
-/**
- * Class StringUtils This is utility class for string.
- * 
- * 
- * @since GemFire version 7.0.1
- */
-public class StringUtils {
-  /**
-   * Checks the string if it is not null, not empty, and not white space only
-   * using standard Java classes.
-   * 
-   * @param string
-   *          String to be checked.
-   * @return {@code true} if provided String is not null, is not empty, and has
-   *         at least one character that is not considered white space.
-   */
-  public static boolean isNotNullNotEmptyNotWhiteSpace(final String string) {
-    return string != null && !string.isEmpty() && !string.trim().isEmpty();
-  }
-
-  /**
-   * Checking for String that is not null, not empty, and not white space only
-   * using standard Java classes.
-   * 
-   * @param value
-   *          String to be made compliant.
-   * @return string compliant string.
-   */
-  public static String makeCompliantName(String value) {
-    value = value.replace(':', '-');
-    value = value.replace(',', '-');
-    value = value.replace('=', '-');
-    value = value.replace('*', '-');
-    value = value.replace('?', '-');
-    if (value.length() < 1) {
-      value = "nothing";
-    }
-    return value;
-  }
-
-  /**
-   * Function to get table name derived from region name/full path
-   * 
-   * @param regionName
-   *          String to be made compliant.
-   * @return string compliant string.
-   */
-  public static String getTableNameFromRegionName(String regionName) {
-    String tableName = regionName.replaceFirst("/", "").replace('/', '.');
-    return tableName;
-  }
-
-  /**
-   * Function to get region name/full path derived from table name
-   * 
-   * @param tableName
-   *          String to be made compliant.
-   * @return string compliant string.
-   */
-  public static String getRegionNameFromTableName(String tableName) {
-    String regionName = "/" + tableName.replace('.', '/');
-    return regionName;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/TimeUtils.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/TimeUtils.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/TimeUtils.java
deleted file mode 100644
index 21f9116..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/util/TimeUtils.java
+++ /dev/null
@@ -1,120 +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 com.vmware.geode.tools.pulse.internal.util;
-
-/**
- * Class TimeUtils 
- * 
- * This is utility class used for conversions of time.
- * 
- * 
- * @since GemFire version 7.0.1
- */
-public class TimeUtils {
-
-  /**
-   * Method to converts time given in milliseconds to string representation in
-   * days, hours, minutes and seconds
-   * 
-   * @param longMilliSecs
-   *          Time in milliseconds.
-   * @return String
-   */
-  public static String convertTimeMillisecondsToHMS(long longMilliSecs) {
-
-    long days = longMilliSecs / (1000 * 60 * 60 * 24);
-    long remainder = longMilliSecs % (1000 * 60 * 60 * 24);
-
-    long hours = remainder / (1000 * 60 * 60);
-    remainder = remainder % (1000 * 60 * 60);
-
-    long mins = remainder / (1000 * 60);
-    remainder = remainder % (1000 * 60);
-
-    long secs = remainder / 1000;
-
-    String strDaysHrsMinsSecs = "";
-
-    if (days > 0) {
-      strDaysHrsMinsSecs += days + " Days ";
-    }
-
-    if (hours > 0) {
-      strDaysHrsMinsSecs += hours + " Hours ";
-    } else {
-      strDaysHrsMinsSecs += "0 Hours ";
-    }
-
-    if (mins > 0) {
-      strDaysHrsMinsSecs += mins + " Mins ";
-    } else {
-      strDaysHrsMinsSecs += "0 Mins ";
-    }
-
-    strDaysHrsMinsSecs += secs + " Secs";
-
-    return strDaysHrsMinsSecs;
-  }
-
-  /**
-   * Method to converts time given in seconds to string representation in days,
-   * hours, minutes and seconds
-   * 
-   * @param longSecs
-   *          Time in seconds.
-   * @return String
-   */
-  public static String convertTimeSecondsToHMS(long longSecs) {
-
-    long days = longSecs / (60 * 60 * 24);
-    long remainder = longSecs % (60 * 60 * 24);
-
-    long hours = remainder / (60 * 60);
-    remainder = remainder % (60 * 60);
-
-    long mins = remainder / (60);
-    remainder = remainder % (60);
-
-    long secs = remainder;
-
-    String strDaysHrsMinsSecs = "";
-
-    if (days > 0) {
-      strDaysHrsMinsSecs += days + " Days ";
-    }
-
-    if (hours > 0) {
-      strDaysHrsMinsSecs += hours + " Hours ";
-    } else {
-      strDaysHrsMinsSecs += "0 Hours ";
-    }
-
-    if (mins > 0) {
-      strDaysHrsMinsSecs += mins + " Mins ";
-    } else {
-      strDaysHrsMinsSecs += "0 Mins ";
-    }
-
-    strDaysHrsMinsSecs += secs + " Secs";
-
-    return strDaysHrsMinsSecs;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/PulseAppListener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/PulseAppListener.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/PulseAppListener.java
new file mode 100644
index 0000000..d4d95a7
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/PulseAppListener.java
@@ -0,0 +1,742 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal;
+
+import org.apache.geode.tools.pulse.internal.controllers.PulseController;
+import org.apache.geode.tools.pulse.internal.data.PulseConfig;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+import org.apache.geode.tools.pulse.internal.util.StringUtils;
+import org.springframework.web.context.WebApplicationContext;
+import org.springframework.web.context.support.WebApplicationContextUtils;
+
+import javax.servlet.ServletContextEvent;
+import javax.servlet.ServletContextListener;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.net.InetAddress;
+import java.net.UnknownHostException;
+import java.text.DateFormat;
+import java.text.SimpleDateFormat;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Map.Entry;
+import java.util.Properties;
+import java.util.ResourceBundle;
+import java.util.Set;
+import java.util.logging.Level;
+
+/**
+ * This class is used for checking the application running mode i.e. Embedded or
+ * not
+ * 
+ * @since GemFire version 7.0.Beta 2012-09-23
+ * 
+ */
+// @WebListener
+public class PulseAppListener implements ServletContextListener {
+  private PulseLogWriter LOGGER;
+  private final ResourceBundle resourceBundle = Repository.get()
+      .getResourceBundle();
+
+  // String object to store all messages which needs to be logged into the log
+  // file before logger gets initialized
+  private String messagesToBeLogged = "";
+
+  private Properties pulseProperties;
+  private Properties pulseSecurityProperties;
+  private Boolean sysPulseUseLocator;
+  private String sysPulseHost;
+  private String sysPulsePort;
+  private String jmxUserName;
+  private String jmxUserPassword;
+  
+  private boolean sysPulseUseSSLLocator;
+  private boolean sysPulseUseSSLManager;
+  
+  //This property determines if pulse webApp login is authenticated against
+  //GemFire integrated security or custom spring-security config provided 
+  //in pulse-authentication-custom.xml 
+  private boolean useGemFireCredentials;
+
+  @Override
+  public void contextDestroyed(ServletContextEvent event) {
+
+    // Stop all running threads those are created in Pulse
+    // Stop cluster threads
+    Repository.get().removeAllClusters();
+
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_CONTEXT_DESTROYED")
+          + event.getServletContext().getContextPath());
+    }
+  }
+
+  @Override
+  public void contextInitialized(ServletContextEvent event) {
+    
+    messagesToBeLogged = messagesToBeLogged
+        .concat(formatLogString(resourceBundle
+            .getString("LOG_MSG_CONTEXT_INITIALIZED")));
+
+    // Load Pulse version details
+    loadPulseVersionDetails();
+
+    // Load Pulse Properties
+    pulseProperties = loadProperties(PulseConstants.PULSE_PROPERTIES_FILE);
+
+    if (pulseProperties.isEmpty()) {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_PROPERTIES_NOT_FOUND")));
+    } else {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_PROPERTIES_FOUND")));
+
+      // set Pulse product support into the Pulse controller for access from
+      // client side
+      // to display the appropriate ui depending on which product is supported
+      // in present deployment
+      String pulseProduct = pulseProperties.getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_PRODUCTSUPPORT);
+      // default is gemfire
+
+      if ((pulseProduct != null) && (pulseProduct.trim().equalsIgnoreCase(PulseConstants.PRODUCT_NAME_SQLFIRE))) {
+        PulseController.setPulseProductSupport(PulseConstants.PRODUCT_NAME_SQLFIRE);
+      }
+    }
+    
+    pulseSecurityProperties = loadProperties(PulseConstants.PULSE_SECURITY_PROPERTIES_FILE);
+
+    // Initialize logger
+    initializeLogger();
+
+    // Reference to repository
+    Repository repository = Repository.get();
+
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_CHECK_APP_RUNNING_MODE"));
+    }
+
+    boolean sysIsEmbedded = Boolean
+        .getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_EMBEDDED);
+
+    if (sysIsEmbedded) {
+      // Application Pulse is running in Embedded Mode
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle
+            .getString("LOG_MSG_APP_RUNNING_EMBEDDED_MODE"));
+      }
+      repository.setIsEmbeddedMode(true);
+
+      sysPulseUseLocator = Boolean.FALSE;
+	  try{
+				// Get host name of machine running pulse in embedded mode
+		   sysPulseHost = InetAddress.getLocalHost().getCanonicalHostName();
+		} catch (UnknownHostException e) {
+			if (LOGGER.fineEnabled()) {
+				LOGGER.fine(resourceBundle
+							.getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST")
+							+ e.getMessage());
+		    }
+				// Set default host name
+		    sysPulseHost = PulseConstants.GEMFIRE_DEFAULT_HOST;
+		} catch (Exception e) {
+			if (LOGGER.fineEnabled()) {
+					LOGGER.fine(resourceBundle
+							.getString("LOG_MSG_JMX_CONNECTION_UNKNOWN_HOST")
+							+ e.getMessage());
+			}
+				// Set default host name
+			sysPulseHost = PulseConstants.GEMFIRE_DEFAULT_HOST;
+		}
+      sysPulsePort = PulseConstants.GEMFIRE_DEFAULT_PORT;
+      
+      boolean pulseEmbededSqlf = Boolean.getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_EMBEDDED_SQLF);
+      if(pulseEmbededSqlf){
+        PulseController.setPulseProductSupport(PulseConstants.PRODUCT_NAME_SQLFIRE);
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle
+              .getString("LOG_MSG_APP_RUNNING_EMBEDDED_SQLF_MODE"));
+        }
+      }
+
+    } else {
+      // Application Pulse is running in Non-Embedded Mode
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle
+            .getString("LOG_MSG_APP_RUNNING_NONEMBEDDED_MODE"));
+      }
+      repository.setIsEmbeddedMode(false);
+
+      // Load JMX User Details
+      loadJMXUserDetails();
+      // Load locator and/or manager details
+      loadLocatorManagerDetails();
+       
+      useGemFireCredentials = areWeUsingGemFireSecurityProfile(event); 
+    }
+
+    // Set user details in repository    
+    repository.setJmxUserName(jmxUserName);
+    repository.setJmxUserPassword(jmxUserPassword);
+
+    // Set locator/Manager details in repository
+    repository.setJmxUseLocator(sysPulseUseLocator);
+    repository.setJmxHost(sysPulseHost);
+    repository.setJmxPort(sysPulsePort);
+    
+    //set SSL info
+    initializeSSL();
+    repository.setUseSSLLocator(sysPulseUseSSLLocator);
+    repository.setUseSSLManager(sysPulseUseSSLManager);
+    
+    repository.setUseGemFireCredentials(useGemFireCredentials);
+
+  }
+
+  /**
+   * Return true if pulse is configure to authenticate using gemfire
+   * integrated security
+   * 
+   * @param event
+   * @return
+   */
+  private boolean areWeUsingGemFireSecurityProfile(ServletContextEvent event) {
+    String profile = null;
+    WebApplicationContext ctx = WebApplicationContextUtils.getWebApplicationContext(event.getServletContext());
+    if (ctx.getEnvironment() != null) {
+      String[] profiles = ctx.getEnvironment().getActiveProfiles();
+      if (profiles != null && profiles.length > 0) {
+        StringBuilder sb = new StringBuilder();
+        for (String p : profiles)
+          sb.append(p).append(",");
+        LOGGER.info("#SpringProfilesConfigured : " + sb.toString());
+        profile = ctx.getEnvironment().getActiveProfiles()[0];
+        LOGGER.info("#First Profile : " + profile);
+      } else {
+        LOGGER.info("No SpringProfileConfigured using default spring profile");
+        return false;
+      }
+    }
+    if (PulseConstants.APPLICATION_PROPERTY_PULSE_SEC_PROFILE_GEMFIRE.equals(profile)) {
+      LOGGER.info("Using gemfire integrated security profile");
+      return true;
+    }      
+    return false;
+  }
+
+  // Function to load pulse version details from properties file
+  private void loadPulseVersionDetails() {
+
+    // Read version details from version property file
+    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+    InputStream inputStream = classLoader
+        .getResourceAsStream(PulseConstants.PULSE_VERSION_PROPERTIES_FILE);
+
+    if (inputStream != null) {
+      Properties properties = new Properties();
+      try {
+        properties.load(inputStream);
+      } catch (IOException e) {
+        messagesToBeLogged = messagesToBeLogged
+            .concat(formatLogString(resourceBundle
+                .getString("LOG_MSG_EXCEPTION_LOADING_PROPERTIES_FILE")));
+      } finally {
+        try {
+          inputStream.close();
+        } catch (IOException e) {
+          messagesToBeLogged = messagesToBeLogged
+              .concat(formatLogString(resourceBundle
+                  .getString("LOG_MSG_EXCEPTION_CLOSING_INPUT_STREAM")));
+        }
+      }
+      // Set pulse version details in common object
+      PulseController.pulseVersion.setPulseVersion(properties.getProperty(
+          PulseConstants.PROPERTY_PULSE_VERSION, ""));
+      PulseController.pulseVersion.setPulseBuildId(properties.getProperty(
+          PulseConstants.PROPERTY_BUILD_ID, ""));
+      PulseController.pulseVersion.setPulseBuildDate(properties.getProperty(
+          PulseConstants.PROPERTY_BUILD_DATE, ""));
+      PulseController.pulseVersion.setPulseSourceDate(properties.getProperty(
+          PulseConstants.PROPERTY_SOURCE_DATE, ""));
+      PulseController.pulseVersion.setPulseSourceRevision(properties
+          .getProperty(PulseConstants.PROPERTY_SOURCE_REVISION, ""));
+      PulseController.pulseVersion.setPulseSourceRepository(properties
+          .getProperty(PulseConstants.PROPERTY_SOURCE_REPOSITORY, ""));
+    }
+
+    // Log Pulse Version details into log file
+    messagesToBeLogged = messagesToBeLogged
+        .concat(formatLogString(PulseController.pulseVersion
+            .getPulseVersionLogMessage()));
+  }
+
+  private void initializeLogger() {
+
+    // Override default log configuration by properties which are provided in
+    // properties file.
+    loadLogDetailsFromPropertyFile();
+
+    // Override log configuration by properties which are provided in
+    // through system properties.
+    loadLogDetailsFromSystemProperties();
+
+    // Initialize logger object
+    LOGGER = PulseLogWriter.getLogger();
+
+    // Log messages stored in messagesToBeLogged
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(messagesToBeLogged);
+      messagesToBeLogged = "";
+    }
+  }
+
+  // Function to load pulse properties from pulse.properties file
+  private Properties loadProperties(String propertyFile) {
+
+    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+    InputStream inputStream = classLoader.getResourceAsStream(propertyFile);
+    Properties properties = new Properties();
+
+    if (inputStream != null) {
+      messagesToBeLogged = messagesToBeLogged.concat(formatLogString(propertyFile + " "
+          + resourceBundle.getString("LOG_MSG_FILE_FOUND")));
+
+      try {
+        // Load properties from input stream
+        properties.load(inputStream);
+      } catch (IOException e1) {
+        messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
+            .getString("LOG_MSG_EXCEPTION_LOADING_PROPERTIES_FILE")
+            + " " + propertyFile));
+      } finally {
+        // Close input stream
+        try {
+          inputStream.close();
+        } catch (IOException e) {
+          messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_EXCEPTION_CLOSING_INPUT_STREAM")
+              + " " + propertyFile));
+        }
+      }
+
+    } else {
+      messagesToBeLogged = messagesToBeLogged.concat(formatLogString(resourceBundle
+          .getString("LOG_MSG_COULD_NOT_READ_FILE")
+          + " " + propertyFile));
+    }
+    return properties;
+  }
+
+  // Function to load Logging details from properties file
+  private void loadLogDetailsFromPropertyFile() {
+
+    // return, if Pulse Properties are not provided
+    if (pulseProperties.size() == 0) {
+      return;
+    }
+
+    messagesToBeLogged = messagesToBeLogged
+        .concat(formatLogString(resourceBundle
+            .getString("LOG_MSG_CHECK_LOG_PROPERTIES_IN_FILE")));
+
+    HashMap<String, String> logPropertiesHM = new HashMap<String, String>();
+
+    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME, ""));
+
+    logPropertiesHM.put(
+        PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION, ""));
+
+    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE, ""));
+
+    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT, ""));
+
+    logPropertiesHM.put(
+        PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN, ""));
+
+    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL, ""));
+
+    logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
+        pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND, ""));
+
+    if (logPropertiesHM.size() == 0) {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_LOG_PROPERTIES_NOT_FOUND_IN_FILE")));
+    } else {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_LOG_PROPERTIES_FOUND_IN_FILE")));
+    }
+
+    setLogConfigurations(logPropertiesHM);
+  }
+
+  // Function to load Logging details from system properties
+  private void loadLogDetailsFromSystemProperties() {
+
+    messagesToBeLogged = messagesToBeLogged
+        .concat(formatLogString(resourceBundle
+            .getString("LOG_MSG_CHECK_LOG_PROPERTIES_IN_SYSTEM_PROPERTIES")));
+
+    HashMap<String, String> logPropertiesHM = new HashMap<String, String>();
+
+    String sysLogFileName = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME);
+    String sysLogFileLocation = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION);
+    String sysLogFileSize = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE);
+    String sysLogFileCount = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT);
+    String sysLogDatePattern = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN);
+    String sysLogLevel = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL);
+    String sysLogAppend = System
+        .getProperty(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND);
+
+    if (sysLogFileName == null || sysLogFileName.isEmpty()) {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME, "");
+    } else {
+      logPropertiesHM
+          .put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME,
+              sysLogFileName);
+    }
+
+    if (sysLogFileLocation == null || sysLogFileLocation.isEmpty()) {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION, "");
+    } else {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION,
+          sysLogFileLocation);
+    }
+
+    if (sysLogFileSize == null || sysLogFileSize.isEmpty()) {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE, "");
+    } else {
+      logPropertiesHM
+          .put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE,
+              sysLogFileSize);
+    }
+
+    if (sysLogFileCount == null || sysLogFileCount.isEmpty()) {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT, "");
+    } else {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT,
+          sysLogFileCount);
+    }
+
+    if (sysLogDatePattern == null || sysLogDatePattern.isEmpty()) {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN, "");
+    } else {
+      logPropertiesHM.put(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN,
+          sysLogDatePattern);
+    }
+
+    if (sysLogLevel == null || sysLogLevel.isEmpty()) {
+      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
+          "");
+    } else {
+      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL,
+          sysLogLevel);
+    }
+
+    if (sysLogAppend == null || sysLogAppend.isEmpty()) {
+      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
+          "");
+    } else {
+      logPropertiesHM.put(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND,
+          sysLogAppend);
+    }
+
+    if (logPropertiesHM.size() == 0) {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_LOG_PROPERTIES_NOT_FOUND_IN_SYSTEM_PROPERTIES")));
+    } else {
+      messagesToBeLogged = messagesToBeLogged
+          .concat(formatLogString(resourceBundle
+              .getString("LOG_MSG_LOG_PROPERTIES_FOUND_IN_SYSTEM_PROPERTIES")));
+    }
+
+    setLogConfigurations(logPropertiesHM);
+  }
+
+  private void setLogConfigurations(HashMap<String, String> logPropertiesHM) {
+
+    PulseConfig pulseConfig = Repository.get().getPulseConfig();
+
+    // log file name
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME))) {
+      pulseConfig.setLogFileName(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILENAME));
+    }
+
+    // log file location
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION))) {
+      pulseConfig.setLogFileLocation(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILELOCATION));
+    }
+
+    // log file size
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE))) {
+      pulseConfig.setLogFileSize(Integer.parseInt(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILESIZE)));
+    }
+
+    // log file count
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT))) {
+      pulseConfig.setLogFileCount(Integer.parseInt(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGFILECOUNT)));
+    }
+
+    // log message date pattern
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN))) {
+      pulseConfig.setLogDatePattern(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGDATEPATTERN));
+    }
+
+    // log level
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL))) {
+      pulseConfig.setLogLevel(Level.parse(logPropertiesHM.get(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_LOGLEVEL).toUpperCase()));
+    }
+
+    // log append
+    if (StringUtils.isNotNullNotEmptyNotWhiteSpace(logPropertiesHM
+        .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND))) {
+      pulseConfig.setLogAppend(Boolean.valueOf(logPropertiesHM
+          .get(PulseConstants.APPLICATION_PROPERTY_PULSE_LOGAPPEND)));
+    }
+
+  }
+
+  // Function to load JMX User details from properties
+  private void loadJMXUserDetails() {
+
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_JMX_USER_DETAILS"));
+    }
+
+    if (pulseProperties.isEmpty()) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER
+            .info(resourceBundle
+                .getString("LOG_MSG_JMX_USER_DETAILS_NOT_FOUND")
+                + resourceBundle
+                    .getString("LOG_MSG_REASON_USER_DETAILS_NOT_FOUND"));
+      }
+    } else {
+      jmxUserName = pulseProperties.getProperty(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_JMXUSERNAME, "");
+      jmxUserPassword = pulseProperties.getProperty(
+          PulseConstants.APPLICATION_PROPERTY_PULSE_JMXPASSWORD, "");
+
+      if (jmxUserName.isEmpty() || jmxUserPassword.isEmpty()) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle
+              .getString("LOG_MSG_JMX_USER_DETAILS_NOT_FOUND")
+              + resourceBundle
+                  .getString("LOG_MSG_REASON_USER_DETAILS_NOT_FOUND"));
+        }
+      } else {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle
+              .getString("LOG_MSG_JMX_USER_DETAILS_FOUND"));
+        }
+      }
+    }
+  }
+  
+//Function to set SSL VM arguments
+  private void initializeSSL() {
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_SSL_DETAILS"));
+    }
+
+     
+    this.sysPulseUseSSLLocator = Boolean.valueOf(pulseProperties.getProperty(
+        PulseConstants.SYSTEM_PROPERTY_PULSE_USESSL_LOCATOR, "false"));
+
+    this.sysPulseUseSSLManager = Boolean.valueOf(pulseProperties.getProperty(
+        PulseConstants.SYSTEM_PROPERTY_PULSE_USESSL_MANAGER, "false"));
+
+
+    if ((sysPulseUseSSLLocator || sysPulseUseSSLManager)) {
+      Properties sslProperties = new Properties();
+      if (!pulseSecurityProperties.isEmpty()) {
+        Set entrySet = pulseSecurityProperties.entrySet();
+        for (Iterator it = entrySet.iterator(); it.hasNext();) {
+          Entry<String, String> entry = (Entry<String, String>) it.next();
+          String key = entry.getKey();
+          if (key.startsWith("javax.net.ssl.")) {
+
+            String val = entry.getValue();
+            System.setProperty(key, val);
+            sslProperties.setProperty(key, val);
+          }
+        }
+      }
+      if (sslProperties.isEmpty()) {
+        if (LOGGER.warningEnabled()) {
+          LOGGER.warning(resourceBundle.getString("LOG_MSG_SSL_NOT_SET"));
+        }
+      }
+    }
+
+  }
+
+  // Function to load locator and/or manager details
+  private void loadLocatorManagerDetails() {
+
+    // Get locator details through System Properties
+    if (LOGGER.infoEnabled()) {
+      LOGGER.info(resourceBundle.getString("LOG_MSG_GET_LOCATOR_DETAILS_1"));
+    }
+
+    // Required System properties are
+    // -Dpulse.embedded="false" -Dpulse.useLocator="false"
+    // -Dpulse.host="192.168.2.11" -Dpulse.port="2099"
+    sysPulseUseLocator = Boolean
+        .getBoolean(PulseConstants.SYSTEM_PROPERTY_PULSE_USELOCATOR);
+    sysPulseHost = System
+        .getProperty(PulseConstants.SYSTEM_PROPERTY_PULSE_HOST);
+    sysPulsePort = System
+        .getProperty(PulseConstants.SYSTEM_PROPERTY_PULSE_PORT);
+
+    if (sysPulseHost == null || sysPulseHost.isEmpty() || sysPulsePort == null
+        || sysPulsePort.isEmpty()) {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle
+            .getString("LOG_MSG_LOCATOR_DETAILS_NOT_FOUND")
+            + resourceBundle
+                .getString("LOG_MSG_REASON_LOCATOR_DETAILS_NOT_FOUND_1"));
+        LOGGER.info(resourceBundle.getString("LOG_MSG_GET_LOCATOR_DETAILS_2"));
+      }
+
+      if (pulseProperties.isEmpty()) {
+        if (LOGGER.infoEnabled()) {
+          LOGGER.info(resourceBundle
+              .getString("LOG_MSG_LOCATOR_DETAILS_NOT_FOUND")
+              + resourceBundle
+                  .getString("LOG_MSG_REASON_LOCATOR_DETAILS_NOT_FOUND_2"));
+        }
+
+        sysPulseHost = "";
+        sysPulsePort = "";
+      } else {
+        if (LOGGER.infoEnabled()) {
+          LOGGER
+              .info(resourceBundle.getString("LOG_MSG_LOCATOR_DETAILS_FOUND"));
+        }
+
+        sysPulseUseLocator = Boolean.valueOf(pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_USELOCATOR, ""));
+        sysPulseHost = pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_HOST, "");
+        sysPulsePort = pulseProperties.getProperty(
+            PulseConstants.APPLICATION_PROPERTY_PULSE_PORT, "");
+      }
+    } else {
+      if (LOGGER.infoEnabled()) {
+        LOGGER.info(resourceBundle.getString("LOG_MSG_LOCATOR_DETAILS_FOUND"));
+      }
+    }
+  }
+
+  private String formatLogString(String logMessage) {
+
+    DateFormat df = new SimpleDateFormat(
+        PulseConstants.LOG_MESSAGE_DATE_PATTERN);
+    // DateFormat df = new
+    // SimpleDateFormat(Repository.get().getPulseConfig().getLogDatePattern());
+    StringWriter sw = new StringWriter();
+    PrintWriter pw = new PrintWriter(sw);
+
+    pw.println();
+    pw.print("[");
+    pw.print("INFO");
+    pw.print(" ");
+    pw.print(df.format(new Date(System.currentTimeMillis())));
+    String threadName = Thread.currentThread().getName();
+    if (threadName != null) {
+      pw.print(" ");
+      pw.print(threadName);
+    }
+    pw.print(" tid=0x");
+    pw.print(Long.toHexString(Thread.currentThread().getId()));
+    pw.print("] ");
+    pw.print("(msgTID=");
+    pw.print("");
+
+    pw.print(" msgSN=");
+    pw.print("");
+
+    pw.print(") ");
+
+    pw.println("[" + PulseConstants.APP_NAME + "]");
+
+    pw.println(PulseLogWriter.class.getName());
+
+    pw.println(logMessage);
+
+    pw.close();
+    try {
+      sw.close();
+    } catch (IOException ignore) {
+    }
+    String result = sw.toString();
+    return result;
+
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
new file mode 100644
index 0000000..24f8dc9
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/controllers/ExceptionHandlingAdvice.java
@@ -0,0 +1,51 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.controllers;
+
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+
+import org.springframework.http.HttpStatus;
+import org.springframework.web.bind.annotation.ControllerAdvice;
+import org.springframework.web.bind.annotation.ExceptionHandler;
+import org.springframework.web.bind.annotation.ResponseStatus;
+
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+
+/**
+ * For handling IO exception in our controllers
+ * 
+ * 
+ */
+@ControllerAdvice
+public class ExceptionHandlingAdvice {
+
+  @ExceptionHandler(IOException.class)
+  @ResponseStatus(HttpStatus.INTERNAL_SERVER_ERROR)
+  public void handleExc(IOException ext) {
+    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+    // write errors
+    StringWriter swBuffer = new StringWriter();
+    PrintWriter prtWriter = new PrintWriter(swBuffer);
+    ext.printStackTrace(prtWriter);
+    LOGGER.severe("IOException Details : " + swBuffer.toString() + "\n");
+  }
+}


[64/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/README
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/README b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/README
new file mode 100644
index 0000000..2d7cdcf
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/README
@@ -0,0 +1,68 @@
+JSON in Java [package com.vmware.gemfire.tools.pulse.internal.json]
+
+Douglas Crockford
+douglas@crockford.com
+
+2011-02-02
+
+
+JSON is a light-weight, language independent, data interchange format.
+See http://www.JSON.org/
+
+The files in this package implement JSON encoders/decoders in Java. 
+It also includes the capability to convert between JSON and XML, HTTP 
+headers, Cookies, and CDL. 
+
+This is a reference implementation. There is a large number of JSON packages
+in Java. Perhaps someday the Java community will standardize on one. Until 
+then, choose carefully.
+
+The license includes this restriction: "The software shall be used for good, 
+not evil." If your conscience cannot live with that, then choose a different
+package.
+
+The package compiles on Java 1.2 thru Java 1.4.
+
+
+JSONObject.java: The JSONObject can parse text from a String or a JSONTokener
+to produce a map-like object. The object provides methods for manipulating its
+contents, and for producing a JSON compliant object serialization.
+
+JSONArray.java: The JSONObject can parse text from a String or a JSONTokener
+to produce a vector-like object. The object provides methods for manipulating 
+its contents, and for producing a JSON compliant array serialization.
+
+JSONTokener.java: The JSONTokener breaks a text into a sequence of individual
+tokens. It can be constructed from a String, Reader, or InputStream.
+
+JSONException.java: The JSONException is the standard exception type thrown
+by this package.
+
+
+JSONString.java: The JSONString interface requires a toJSONString method, 
+allowing an object to provide its own serialization.
+
+JSONStringer.java: The JSONStringer provides a convenient facility for 
+building JSON strings.
+
+JSONWriter.java: The JSONWriter provides a convenient facility for building 
+JSON text through a writer.
+ 
+
+CDL.java: CDL provides support for converting between JSON and comma
+delimited lists.
+
+Cookie.java: Cookie provides support for converting between JSON and cookies.
+
+CookieList.java: CookieList provides support for converting between JSON and
+cookie lists.
+
+HTTP.java: HTTP provides support for converting between JSON and HTTP headers.
+
+HTTPTokener.java: HTTPTokener extends JSONTokener for parsing HTTP headers.
+
+XML.java: XML provides support for converting between JSON and XML.
+
+JSONML.java: JSONML provides support for converting between JSONML and XML.
+
+XMLTokener.java: XMLTokener extends JSONTokener for parsing XML text.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XML.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XML.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XML.java
new file mode 100644
index 0000000..2aa8b8d
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XML.java
@@ -0,0 +1,503 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+import java.util.Iterator;
+
+
+/**
+ * This provides static methods to convert an XML text into a JSONObject,
+ * and to covert a JSONObject into an XML text.
+ * @author JSON.org
+ * @version 2011-02-11
+ */
+public class XML {
+
+    /** The Character '&'. */
+    public static final Character AMP   = new Character('&');
+
+    /** The Character '''. */
+    public static final Character APOS  = new Character('\'');
+
+    /** The Character '!'. */
+    public static final Character BANG  = new Character('!');
+
+    /** The Character '='. */
+    public static final Character EQ    = new Character('=');
+
+    /** The Character '>'. */
+    public static final Character GT    = new Character('>');
+
+    /** The Character '<'. */
+    public static final Character LT    = new Character('<');
+
+    /** The Character '?'. */
+    public static final Character QUEST = new Character('?');
+
+    /** The Character '"'. */
+    public static final Character QUOT  = new Character('"');
+
+    /** The Character '/'. */
+    public static final Character SLASH = new Character('/');
+
+    /**
+     * Replace special characters with XML escapes:
+     * <pre>
+     * &amp; <small>(ampersand)</small> is replaced by &amp;amp;
+     * &lt; <small>(less than)</small> is replaced by &amp;lt;
+     * &gt; <small>(greater than)</small> is replaced by &amp;gt;
+     * &quot; <small>(double quote)</small> is replaced by &amp;quot;
+     * </pre>
+     * @param string The string to be escaped.
+     * @return The escaped string.
+     */
+    public static String escape(String string) {
+        StringBuffer sb = new StringBuffer();
+        for (int i = 0, length = string.length(); i < length; i++) {
+            char c = string.charAt(i);
+            switch (c) {
+            case '&':
+                sb.append("&amp;");
+                break;
+            case '<':
+                sb.append("&lt;");
+                break;
+            case '>':
+                sb.append("&gt;");
+                break;
+            case '"':
+                sb.append("&quot;");
+                break;
+            case '\'':
+                sb.append("&apos;");
+                break;
+            default:
+                sb.append(c);
+            }
+        }
+        return sb.toString();
+    }
+    
+    /**
+     * Throw an exception if the string contains whitespace. 
+     * Whitespace is not allowed in tagNames and attributes.
+     * @param string
+     * @throws JSONException
+     */
+    public static void noSpace(String string) throws JSONException {
+        int i, length = string.length();
+        if (length == 0) {
+            throw new JSONException("Empty string.");
+        }
+        for (i = 0; i < length; i += 1) {
+            if (Character.isWhitespace(string.charAt(i))) {
+                throw new JSONException("'" + string + 
+                        "' contains a space character.");
+            }
+        }
+    }
+
+    /**
+     * Scan the content following the named tag, attaching it to the context.
+     * @param x       The XMLTokener containing the source string.
+     * @param context The JSONObject that will include the new material.
+     * @param name    The tag name.
+     * @return true if the close tag is processed.
+     * @throws JSONException
+     */
+    private static boolean parse(XMLTokener x, JSONObject context,
+                                 String name) throws JSONException {
+        char       c;
+        int        i;
+        JSONObject jsonobject = null;
+        String     string;
+        String     tagName;
+        Object     token;
+
+// Test for and skip past these forms:
+//      <!-- ... -->
+//      <!   ...   >
+//      <![  ... ]]>
+//      <?   ...  ?>
+// Report errors for these forms:
+//      <>
+//      <=
+//      <<
+
+        token = x.nextToken();
+
+// <!
+
+        if (token == BANG) {
+            c = x.next();
+            if (c == '-') {
+                if (x.next() == '-') {
+                    x.skipPast("-->");
+                    return false;
+                }
+                x.back();
+            } else if (c == '[') {
+                token = x.nextToken();
+                if ("CDATA".equals(token)) {
+                    if (x.next() == '[') {
+                        string = x.nextCDATA();
+                        if (string.length() > 0) {
+                            context.accumulate("content", string);
+                        }
+                        return false;
+                    }
+                }
+                throw x.syntaxError("Expected 'CDATA['");
+            }
+            i = 1;
+            do {
+                token = x.nextMeta();
+                if (token == null) {
+                    throw x.syntaxError("Missing '>' after '<!'.");
+                } else if (token == LT) {
+                    i += 1;
+                } else if (token == GT) {
+                    i -= 1;
+                }
+            } while (i > 0);
+            return false;
+        } else if (token == QUEST) {
+
+// <?
+
+            x.skipPast("?>");
+            return false;
+        } else if (token == SLASH) {
+
+// Close tag </
+
+            token = x.nextToken();
+            if (name == null) {
+                throw x.syntaxError("Mismatched close tag " + token);
+            }            
+            if (!token.equals(name)) {
+                throw x.syntaxError("Mismatched " + name + " and " + token);
+            }
+            if (x.nextToken() != GT) {
+                throw x.syntaxError("Misshaped close tag");
+            }
+            return true;
+
+        } else if (token instanceof Character) {
+            throw x.syntaxError("Misshaped tag");
+
+// Open tag <
+
+        } else {
+            tagName = (String)token;
+            token = null;
+            jsonobject = new JSONObject();
+            for (;;) {
+                if (token == null) {
+                    token = x.nextToken();
+                }
+
+// attribute = value
+
+                if (token instanceof String) {
+                    string = (String)token;
+                    token = x.nextToken();
+                    if (token == EQ) {
+                        token = x.nextToken();
+                        if (!(token instanceof String)) {
+                            throw x.syntaxError("Missing value");
+                        }
+                        jsonobject.accumulate(string, 
+                                XML.stringToValue((String)token));
+                        token = null;
+                    } else {
+                        jsonobject.accumulate(string, "");
+                    }
+
+// Empty tag <.../>
+
+                } else if (token == SLASH) {
+                    if (x.nextToken() != GT) {
+                        throw x.syntaxError("Misshaped tag");
+                    }
+                    if (jsonobject.length() > 0) {
+                        context.accumulate(tagName, jsonobject);
+                    } else {
+                        context.accumulate(tagName, "");
+                    }
+                    return false;
+
+// Content, between <...> and </...>
+
+                } else if (token == GT) {
+                    for (;;) {
+                        token = x.nextContent();
+                        if (token == null) {
+                            if (tagName != null) {
+                                throw x.syntaxError("Unclosed tag " + tagName);
+                            }
+                            return false;
+                        } else if (token instanceof String) {
+                            string = (String)token;
+                            if (string.length() > 0) {
+                                jsonobject.accumulate("content", 
+                                        XML.stringToValue(string));
+                            }
+
+// Nested element
+
+                        } else if (token == LT) {
+                            if (parse(x, jsonobject, tagName)) {
+                                if (jsonobject.length() == 0) {
+                                    context.accumulate(tagName, "");
+                                } else if (jsonobject.length() == 1 &&
+                                       jsonobject.opt("content") != null) {
+                                    context.accumulate(tagName, 
+                                            jsonobject.opt("content"));
+                                } else {
+                                    context.accumulate(tagName, jsonobject);
+                                }
+                                return false;
+                            }
+                        }
+                    }
+                } else {
+                    throw x.syntaxError("Misshaped tag");
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Try to convert a string into a number, boolean, or null. If the string
+     * can't be converted, return the string. This is much less ambitious than
+     * JSONObject.stringToValue, especially because it does not attempt to
+     * convert plus forms, octal forms, hex forms, or E forms lacking decimal 
+     * points.
+     * @param string A String.
+     * @return A simple JSON value.
+     */
+    public static Object stringToValue(String string) {
+        if ("".equals(string)) {
+            return string;
+        }
+        if ("true".equalsIgnoreCase(string)) {
+            return Boolean.TRUE;
+        }
+        if ("false".equalsIgnoreCase(string)) {
+            return Boolean.FALSE;
+        }
+        if ("null".equalsIgnoreCase(string)) {
+            return JSONObject.NULL;
+        }
+        if ("0".equals(string)) {
+            return new Integer(0);
+        }
+
+// If it might be a number, try converting it. If that doesn't work, 
+// return the string.
+
+        try {
+            char initial = string.charAt(0);
+            boolean negative = false;
+            if (initial == '-') {
+                initial = string.charAt(1);
+                negative = true;
+            }
+            if (initial == '0' && string.charAt(negative ? 2 : 1) == '0') {
+                return string;
+            }
+            if ((initial >= '0' && initial <= '9')) {
+                if (string.indexOf('.') >= 0) {
+                    return Double.valueOf(string);
+                } else if (string.indexOf('e') < 0 && string.indexOf('E') < 0) {
+                    Long myLong = new Long(string);
+                    if (myLong.longValue() == myLong.intValue()) {
+                        return new Integer(myLong.intValue());
+                    } else {
+                        return myLong;
+                    }
+                }
+            }
+        }  catch (Exception ignore) {
+        }
+        return string;
+    }
+
+    
+    /**
+     * Convert a well-formed (but not necessarily valid) XML string into a
+     * JSONObject. Some information may be lost in this transformation
+     * because JSON is a data format and XML is a document format. XML uses
+     * elements, attributes, and content text, while JSON uses unordered
+     * collections of name/value pairs and arrays of values. JSON does not
+     * does not like to distinguish between elements and attributes.
+     * Sequences of similar elements are represented as JSONArrays. Content
+     * text may be placed in a "content" member. Comments, prologs, DTDs, and
+     * <code>&lt;[ [ ]]></code> are ignored.
+     * @param string The source string.
+     * @return A JSONObject containing the structured data from the XML string.
+     * @throws JSONException
+     */
+    public static JSONObject toJSONObject(String string) throws JSONException {
+        JSONObject jo = new JSONObject();
+        XMLTokener x = new XMLTokener(string);
+        while (x.more() && x.skipPast("<")) {
+            parse(x, jo, null);
+        }
+        return jo;
+    }
+
+
+    /**
+     * Convert a JSONObject into a well-formed, element-normal XML string.
+     * @param object A JSONObject.
+     * @return  A string.
+     * @throws  JSONException
+     */
+    public static String toString(Object object) throws JSONException {
+        return toString(object, null);
+    }
+
+
+    /**
+     * Convert a JSONObject into a well-formed, element-normal XML string.
+     * @param object A JSONObject.
+     * @param tagName The optional name of the enclosing tag.
+     * @return A string.
+     * @throws JSONException
+     */
+    public static String toString(Object object, String tagName)
+            throws JSONException {
+        StringBuffer sb = new StringBuffer();
+        int          i;
+        JSONArray    ja;
+        JSONObject   jo;
+        String       key;
+        Iterator     keys;
+        int          length;
+        String       string;
+        Object       value;
+        if (object instanceof JSONObject) {
+
+// Emit <tagName>
+
+            if (tagName != null) {
+                sb.append('<');
+                sb.append(tagName);
+                sb.append('>');
+            }
+
+// Loop thru the keys.
+
+            jo = (JSONObject)object;
+            keys = jo.keys();
+            while (keys.hasNext()) {
+                key = keys.next().toString();
+                value = jo.opt(key);
+                if (value == null) {
+                    value = "";
+                }
+                if (value instanceof String) {
+                    string = (String)value;
+                } else {
+                    string = null;
+                }
+
+// Emit content in body
+
+                if ("content".equals(key)) {
+                    if (value instanceof JSONArray) {
+                        ja = (JSONArray)value;
+                        length = ja.length();
+                        for (i = 0; i < length; i += 1) {
+                            if (i > 0) {
+                                sb.append('\n');
+                            }
+                            sb.append(escape(ja.get(i).toString()));
+                        }
+                    } else {
+                        sb.append(escape(value.toString()));
+                    }
+
+// Emit an array of similar keys
+
+                } else if (value instanceof JSONArray) {
+                    ja = (JSONArray)value;
+                    length = ja.length();
+                    for (i = 0; i < length; i += 1) {
+                        value = ja.get(i);
+                        if (value instanceof JSONArray) {
+                            sb.append('<');
+                            sb.append(key);
+                            sb.append('>');
+                            sb.append(toString(value));
+                            sb.append("</");
+                            sb.append(key);
+                            sb.append('>');
+                        } else {
+                            sb.append(toString(value, key));
+                        }
+                    }
+                } else if ("".equals(value)) {
+                    sb.append('<');
+                    sb.append(key);
+                    sb.append("/>");
+
+// Emit a new tag <k>
+
+                } else {
+                    sb.append(toString(value, key));
+                }
+            }
+            if (tagName != null) {
+
+// Emit the </tagname> close tag
+
+                sb.append("</");
+                sb.append(tagName);
+                sb.append('>');
+            }
+            return sb.toString();
+
+// XML does not have good support for arrays. If an array appears in a place
+// where XML is lacking, synthesize an <array> element.
+
+        } else {
+            if (object.getClass().isArray()) {
+                object = new JSONArray(object);
+            }
+            if (object instanceof JSONArray) {
+                ja = (JSONArray)object;
+                length = ja.length();
+                for (i = 0; i < length; i += 1) {
+                    sb.append(toString(ja.opt(i), tagName == null ? "array" : tagName));
+                }
+                return sb.toString();
+            } else {
+                string = (object == null) ? "null" : escape(object.toString());
+                return (tagName == null) ? "\"" + string + "\"" :
+                    (string.length() == 0) ? "<" + tagName + "/>" :
+                    "<" + tagName + ">" + string + "</" + tagName + ">";
+            }
+        }
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XMLTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XMLTokener.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XMLTokener.java
new file mode 100644
index 0000000..7995af0
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/json/XMLTokener.java
@@ -0,0 +1,360 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.json;
+
+/**
+ * The XMLTokener extends the JSONTokener to provide additional methods
+ * for the parsing of XML texts.
+ * @author JSON.org
+ * @version 2010-12-24
+ */
+public class XMLTokener extends JSONTokener {
+
+
+   /** The table of entity values. It initially contains Character values for
+    * amp, apos, gt, lt, quot.
+    */
+   public static final java.util.HashMap entity;
+
+   static {
+       entity = new java.util.HashMap(8);
+       entity.put("amp",  XML.AMP);
+       entity.put("apos", XML.APOS);
+       entity.put("gt",   XML.GT);
+       entity.put("lt",   XML.LT);
+       entity.put("quot", XML.QUOT);
+   }
+
+    /**
+     * Construct an XMLTokener from a string.
+     * @param s A source string.
+     */
+    public XMLTokener(String s) {
+        super(s);
+    }
+
+    /**
+     * Get the text in the CDATA block.
+     * @return The string up to the <code>]]&gt;</code>.
+     * @throws JSONException If the <code>]]&gt;</code> is not found.
+     */
+    public String nextCDATA() throws JSONException {
+        char         c;
+        int          i;
+        StringBuffer sb = new StringBuffer();
+        for (;;) {
+            c = next();
+            if (end()) {
+                throw syntaxError("Unclosed CDATA");
+            }
+            sb.append(c);
+            i = sb.length() - 3;
+            if (i >= 0 && sb.charAt(i) == ']' &&
+                          sb.charAt(i + 1) == ']' && sb.charAt(i + 2) == '>') {
+                sb.setLength(i);
+                return sb.toString();
+            }
+        }
+    }
+
+
+    /**
+     * Get the next XML outer token, trimming whitespace. There are two kinds
+     * of tokens: the '<' character which begins a markup tag, and the content
+     * text between markup tags.
+     *
+     * @return  A string, or a '<' Character, or null if there is no more
+     * source text.
+     * @throws JSONException
+     */
+    public Object nextContent() throws JSONException {
+        char         c;
+        StringBuffer sb;
+        do {
+            c = next();
+        } while (Character.isWhitespace(c));
+        if (c == 0) {
+            return null;
+        }
+        if (c == '<') {
+            return XML.LT;
+        }
+        sb = new StringBuffer();
+        for (;;) {
+            if (c == '<' || c == 0) {
+                back();
+                return sb.toString().trim();
+            }
+            if (c == '&') {
+                sb.append(nextEntity(c));
+            } else {
+                sb.append(c);
+            }
+            c = next();
+        }
+    }
+
+
+    /**
+     * Return the next entity. These entities are translated to Characters:
+     *     <code>&amp;  &apos;  &gt;  &lt;  &quot;</code>.
+     * @param ampersand An ampersand character.
+     * @return  A Character or an entity String if the entity is not recognized.
+     * @throws JSONException If missing ';' in XML entity.
+     */
+    public Object nextEntity(char ampersand) throws JSONException {
+        StringBuffer sb = new StringBuffer();
+        for (;;) {
+            char c = next();
+            if (Character.isLetterOrDigit(c) || c == '#') {
+                sb.append(Character.toLowerCase(c));
+            } else if (c == ';') {
+                break;
+            } else {
+                throw syntaxError("Missing ';' in XML entity: &" + sb);
+            }
+        }
+        String string = sb.toString();
+        Object object = entity.get(string);
+        return object != null ? object : ampersand + string + ";";
+    }
+
+
+    /**
+     * Returns the next XML meta token. This is used for skipping over <!...>
+     * and <?...?> structures.
+     * @return Syntax characters (<code>< > / = ! ?</code>) are returned as
+     *  Character, and strings and names are returned as Boolean. We don't care
+     *  what the values actually are.
+     * @throws JSONException If a string is not properly closed or if the XML
+     *  is badly structured.
+     */
+    public Object nextMeta() throws JSONException {
+        char c;
+        char q;
+        do {
+            c = next();
+        } while (Character.isWhitespace(c));
+        switch (c) {
+        case 0:
+            throw syntaxError("Misshaped meta tag");
+        case '<':
+            return XML.LT;
+        case '>':
+            return XML.GT;
+        case '/':
+            return XML.SLASH;
+        case '=':
+            return XML.EQ;
+        case '!':
+            return XML.BANG;
+        case '?':
+            return XML.QUEST;
+        case '"':
+        case '\'':
+            q = c;
+            for (;;) {
+                c = next();
+                if (c == 0) {
+                    throw syntaxError("Unterminated string");
+                }
+                if (c == q) {
+                    return Boolean.TRUE;
+                }
+            }
+        default:
+            for (;;) {
+                c = next();
+                if (Character.isWhitespace(c)) {
+                    return Boolean.TRUE;
+                }
+                switch (c) {
+                case 0:
+                case '<':
+                case '>':
+                case '/':
+                case '=':
+                case '!':
+                case '?':
+                case '"':
+                case '\'':
+                    back();
+                    return Boolean.TRUE;
+                }
+            }
+        }
+    }
+
+
+    /**
+     * Get the next XML Token. These tokens are found inside of angle
+     * brackets. It may be one of these characters: <code>/ > = ! ?</code> or it
+     * may be a string wrapped in single quotes or double quotes, or it may be a
+     * name.
+     * @return a String or a Character.
+     * @throws JSONException If the XML is not well formed.
+     */
+    public Object nextToken() throws JSONException {
+        char c;
+        char q;
+        StringBuffer sb;
+        do {
+            c = next();
+        } while (Character.isWhitespace(c));
+        switch (c) {
+        case 0:
+            throw syntaxError("Misshaped element");
+        case '<':
+            throw syntaxError("Misplaced '<'");
+        case '>':
+            return XML.GT;
+        case '/':
+            return XML.SLASH;
+        case '=':
+            return XML.EQ;
+        case '!':
+            return XML.BANG;
+        case '?':
+            return XML.QUEST;
+
+// Quoted string
+
+        case '"':
+        case '\'':
+            q = c;
+            sb = new StringBuffer();
+            for (;;) {
+                c = next();
+                if (c == 0) {
+                    throw syntaxError("Unterminated string");
+                }
+                if (c == q) {
+                    return sb.toString();
+                }
+                if (c == '&') {
+                    sb.append(nextEntity(c));
+                } else {
+                    sb.append(c);
+                }
+            }
+        default:
+
+// Name
+
+            sb = new StringBuffer();
+            for (;;) {
+                sb.append(c);
+                c = next();
+                if (Character.isWhitespace(c)) {
+                    return sb.toString();
+                }
+                switch (c) {
+                case 0:
+                    return sb.toString();
+                case '>':
+                case '/':
+                case '=':
+                case '!':
+                case '?':
+                case '[':
+                case ']':
+                    back();
+                    return sb.toString();
+                case '<':
+                case '"':
+                case '\'':
+                    throw syntaxError("Bad character in a name");
+                }
+            }
+        }
+    }
+    
+    
+    /**
+     * Skip characters until past the requested string.
+     * If it is not found, we are left at the end of the source with a result of false.
+     * @param to A string to skip past.
+     * @throws JSONException
+     */
+    public boolean skipPast(String to) throws JSONException {
+        boolean b;
+        char c;
+        int i;
+        int j;
+        int offset = 0;
+        int length = to.length();
+        char[] circle = new char[length];
+        
+        /*
+         * First fill the circle buffer with as many characters as are in the
+         * to string. If we reach an early end, bail.
+         */
+        
+        for (i = 0; i < length; i += 1) {
+            c = next();
+            if (c == 0) {
+                return false;
+            }
+            circle[i] = c;
+        }
+        /*
+         * We will loop, possibly for all of the remaining characters.
+         */
+        for (;;) {
+            j = offset;
+            b = true;
+            /*
+             * Compare the circle buffer with the to string. 
+             */
+            for (i = 0; i < length; i += 1) {
+                if (circle[j] != to.charAt(i)) {
+                    b = false;
+                    break;
+                }
+                j += 1;
+                if (j >= length) {
+                    j -= length;
+                }
+            }
+            /*
+             * If we exit the loop with b intact, then victory is ours.
+             */
+            if (b) {
+                return true;
+            }
+            /*
+             * Get the next character. If there isn't one, then defeat is ours.
+             */
+            c = next();
+            if (c == 0) {
+                return false;
+            }
+            /*
+             * Shove the character in the circle buffer and advance the 
+             * circle offset. The offset is mod n.
+             */
+            circle[offset] = c;
+            offset += 1;
+            if (offset >= length) {
+                offset -= length;
+            }
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/LogWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/LogWriter.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/LogWriter.java
new file mode 100644
index 0000000..72c9831
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/LogWriter.java
@@ -0,0 +1,265 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.log;
+
+/**
+ * interface LogWriter
+ * 
+ * LogWriter interface for Pulse Logging.
+ * 
+ * @since GemFire 7.0.1
+ * 
+ */
+public interface LogWriter {
+  /**
+   * Returns true if "severe" log messages are enabled. Returns false if
+   * "severe" log messages are disabled.
+   */
+  public boolean severeEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "severe".
+   */
+  public void severe(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "severe".
+   */
+  public void severe(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "severe".
+   */
+  public void severe(Throwable ex);
+
+  /**
+   * Returns true if "error" log messages are enabled. Returns false if "error"
+   * log messages are disabled.
+   */
+  // public boolean errorEnabled();
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "error".
+   */
+  // public void error(String msg, Throwable ex);
+  /**
+   * Writes a message to this writer. The message level is "error".
+   */
+  // public void error(String msg);
+  /**
+   * Writes an exception to this writer. The exception level is "error".
+   */
+  // public void error(Throwable ex);
+  /**
+   * Returns true if "warning" log messages are enabled. Returns false if
+   * "warning" log messages are disabled.
+   */
+  public boolean warningEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "warning".
+   */
+  public void warning(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "warning".
+   */
+  public void warning(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "warning".
+   */
+  public void warning(Throwable ex);
+
+  /**
+   * Returns true if "info" log messages are enabled. Returns false if "info"
+   * log messages are disabled.
+   */
+  public boolean infoEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "information".
+   */
+  public void info(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "information".
+   */
+  public void info(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "information".
+   */
+  public void info(Throwable ex);
+
+  /**
+   * Returns true if "config" log messages are enabled. Returns false if
+   * "config" log messages are disabled.
+   */
+  public boolean configEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "config".
+   */
+  public void config(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "config".
+   */
+  public void config(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "config".
+   */
+  public void config(Throwable ex);
+
+  /**
+   * Returns true if "fine" log messages are enabled. Returns false if "fine"
+   * log messages are disabled.
+   */
+  public boolean fineEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "fine".
+   */
+  public void fine(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "fine".
+   */
+  public void fine(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "fine".
+   */
+  public void fine(Throwable ex);
+
+  /**
+   * Returns true if "finer" log messages are enabled. Returns false if "finer"
+   * log messages are disabled.
+   */
+  public boolean finerEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "finer".
+   */
+  public void finer(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "finer".
+   */
+  public void finer(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "finer".
+   */
+  public void finer(Throwable ex);
+
+  /**
+   * Log a method entry.
+   * <p>
+   * The logging is done using the <code>finer</code> level. The string message
+   * will start with <code>"ENTRY"</code> and include the class and method
+   * names.
+   * 
+   * @param sourceClass
+   *          Name of class that issued the logging request.
+   * @param sourceMethod
+   *          Name of the method that issued the logging request.
+   */
+  public void entering(String sourceClass, String sourceMethod);
+
+  /**
+   * Log a method return.
+   * <p>
+   * The logging is done using the <code>finer</code> level. The string message
+   * will start with <code>"RETURN"</code> and include the class and method
+   * names.
+   * 
+   * @param sourceClass
+   *          Name of class that issued the logging request.
+   * @param sourceMethod
+   *          Name of the method that issued the logging request.
+   */
+  public void exiting(String sourceClass, String sourceMethod);
+
+  /**
+   * Log throwing an exception.
+   * <p>
+   * Use to log that a method is terminating by throwing an exception. The
+   * logging is done using the <code>finer</code> level.
+   * <p>
+   * This is a convenience method that could be done instead by calling
+   * {@link #finer(String, Throwable)}. The string message will start with
+   * <code>"THROW"</code> and include the class and method names.
+   * 
+   * @param sourceClass
+   *          Name of class that issued the logging request.
+   * @param sourceMethod
+   *          Name of the method that issued the logging request.
+   * @param thrown
+   *          The Throwable that is being thrown.
+   */
+  public void throwing(String sourceClass, String sourceMethod, Throwable thrown);
+
+  /**
+   * Returns true if "finest" log messages are enabled. Returns false if
+   * "finest" log messages are disabled.
+   */
+  public boolean finestEnabled();
+
+  /**
+   * Writes both a message and exception to this writer. The message level is
+   * "finest".
+   */
+  public void finest(String msg, Throwable ex);
+
+  /**
+   * Writes a message to this writer. The message level is "finest".
+   */
+  public void finest(String msg);
+
+  /**
+   * Writes an exception to this writer. The exception level is "finest".
+   */
+  public void finest(Throwable ex);
+
+  /**
+   * Returns a 1.4 logging handler that can be used to direct application output
+   * to this GemFire logger using the standard JDK logger APIs. Each time this
+   * method is called it creates a new instance of a Handler so care should be
+   * taken to not call this method too often.
+   */
+  // public Handler getHandler();
+
+  /**
+   * A mechanism for accessing the abstraction layer used for
+   * internationalization.
+   * 
+   * @return LogWriterI18n
+   */
+  // public LogWriterI18n convertToLogWriterI18n();
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/MessageFormatter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/MessageFormatter.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/MessageFormatter.java
new file mode 100644
index 0000000..3828759
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/MessageFormatter.java
@@ -0,0 +1,102 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.log;
+
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.text.DateFormat;
+import java.text.SimpleDateFormat;
+import java.util.Date;
+import java.util.logging.Formatter;
+import java.util.logging.Handler;
+import java.util.logging.LogRecord;
+
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+
+/**
+ * Class MessageFormatter
+ * 
+ * MessageFormatter is the custom formatter class for formatting the log
+ * messages.
+ * 
+ * @since GemFire version 7.0.1
+ */
+public class MessageFormatter extends Formatter {
+
+  public MessageFormatter() {
+    super();
+  }
+
+  @Override
+  public String format(LogRecord record) {
+    DateFormat df = new SimpleDateFormat(Repository.get().getPulseConfig()
+        .getLogDatePattern());
+    StringWriter sw = new StringWriter();
+    PrintWriter pw = new PrintWriter(sw);
+
+    pw.println();
+    pw.print("[");
+    pw.print(record.getLevel().getName());
+    pw.print(" ");
+    pw.print(df.format(new Date(record.getMillis())));
+    String threadName = Thread.currentThread().getName();
+    if (threadName != null) {
+      pw.print(" ");
+      pw.print(threadName);
+    }
+    pw.print(" tid=0x");
+    pw.print(Long.toHexString(Thread.currentThread().getId()));
+    pw.print("] ");
+    pw.print("(msgTID=");
+    pw.print(record.getThreadID());
+
+    pw.print(" msgSN=");
+    pw.print(record.getSequenceNumber());
+
+    pw.print(") ");
+
+    pw.println("[" + PulseConstants.APP_NAME + "]");
+
+    pw.println("[" + record.getLoggerName() + "]");
+
+    pw.println(record.getMessage());
+
+    if (record.getThrown() != null) {
+      record.getThrown().printStackTrace(pw);
+    }
+    pw.close();
+    try {
+      sw.close();
+    } catch (IOException ignore) {
+    }
+    String result = sw.toString();
+    return result;
+  }
+
+  public String getHead(Handler h) {
+    return super.getHead(h);
+  }
+
+  public String getTail(Handler h) {
+    return super.getTail(h);
+  }
+} // End of Class MessageFormatter

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogWriter.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogWriter.java
new file mode 100644
index 0000000..901f2f4
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogWriter.java
@@ -0,0 +1,299 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.log;
+
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.util.logging.FileHandler;
+import java.util.logging.Level;
+import java.util.logging.Logger;
+
+import org.apache.geode.tools.pulse.internal.data.PulseConfig;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+
+/**
+ * Class PulseLogWriter
+ * 
+ * PulseLogWriter is the implementation of LogWriter.
+ * 
+ * @since GemFire 7.0.1
+ * 
+ */
+public class PulseLogWriter implements LogWriter {
+
+  // Log File handle Object
+  private FileHandler fileHandler;
+
+  // Message Formatter Object
+  private static MessageFormatter messageformatter;
+
+  // pulse log writer
+  private static PulseLogWriter pulseLogger = null;
+
+  // Logger Object
+  private Logger logger;
+
+  private PulseLogWriter() {
+    PulseConfig pulseConfig = Repository.get().getPulseConfig();
+    // Create Logger
+    logger = Logger.getLogger(this.getClass().getName());
+
+    // Set minimum log level to level passed
+    logger.setLevel(pulseConfig.getLogLevel());
+
+    try {
+      // Get file handler to log messages into log file.
+      if (fileHandler == null) {
+        fileHandler = new FileHandler(
+            pulseConfig.getLogFileFullName(),
+            pulseConfig.getLogFileSize(),
+            pulseConfig.getLogFileCount(),
+            pulseConfig.getLogAppend());
+
+        // Log Message Formatter
+        messageformatter = new MessageFormatter();
+        fileHandler.setFormatter(messageformatter);
+      }
+
+      // Add File Handler to logger object
+      logger.addHandler(fileHandler);
+    } catch (SecurityException e) {
+      logger.setUseParentHandlers(true);
+      e.printStackTrace();
+    } catch (IOException e) {
+      logger.setUseParentHandlers(true);
+      e.printStackTrace();
+    } catch (Exception e) {
+      e.printStackTrace();
+    }
+  }
+
+  /**
+   * @param jsonErr
+   * @param errorData
+   */
+  public void logJSONError(Exception jsonErr, Object errorData) {
+
+    // print details of thrown exception and data that couldn't be converted to
+    // json
+    if (this.fineEnabled()) {
+
+      // write errors
+      StringWriter swBuffer = new StringWriter();
+      PrintWriter prtWriter = new PrintWriter(swBuffer);
+      jsonErr.printStackTrace(prtWriter);
+      this.fine("JSON Error Details : " + swBuffer.toString() + "\n");
+
+      this.fine("Erroneous Data : "
+          + ((errorData != null) ? errorData.toString()
+              : "Not Available for output") + "\n");
+    }
+  }
+
+  public static synchronized PulseLogWriter getLogger() {
+    if (null == pulseLogger) {
+      pulseLogger = new PulseLogWriter();
+    }
+    return pulseLogger;
+  }
+
+  @Override
+  public boolean severeEnabled() {
+    return logger.isLoggable(Level.SEVERE);
+  }
+
+  @Override
+  public void severe(String msg, Throwable ex) {
+    logger.logp(Level.SEVERE, "", "", msg, ex);
+  }
+
+  @Override
+  public void severe(String msg) {
+    logger.severe(msg);
+  }
+
+  @Override
+  public void severe(Throwable ex) {
+    logger.logp(Level.SEVERE, "", "", "", ex);
+  }
+
+  /*
+  @Override
+  public boolean errorEnabled() {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public void error(String msg, Throwable ex) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void error(String msg) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void error(Throwable ex) {
+    // TODO Auto-generated method stub
+
+  }
+  */
+
+  @Override
+  public boolean warningEnabled() {
+    return logger.isLoggable(Level.WARNING);
+  }
+
+  @Override
+  public void warning(String msg, Throwable ex) {
+    logger.logp(Level.WARNING, "", "", msg, ex);
+  }
+
+  @Override
+  public void warning(String msg) {
+    logger.warning(msg);
+  }
+
+  @Override
+  public void warning(Throwable ex) {
+    logger.logp(Level.WARNING, "", "", "", ex);
+  }
+
+  @Override
+  public boolean infoEnabled() {
+    return logger.isLoggable(Level.INFO);
+  }
+
+  @Override
+  public void info(String msg, Throwable ex) {
+    logger.logp(Level.INFO, "", "", msg, ex);
+  }
+
+  @Override
+  public void info(String msg) {
+    logger.info(msg);
+  }
+
+  @Override
+  public void info(Throwable ex) {
+    logger.logp(Level.WARNING, "", "", "", ex);
+  }
+
+  @Override
+  public boolean configEnabled() {
+    return logger.isLoggable(Level.CONFIG);
+  }
+
+  @Override
+  public void config(String msg, Throwable ex) {
+    logger.logp(Level.CONFIG, "", "", msg, ex);
+  }
+
+  @Override
+  public void config(String msg) {
+    logger.config(msg);
+  }
+
+  @Override
+  public void config(Throwable ex) {
+    logger.logp(Level.CONFIG, "", "", "", ex);
+  }
+
+  @Override
+  public boolean fineEnabled() {
+    return logger.isLoggable(Level.FINE);
+  }
+
+  @Override
+  public void fine(String msg, Throwable ex) {
+    logger.logp(Level.FINE, "", "", msg, ex);
+  }
+
+  @Override
+  public void fine(String msg) {
+    logger.fine(msg);
+  }
+
+  @Override
+  public void fine(Throwable ex) {
+    logger.logp(Level.FINE, "", "", "", ex);
+  }
+
+  @Override
+  public boolean finerEnabled() {
+    return logger.isLoggable(Level.FINER);
+  }
+
+  @Override
+  public void finer(String msg, Throwable ex) {
+    logger.logp(Level.FINER, "", "", msg, ex);
+  }
+
+  @Override
+  public void finer(String msg) {
+    logger.finer(msg);
+  }
+
+  @Override
+  public void finer(Throwable ex) {
+    logger.logp(Level.FINER, "", "", "", ex);
+  }
+
+  @Override
+  public void entering(String sourceClass, String sourceMethod) {
+    logger.entering(sourceClass, sourceMethod);
+  }
+
+  @Override
+  public void exiting(String sourceClass, String sourceMethod) {
+    logger.exiting(sourceClass, sourceMethod);
+  }
+
+  @Override
+  public void throwing(String sourceClass, String sourceMethod, Throwable thrown) {
+    logger.throwing(sourceClass, sourceMethod, thrown);
+  }
+
+  @Override
+  public boolean finestEnabled() {
+    return logger.isLoggable(Level.FINEST);
+  }
+
+  @Override
+  public void finest(String msg, Throwable ex) {
+    logger.logp(Level.FINEST, "", "", msg, ex);
+  }
+
+  @Override
+  public void finest(String msg) {
+    logger.finest(msg);
+  }
+
+  @Override
+  public void finest(Throwable ex) {
+    logger.logp(Level.FINEST, "", "", "", ex);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogger.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogger.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogger.java
new file mode 100644
index 0000000..b4f08c1
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/log/PulseLogger.java
@@ -0,0 +1,142 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.log;
+
+import java.io.IOException;
+import java.text.DateFormat;
+import java.text.SimpleDateFormat;
+import java.util.Date;
+import java.util.logging.FileHandler;
+import java.util.logging.Formatter;
+import java.util.logging.Handler;
+import java.util.logging.Level;
+import java.util.logging.LogRecord;
+import java.util.logging.Logger;
+
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+
+/**
+ * Class PulseLogger
+ * 
+ * PulseLogger is the custom logger class for Pulse Web Application. It logs
+ * messages to the file in custom format.
+ * 
+ * @since GemFire version 7.0.Beta
+ */
+public class PulseLogger {
+
+  // Pulse Application Log File
+  private static final String LOG_FILE_NAME = PulseConstants.PULSE_LOG_FILE_LOCATION
+      + "/" + PulseConstants.PULSE_LOG_FILE;
+
+  // Date pattern to be used in log messages
+  public static final String LOG_MESSAGE_DATE_PATTERN = "dd/MM/yyyy hh:mm:ss.SSS";
+
+  // The log file size is set to 1MB.
+  public static final int FILE_SIZE = 1024 * 1024;
+
+  // The log file count set to 1 files.
+  public static final int FILE_COUNT = 5;
+
+  // Append logs is set to true.
+  public static final boolean FLAG_APPEND = true;
+
+  // Log File handle Object
+  private static FileHandler fileHandler;
+
+  // Message Formatter Object
+  private static MessageFormatter messageformatter;
+
+  // Logger Object
+  private static Logger logger;
+
+  public static Logger getLogger(String name) {
+    // Create Logger
+    logger = Logger.getLogger(name);
+
+    // Set minimum log level to inform
+    logger.setLevel(Level.INFO);
+
+    // Get file handler to log messages into log file.
+    try {
+      // fileHandler = new FileHandler(LOG_FILE_NAME, FILE_SIZE, FILE_COUNT,
+      // FLAG_APPEND);
+      fileHandler = new FileHandler(LOG_FILE_NAME, FLAG_APPEND);
+
+      // Log Message Formatter
+      messageformatter = new MessageFormatter();
+
+      fileHandler.setFormatter(messageformatter);
+
+      // Add File Handler to logger object
+      logger.addHandler(fileHandler);
+
+    } catch (SecurityException e) {
+      e.printStackTrace();
+    } catch (IOException e) {
+      e.printStackTrace();
+    } catch (Exception e) {
+      e.printStackTrace();
+    }
+
+    return logger;
+  }
+
+  /**
+   * Class MessageFormatter
+   * 
+   * MessageFormatter is the custom formatter class for formatting the log
+   * messages.
+   * 
+   * @since GemFire version 7.0.Beta 2012-09-23
+   */
+  private static class MessageFormatter extends Formatter {
+
+    public MessageFormatter() {
+      super();
+    }
+
+    @Override
+    public String format(LogRecord record) {
+      // Set DateFormat
+      DateFormat df = new SimpleDateFormat(PulseLogger.LOG_MESSAGE_DATE_PATTERN);
+      StringBuilder builder = new StringBuilder(1000);
+
+      // Format Log Message
+      builder.append(df.format(new Date(record.getMillis()))).append(" - ");
+      builder.append("[ " + PulseConstants.APP_NAME + " ] - ");
+      builder.append("[").append(record.getSourceClassName()).append(".");
+      builder.append(record.getSourceMethodName()).append("] - ");
+      builder.append("[").append(record.getLevel()).append("] - ");
+      builder.append(formatMessage(record));
+      builder.append(System.getProperty("line.separator"));
+
+      return builder.toString();
+    }
+
+    public String getHead(Handler h) {
+      return super.getHead(h);
+    }
+
+    public String getTail(Handler h) {
+      return super.getTail(h);
+    }
+  } // End of Class MessageFormatter
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthentication.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthentication.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthentication.java
new file mode 100644
index 0000000..425f5a5
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthentication.java
@@ -0,0 +1,91 @@
+/*
+ * 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 org.apache.geode.tools.pulse.internal.security;
+
+import java.util.ArrayList;
+import java.util.Collection;
+import javax.management.MBeanServerConnection;
+import javax.management.ObjectName;
+import javax.management.remote.JMXConnector;
+
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+
+import org.springframework.security.authentication.UsernamePasswordAuthenticationToken;
+import org.springframework.security.core.GrantedAuthority;
+import org.springframework.security.core.SpringSecurityCoreVersion;
+import org.springframework.security.core.authority.SimpleGrantedAuthority;
+
+/**
+ * Spring security authentication object for GemFire
+ * <p>
+ * To use GemFire Integrated Security Model set Spring Application Profile to pulse.authentication.gemfire
+ * <p>
+ * 1. Authentication :
+ * 1.a GemFire profile creates JMX connection with given credentials at the login time.
+ * 1.b Successful connect is considered as Successful Authentication for Pulse WebApp
+ * <p>
+ * <p>
+ * 2. Authorization :
+ * 2.a Using newly created authenticated connection AccessControlMXBean is called to get authentication
+ * levels. See @See {@link #populateAuthorities(JMXConnector)}. This sets Spring Security Authorities
+ * 2.b DataBrowser end-points are required to be authorized against Spring Granted Authority
+ * @since GemFire version 9.0
+ */
+public class GemFireAuthentication extends UsernamePasswordAuthenticationToken {
+
+  private final static PulseLogWriter logger = PulseLogWriter.getLogger();
+
+  private JMXConnector jmxc = null;
+
+  public GemFireAuthentication(Object principal, Object credentials, Collection<GrantedAuthority> list, JMXConnector jmxc) {
+    super(principal, credentials, list);
+    this.jmxc = jmxc;
+  }
+
+  private static final long serialVersionUID = SpringSecurityCoreVersion.SERIAL_VERSION_UID;
+
+  public static ArrayList<GrantedAuthority> populateAuthorities(JMXConnector jmxc) {
+    ObjectName name;
+    ArrayList<GrantedAuthority> authorities = new ArrayList<>();
+    try {
+      name = new ObjectName(PulseConstants.OBJECT_NAME_ACCESSCONTROL_MBEAN);
+      MBeanServerConnection mbeanServer = jmxc.getMBeanServerConnection();
+
+      for (String role : PulseConstants.PULSE_ROLES) {
+        Object[] params = role.split(":");
+        String[] signature = new String[] { String.class.getCanonicalName(), String.class.getCanonicalName() };
+        boolean result = (Boolean) mbeanServer.invoke(name, "authorize", params, signature);
+        if (result) {
+          authorities.add(new SimpleGrantedAuthority(role));
+        }
+      }
+    }
+    catch (Exception e) {
+      throw new RuntimeException(e.getMessage(), e);
+    }
+
+    return authorities;
+
+  }
+
+  public JMXConnector getJmxc() {
+    return jmxc;
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthenticationProvider.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthenticationProvider.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthenticationProvider.java
new file mode 100644
index 0000000..f4575cc
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/GemFireAuthenticationProvider.java
@@ -0,0 +1,80 @@
+/*
+ * 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 org.apache.geode.tools.pulse.internal.security;
+
+import java.util.Collection;
+import javax.management.remote.JMXConnector;
+
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+
+import org.springframework.security.authentication.AuthenticationProvider;
+import org.springframework.security.authentication.AuthenticationServiceException;
+import org.springframework.security.authentication.BadCredentialsException;
+import org.springframework.security.authentication.UsernamePasswordAuthenticationToken;
+import org.springframework.security.core.Authentication;
+import org.springframework.security.core.AuthenticationException;
+import org.springframework.security.core.GrantedAuthority;
+
+/**
+ * Spring security AuthenticationProvider for GemFire. It connects to gemfire manager using given credentials.
+ * Successful connect is treated as successful authentication and web user is authenticated
+ * @since GemFire version 9.0
+ */
+public class GemFireAuthenticationProvider implements AuthenticationProvider {
+
+  private final static PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+
+  public GemFireAuthenticationProvider() {
+    System.out.println("here");
+  }
+
+  @Override
+  public Authentication authenticate(Authentication authentication) throws AuthenticationException {
+
+    if (authentication instanceof GemFireAuthentication) {
+      GemFireAuthentication gemAuth = (GemFireAuthentication) authentication;
+      LOGGER.fine("GemAuthentication is connected? = " + gemAuth.getJmxc());
+      if (gemAuth.getJmxc() != null && gemAuth.isAuthenticated()) return gemAuth;
+    }
+
+    String name = authentication.getName();
+    String password = authentication.getCredentials().toString();
+
+    try {
+      LOGGER.fine("Connecting to GemFire with user=" + name);
+      JMXConnector jmxc = Repository.get().getCluster(name, password).connectToGemFire();
+      if (jmxc != null) {
+        Collection<GrantedAuthority> list = GemFireAuthentication.populateAuthorities(jmxc);
+        GemFireAuthentication auth = new GemFireAuthentication(authentication.getPrincipal(),
+            authentication.getCredentials(), list, jmxc);
+        LOGGER.fine("For user " + name + " authList=" + list);
+        return auth;
+      } else {
+        throw new AuthenticationServiceException("JMX Connection unavailable");
+      }
+    } catch (Exception e) {
+      throw new BadCredentialsException("Error connecting to GemFire JMX Server", e);
+    }
+  }
+
+  @Override
+  public boolean supports(Class<?> authentication) {
+    return authentication.equals(UsernamePasswordAuthenticationToken.class);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/LogoutHandler.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/LogoutHandler.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/LogoutHandler.java
new file mode 100644
index 0000000..451e19a
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/security/LogoutHandler.java
@@ -0,0 +1,55 @@
+/*
+ * 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 org.apache.geode.tools.pulse.internal.security;
+
+import java.io.IOException;
+import javax.servlet.ServletException;
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.apache.geode.tools.pulse.internal.log.PulseLogWriter;
+
+import org.springframework.security.core.Authentication;
+import org.springframework.security.web.authentication.logout.LogoutSuccessHandler;
+import org.springframework.security.web.authentication.logout.SimpleUrlLogoutSuccessHandler;
+
+/**
+ * Handler is used to close jmx connection maintained at user-level
+ *
+ */
+public class LogoutHandler extends SimpleUrlLogoutSuccessHandler implements LogoutSuccessHandler {
+
+  public LogoutHandler(String defaultTargetURL) {
+    this.setDefaultTargetUrl(defaultTargetURL);
+  }
+
+  public void onLogoutSuccess(HttpServletRequest request, HttpServletResponse response, Authentication authentication)
+      throws IOException, ServletException {
+    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
+    LOGGER.fine("Invoked #LogoutHandler ...");
+    if (Repository.get().isUseGemFireCredentials()) {
+      GemFireAuthentication gemauthentication = (GemFireAuthentication) authentication;
+      if(gemauthentication!=null) {
+        gemauthentication.getJmxc().close();
+        LOGGER.info("#LogoutHandler : Closing GemFireAuthentication JMX Connection...");
+      }
+    }
+    super.onLogoutSuccess(request, response, authentication);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDetailsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDetailsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDetailsService.java
new file mode 100644
index 0000000..0216cb0
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDetailsService.java
@@ -0,0 +1,104 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+import java.text.DecimalFormat;
+
+/**
+ * Class ClusterDetailsService
+ * 
+ * This service class has implementation for providing cluster's basic
+ * statistical data.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterDetails")
+@Scope("singleton")
+public class ClusterDetailsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    String userName = request.getUserPrincipal().getName();
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    Cluster.Alert[] alertsList = cluster.getAlertsList();
+    int severeAlertCount = 0;
+    int errorAlertCount = 0;
+    int warningAlertCount = 0;
+    int infoAlertCount = 0;
+
+    for (Cluster.Alert alertObj : alertsList) {
+      if (alertObj.getSeverity() == Cluster.Alert.SEVERE) {
+        severeAlertCount++;
+      } else if (alertObj.getSeverity() == Cluster.Alert.ERROR) {
+        errorAlertCount++;
+      } else if (alertObj.getSeverity() == Cluster.Alert.WARNING) {
+        warningAlertCount++;
+      } else {
+        infoAlertCount++;
+      }
+    }
+    // getting basic details of Cluster
+    responseJSON.put("clusterName", cluster.getServerName());
+    responseJSON.put("severeAlertCount", severeAlertCount);
+    responseJSON.put("errorAlertCount", errorAlertCount);
+    responseJSON.put("warningAlertCount", warningAlertCount);
+    responseJSON.put("infoAlertCount", infoAlertCount);
+
+    responseJSON.put("totalMembers", cluster.getMemberCount());
+    responseJSON.put("servers", cluster.getServerCount());
+    responseJSON.put("clients", cluster.getClientConnectionCount());
+    responseJSON.put("locators", cluster.getLocatorCount());
+    responseJSON.put("totalRegions", cluster.getTotalRegionCount());
+    Long heapSize = cluster.getTotalHeapSize();
+
+    DecimalFormat df2 = new DecimalFormat(
+        PulseConstants.DECIMAL_FORMAT_PATTERN);
+    Double heapS = heapSize.doubleValue() / 1024;
+    responseJSON.put("totalHeap", Double.valueOf(df2.format(heapS)));
+    responseJSON.put("functions", cluster.getRunningFunctionCount());
+    responseJSON.put("uniqueCQs", cluster.getRegisteredCQCount());
+    responseJSON.put("subscriptions", cluster.getSubscriptionCount());
+    responseJSON.put("txnCommitted", cluster.getTxnCommittedCount());
+    responseJSON.put("txnRollback", cluster.getTxnRollbackCount());
+    responseJSON.put("userName", userName);
+
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDiskThroughputService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDiskThroughputService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDiskThroughputService.java
new file mode 100644
index 0000000..b50b551
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterDiskThroughputService.java
@@ -0,0 +1,71 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class ClusterDiskThroughput This class contains implementations for getting
+ * cluster's current disk throughput details and its trend over time
+ * 
+ * @since GemFire version 7.0.Beta
+ */
+
+@Component
+@Service("ClusterDiskThroughput")
+@Scope("singleton")
+public class ClusterDiskThroughputService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    // cluster's Throughout Writes trend added to json response object
+    // CircularFifoBuffer throughoutWritesTrend =
+    // cluster.getThroughoutWritesTrend();
+    double currentThroughputWrites = cluster.getDiskWritesRate();
+    double currentThroughputReads = cluster.getDiskReadsRate();
+
+    responseJSON.put("currentThroughputReads", currentThroughputReads);
+    responseJSON.put("throughputReads",
+        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_THROUGHPUT_READS)));
+
+    responseJSON.put("currentThroughputWrites", currentThroughputWrites);
+    responseJSON.put("throughputWrites",
+        mapper.valueToTree( cluster.getStatisticTrend(Cluster.CLUSTER_STAT_THROUGHPUT_WRITES)));
+
+    // Send json response
+    return responseJSON;
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterGCPausesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterGCPausesService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterGCPausesService.java
new file mode 100644
index 0000000..164e7e3
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterGCPausesService.java
@@ -0,0 +1,69 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class ClusterGCPausesService
+ * 
+ * This class contains implementations of getting Cluster's GC Pauses (JVM
+ * Pauses) Details and its trend over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterJVMPauses")
+@Scope("singleton")
+public class ClusterGCPausesService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+    // cluster's GC Pauses trend added to json response object
+
+    ArrayNode pauses = mapper.createArrayNode();
+    for (Object obj : cluster.getStatisticTrend(Cluster.CLUSTER_STAT_GARBAGE_COLLECTION)) {
+      if (obj instanceof Number) {
+        pauses.add(((Number) obj).longValue());
+      }
+    }
+    responseJSON.put("currentGCPauses", cluster.getGarbageCollectionCount());
+    responseJSON.put("gCPausesTrend", pauses);
+    // Send json response
+    return responseJSON;
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterKeyStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterKeyStatisticsService.java b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterKeyStatisticsService.java
new file mode 100644
index 0000000..9c35a3c
--- /dev/null
+++ b/geode-pulse/src/main/java/org/apache/geode/tools/pulse/internal/service/ClusterKeyStatisticsService.java
@@ -0,0 +1,69 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.internal.service;
+
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ObjectNode;
+import org.apache.geode.tools.pulse.internal.data.Cluster;
+import org.apache.geode.tools.pulse.internal.data.Repository;
+import org.springframework.context.annotation.Scope;
+import org.springframework.stereotype.Component;
+import org.springframework.stereotype.Service;
+
+import javax.servlet.http.HttpServletRequest;
+
+/**
+ * Class ClusterKeyStatisticsService
+ * 
+ * This class contains implementations of getting Cluster's current Reads,
+ * Writes and queries details and their trends over the time.
+ * 
+ * @since GemFire version 7.5
+ */
+
+@Component
+@Service("ClusterKeyStatistics")
+@Scope("singleton")
+public class ClusterKeyStatisticsService implements PulseService {
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  public ObjectNode execute(final HttpServletRequest request) throws Exception {
+
+    // get cluster object
+    Cluster cluster = Repository.get().getCluster();
+
+    // json object to be sent as response
+    ObjectNode responseJSON = mapper.createObjectNode();
+
+    responseJSON.put("writePerSecTrend",
+        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_WRITES_PER_SECOND)));
+
+    responseJSON.put("readPerSecTrend",
+        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_READ_PER_SECOND)));
+
+    responseJSON.put("queriesPerSecTrend",
+        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_QUERIES_PER_SECOND)));
+
+    // Send json response
+    return responseJSON;
+
+  }
+}


[52/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/BaseServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/BaseServiceTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/BaseServiceTest.java
new file mode 100644
index 0000000..d66d1c8
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/BaseServiceTest.java
@@ -0,0 +1,254 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests.junit;
+
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import org.apache.geode.test.junit.categories.UITest;
+import com.google.gson.JsonObject;
+import org.apache.geode.tools.pulse.internal.json.JSONObject;
+import org.apache.http.HttpEntity;
+import org.apache.http.client.methods.CloseableHttpResponse;
+import org.apache.http.client.methods.HttpUriRequest;
+import org.apache.http.client.methods.RequestBuilder;
+import org.apache.http.cookie.Cookie;
+import org.apache.http.impl.client.BasicCookieStore;
+import org.apache.http.impl.client.CloseableHttpClient;
+import org.apache.http.impl.client.HttpClients;
+import org.apache.http.util.EntityUtils;
+import org.junit.After;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+
+import java.io.BufferedReader;
+import java.io.InputStream;
+import java.io.InputStreamReader;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.net.URI;
+import java.util.List;
+import java.util.Properties;
+
+
+/**
+ * Base class to be extended by other JUnit test classes. This class defines and automatically invokes test for testing server login-logout so no need to add
+ * this test in each sub-class. It also provides doLogin(), doLogout() and print error functionality as protected
+ * functions.
+ *
+ * <b>Sub-classes should ensure that they call doLogin() in @BeforeClass and doLogout() in @AfterClass otherwise tests will fail.</b>
+ *
+ *
+ */
+@Ignore
+@Category(UITest.class)
+public abstract class BaseServiceTest {
+
+  protected static Properties propsForJUnit = new Properties();
+  protected static String strHost = null;
+  protected static String strPort = null;
+  protected static String LOGIN_URL;
+  protected static String LOGOUT_URL;
+  protected static String IS_AUTHENTICATED_USER_URL;
+  protected static String PULSE_UPDATE_URL;
+
+  protected static final String PULSE_UPDATE_PARAM = "pulseData";
+  protected static final String PULSE_UPDATE_1_VALUE = "{'ClusterSelectedRegion':{'regionFullPath':'/GlobalVilage_2/GlobalVilage_9'}}";
+  protected static final String PULSE_UPDATE_2_VALUE = "{'ClusterSelectedRegion':{'regionFullPath':'/Rubbish'}}";
+
+  protected static final String PULSE_UPDATE_3_VALUE = "{'ClusterSelectedRegionsMember':{'regionFullPath':'/GlobalVilage_2/GlobalVilage_9'}}";
+  protected static final String PULSE_UPDATE_4_VALUE = "{'ClusterSelectedRegionsMember':{'regionFullPath':'/Rubbish'}}";
+
+  protected static final String PULSE_UPDATE_5_VALUE = "{'MemberGatewayHub':{'memberName':'pnq-visitor1'}}";
+  protected static final String PULSE_UPDATE_6_VALUE = "{'MemberGatewayHub':{'memberName':'pnq-visitor2'}}";
+  protected static CloseableHttpClient httpclient = null;
+
+  private final ObjectMapper mapper = new ObjectMapper();
+
+  @BeforeClass
+  public static void beforeClass() throws Exception {
+    InputStream stream = BaseServiceTest.class.getClassLoader().getResourceAsStream("pulse.properties");
+
+    try {
+      propsForJUnit.load(stream);
+    } catch (Exception exProps) {
+      System.out.println("BaseServiceTest :: Error loading properties from pulse.properties in classpath");
+    }
+    strHost = propsForJUnit.getProperty("pulse.host");
+    strPort = propsForJUnit.getProperty("pulse.port");
+    System.out.println(
+        "BaseServiceTest :: Loaded properties from classpath. Checking properties for hostname. Hostname found = " + strHost);
+    LOGIN_URL = "http://" + strHost + ":" + strPort + "/pulse/j_spring_security_check";
+    LOGOUT_URL = "http://" + strHost + ":" + strPort + "/pulse/clusterLogout";
+    IS_AUTHENTICATED_USER_URL = "http://" + strHost + ":" + strPort + "/pulse/authenticateUser";
+    PULSE_UPDATE_URL = "http://" + strHost + ":" + strPort + "/pulse/pulseUpdate";
+
+  }
+  /**
+  *
+  * @throws java.lang.Exception
+  */
+  @Before
+  public void setUp() throws Exception {
+    doLogout();
+    System.out.println("BaseServiceTest :: Setup done");
+  }
+
+  /**
+  *
+  * @throws java.lang.Exception
+  */
+  @After
+  public void tearDown() throws Exception {
+    doLogin();
+    System.out.println("BaseServiceTest :: Teardown done");
+  }
+
+  /**
+   * Login to pulse server and setup httpClient for tests
+   * To be called from setupBeforeClass in each test class
+   */
+  protected static void doLogin() throws Exception {
+    System.out.println("BaseServiceTest ::  Executing doLogin with user : admin, password : admin.");
+
+    CloseableHttpResponse loginResponse = null;
+    try{
+      BasicCookieStore cookieStore = new BasicCookieStore();
+      httpclient = HttpClients.custom().setDefaultCookieStore(cookieStore).build();
+      HttpUriRequest login = RequestBuilder.post().setUri(new URI(LOGIN_URL))
+        .addParameter("j_username", "admin").addParameter("j_password", "admin")
+        .build();
+      loginResponse = httpclient.execute(login);
+      try {
+           HttpEntity entity = loginResponse.getEntity();
+           EntityUtils.consume(entity);
+           System.out.println("BaseServiceTest :: HTTP request status : " + loginResponse.getStatusLine());
+
+           List<Cookie> cookies = cookieStore.getCookies();
+           if (cookies.isEmpty()) {
+           } else {
+               for (int i = 0; i < cookies.size(); i++) {
+               }
+           }
+      } finally {
+         if(loginResponse != null)
+           loginResponse.close();
+      }
+    } catch(Exception failed) {
+      logException(failed);
+      throw failed;
+    }
+
+    System.out.println("BaseServiceTest ::  Executed doLogin");
+  }
+
+  /**
+   * Logout to pulse server and close httpClient
+   * To be called from setupAfterClass in each test class
+   */
+  protected static void doLogout() throws Exception {
+    System.out.println("BaseServiceTest ::  Executing doLogout with user : admin, password : admin.");
+    if(httpclient != null){
+      CloseableHttpResponse logoutResponse = null;
+      try{
+        HttpUriRequest logout = RequestBuilder.get().setUri(new URI(LOGOUT_URL))
+            .build();
+        logoutResponse = httpclient.execute(logout);
+        try {
+             HttpEntity entity = logoutResponse.getEntity();
+             EntityUtils.consume(entity);
+        } finally {
+           if(logoutResponse != null)
+             logoutResponse.close();
+           httpclient.close();
+           httpclient = null;
+        }
+      } catch(Exception failed) {
+        logException(failed);
+        throw failed;
+      }
+      System.out.println("BaseServiceTest ::  Executed doLogout");
+    } else{
+      System.out.println("BaseServiceTest ::  User NOT logged-in");
+    }
+  }
+
+  /**
+   * Print exception string to system.out
+   *
+   * @param failed
+   */
+  protected static void logException(Exception failed){
+    StringWriter sw = new StringWriter();
+    PrintWriter pw = new PrintWriter(sw);
+    failed.printStackTrace(pw);
+    System.out.println("BaseServiceTest :: Logging exception details : " + sw.getBuffer().toString());
+  }
+
+  /**
+  *
+  * Tests that service returns json object
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
+  */
+  @Test
+  public void testServerLoginLogout() {
+      System.out.println("BaseServiceTest ::  ------TESTCASE BEGIN : SERVER LOGIN-LOGOUT------");
+      try{
+          doLogin();
+
+          HttpUriRequest pulseupdate = RequestBuilder.get()
+            .setUri(new URI(IS_AUTHENTICATED_USER_URL))
+            .build();
+          CloseableHttpResponse response = httpclient.execute(pulseupdate);
+          try {
+            HttpEntity entity = response.getEntity();
+
+            System.out.println("BaseServiceTest :: HTTP request status : " + response.getStatusLine());
+
+            BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+            StringWriter sw = new StringWriter();
+            PrintWriter pw = new PrintWriter(sw);
+            String sz = null;
+            while((sz = respReader.readLine()) != null){
+              pw.print(sz);
+            }
+            String jsonResp = sw.getBuffer().toString();
+            System.out.println("BaseServiceTest :: JSON response returned : " + jsonResp);
+            EntityUtils.consume(entity);
+
+            JsonNode jsonObj = mapper.readTree(jsonResp);
+            boolean isUserLoggedIn = jsonObj.get("isUserLoggedIn").booleanValue();
+            Assert.assertNotNull("BaseServiceTest :: Server returned null response in 'isUserLoggedIn'", isUserLoggedIn);
+            Assert.assertTrue("BaseServiceTest :: User login failed for this username, password", (isUserLoggedIn == true));
+          } finally {
+            response.close();
+          }
+
+          doLogout();
+      } catch(Exception failed) {
+          logException(failed);
+          Assert.fail("Exception ! ");
+      }
+      System.out.println("BaseServiceTest ::  ------TESTCASE END : SERVER LOGIN-LOGOUT------");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
new file mode 100644
index 0000000..bfee425
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionServiceTest.java
@@ -0,0 +1,340 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests.junit;
+
+import java.io.BufferedReader;
+import java.io.InputStreamReader;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.net.URI;
+
+import org.apache.http.HttpEntity;
+import org.apache.http.client.methods.CloseableHttpResponse;
+import org.apache.http.client.methods.HttpUriRequest;
+import org.apache.http.client.methods.RequestBuilder;
+import org.apache.http.util.EntityUtils;
+import org.junit.*;
+
+import org.apache.geode.tools.pulse.internal.json.JSONArray;
+import org.apache.geode.tools.pulse.internal.json.JSONObject;
+
+/**
+ * JUnit Tests for ClusterSelectedRegionService in the back-end server for region detail page
+ *
+ *
+ */
+@Ignore
+public class ClusterSelectedRegionServiceTest extends BaseServiceTest {
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @BeforeClass
+  public static void setUpBeforeClass() throws Exception {
+    doLogin();
+    System.out.println("\n\nClusterSelectedRegionServiceTest :: Setup done");
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @AfterClass
+  public static void tearDownAfterClass() throws Exception {
+    doLogout();
+    System.out.println("ClusterSelectedRegionServiceTest :: Teardown done");
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @Override
+  @Before
+  public void setUp() throws Exception {
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @Override
+  @After
+  public void tearDown() throws Exception {
+  }
+
+  /**
+   * Tests that service returns json object
+   *
+   */
+  @Test
+  public void testResponseNotNull() {
+    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR CLUSTER REGIONS------");
+    if(httpclient != null){
+        try{
+            HttpUriRequest pulseupdate = RequestBuilder.post()
+                .setUri(new URI(PULSE_UPDATE_URL))
+                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
+                .build();
+            CloseableHttpResponse response = httpclient.execute(pulseupdate);
+            try {
+              HttpEntity entity = response.getEntity();
+
+              System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
+              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+              StringWriter sw = new StringWriter();
+              PrintWriter pw = new PrintWriter(sw);
+              String sz = null;
+              while((sz = respReader.readLine()) != null){
+                pw.print(sz);
+              }
+              String jsonResp = sw.getBuffer().toString();
+              System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
+              EntityUtils.consume(entity);
+
+              JSONObject jsonObj = new JSONObject(jsonResp);
+              Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion", jsonObj.getJSONObject("ClusterSelectedRegion"));
+            } finally {
+              response.close();
+            }
+        } catch(Exception failed) {
+          logException(failed);
+          Assert.fail("Exception ! ");
+        }
+    } else {
+      Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
+    }
+    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR CLUSTER REGIONS------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same logged in user
+  *
+  */
+  @Test
+  public void testResponseUsername() {
+    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGIONS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
+               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion", clusterSelectedRegionObj);
+               String szUser = clusterSelectedRegionObj.getString("userName");
+               Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned wrong user name. Expected was admin. Server returned = " + szUser, szUser, "admin");
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGIONS------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseRegionPathMatches() {
+    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : REGION PATH IN RESPONSE CHECK FOR CLUSTER REGIONS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
+               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion",clusterSelectedRegionObj);
+               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
+               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for selectedRegion",jsonObjRegion);
+               Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'path' of region",jsonObjRegion.has("path"));
+               String szPath = jsonObjRegion.getString("path");
+               Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned wrong region path. Expected region path = /GlobalVilage_2/GlobalVilage_9 , actual region path = " + szPath, szPath, "/GlobalVilage_2/GlobalVilage_9");
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : REGION PATH IN RESPONSE CHECK FOR CLUSTER REGIONS------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseNonExistentRegion() {
+    System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : NON-EXISTENT REGION CHECK FOR CLUSTER REGIONS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_2_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
+               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for ClusterSelectedRegion",clusterSelectedRegionObj);
+               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
+               Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response for selectedRegion",jsonObjRegion);
+               Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return error on non-existent region",jsonObjRegion.has("errorOnRegion"));
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : NON-EXISTENT REGION CHECK FOR CLUSTER REGIONS------\n");
+  }
+
+  /**
+  *
+  * Tests that service returns json object
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.ClusterSelectedRegionService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseMemerberCount() {
+   System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE BEGIN : MISMATCHED MEMBERCOUNT FOR REGION CHECK FOR CLUSTER REGIONS------");
+   if(httpclient != null){
+       try{
+           HttpUriRequest pulseupdate = RequestBuilder.post()
+               .setUri(new URI(PULSE_UPDATE_URL))
+               .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_1_VALUE)
+               .build();
+           CloseableHttpResponse response = httpclient.execute(pulseupdate);
+           try {
+             HttpEntity entity = response.getEntity();
+
+             System.out.println("ClusterSelectedRegionServiceTest :: HTTP request status : " + response.getStatusLine());
+
+             BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+             StringWriter sw = new StringWriter();
+             PrintWriter pw = new PrintWriter(sw);
+             String sz = null;
+             while((sz = respReader.readLine()) != null){
+               pw.print(sz);
+             }
+             String jsonResp = sw.getBuffer().toString();
+             System.out.println("ClusterSelectedRegionServiceTest :: JSON response returned : " + jsonResp);
+             EntityUtils.consume(entity);
+
+             JSONObject jsonObj = new JSONObject(jsonResp);
+             JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegion");
+             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null ClusterSelectedRegion",clusterSelectedRegionObj);
+             JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegion");
+             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null for selectedRegion",jsonObjRegion);
+             Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'memberCount' of region",jsonObjRegion.has("memberCount"));
+             int memberCount = jsonObjRegion.getInt("memberCount");
+             Assert.assertTrue("ClusterSelectedRegionServiceTest :: Server did not return 'members' of region",jsonObjRegion.has("members"));
+             JSONArray arrMembers = jsonObjRegion.getJSONArray("members");
+             Assert.assertNotNull("ClusterSelectedRegionServiceTest :: Server returned null response in selectedRegion",arrMembers);
+             int members = arrMembers.length();
+             Assert.assertEquals("ClusterSelectedRegionServiceTest :: Server returned mismatched member count and region members", members, memberCount);
+           } finally {
+             response.close();
+           }
+       } catch(Exception failed) {
+         logException(failed);
+         Assert.fail("Exception ! ");
+       }
+   } else {
+     Assert.fail("ClusterSelectedRegionServiceTest :: No Http connection was established.");
+   }
+   System.out.println("ClusterSelectedRegionServiceTest ::  ------TESTCASE END : MISMATCHED MEMBERCOUNT FOR REGION CHECK FOR CLUSTER REGIONS------\n");
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
new file mode 100644
index 0000000..f27f08a
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/ClusterSelectedRegionsMemberServiceTest.java
@@ -0,0 +1,354 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests.junit;
+
+import java.io.BufferedReader;
+import java.io.InputStreamReader;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.net.URI;
+import java.util.Iterator;
+
+import org.apache.http.HttpEntity;
+import org.apache.http.client.methods.CloseableHttpResponse;
+import org.apache.http.client.methods.HttpUriRequest;
+import org.apache.http.client.methods.RequestBuilder;
+import org.apache.http.util.EntityUtils;
+import org.junit.*;
+
+import org.apache.geode.tools.pulse.internal.json.JSONObject;
+
+/**
+ * JUnit Tests for ClusterSelectedRegionsMemberService in the back-end server for region detail page
+ *
+ *
+ */
+@Ignore
+public class ClusterSelectedRegionsMemberServiceTest  extends BaseServiceTest {
+
+  /**
+   * @throws java.lang.Exception
+   *
+   */
+  @BeforeClass
+  public static void setUpBeforeClass() throws Exception {
+    doLogin();
+    System.out.println("\n\nClusterSelectedRegionsMemberServiceTest :: Setup done");
+  }
+
+  /**
+   * @throws java.lang.Exception
+   *
+   */
+  @AfterClass
+  public static void tearDownAfterClass() throws Exception {
+    doLogout();
+    System.out.println("ClusterSelectedRegionsMemberServiceTest :: Teardown done");
+  }
+
+  /**
+   * @throws java.lang.Exception
+   */
+  @Override
+  @Before
+  public void setUp() throws Exception {
+    System.out.println("running setup -- ClusterSelectedRegionsMemberServiceTest");
+  }
+
+  /**
+   * @throws java.lang.Exception
+   */
+  @Override
+  @After
+  public void tearDown() throws Exception {
+    System.out.println("running teardown -- ClusterSelectedRegionsMemberServiceTest");
+  }
+
+  /**
+   * Tests that service returns json object
+   *
+   */
+  @Test
+  public void testResponseNotNull() {
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+    if(httpclient != null){
+        try{
+            HttpUriRequest pulseupdate = RequestBuilder.post()
+                .setUri(new URI(PULSE_UPDATE_URL))
+                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
+                .build();
+            CloseableHttpResponse response = httpclient.execute(pulseupdate);
+            try {
+              HttpEntity entity = response.getEntity();
+
+              System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
+
+              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+              StringWriter sw = new StringWriter();
+              PrintWriter pw = new PrintWriter(sw);
+              String sz = null;
+              while((sz = respReader.readLine()) != null){
+                pw.print(sz);
+              }
+              String jsonResp = sw.getBuffer().toString();
+              System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
+              EntityUtils.consume(entity);
+
+              JSONObject jsonObj = new JSONObject(jsonResp);
+              Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember", jsonObj.getJSONObject("ClusterSelectedRegionsMember"));
+            } finally {
+              response.close();
+            }
+        } catch(Exception failed) {
+          logException(failed);
+          Assert.fail("Exception ! ");
+        }
+    } else {
+      Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
+    }
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+  }
+
+  /**
+  *
+  * Tests that response is for same logged in user
+  *
+  */
+  @Test
+  public void testResponseUsername() {
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember", clusterSelectedRegionObj);
+               Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'userName' in request",clusterSelectedRegionObj.has("userName"));
+               String szUser = clusterSelectedRegionObj.getString("userName");
+               Assert.assertEquals("ClusterSelectedRegionsMemberServiceTest :: Server returned wrong user name. Expected was admin. Server returned = " + szUser, szUser, "admin");
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NULL USERNAME IN RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  *
+  */
+  @Test
+  public void testResponseRegionOnMemberInfoMatches() {
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : MEMBER INFO RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
+               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for selectedRegionsMembers",jsonObjRegion);
+               Iterator<String> itrMemberNames = jsonObjRegion.keys();
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null region on member info", itrMemberNames);
+               while(itrMemberNames.hasNext()){
+                 String szMemberName = itrMemberNames.next();
+                 Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null member name", szMemberName);
+                 Assert.assertTrue("Server did not return member details",jsonObjRegion.has(szMemberName));
+                 JSONObject jsonMemberObj = jsonObjRegion.getJSONObject(szMemberName);
+
+                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'regionFullPath' of region on member",jsonMemberObj.has("regionFullPath"));
+                 String szPath = jsonMemberObj.getString("regionFullPath");
+                 Assert.assertEquals("ClusterSelectedRegionsMemberServiceTest :: Server returned wrong region path for region on member", szPath, "/GlobalVilage_2/GlobalVilage_9");
+               }
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : MEMBER INFO RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  *
+  */
+  @Test
+  public void testResponseNonExistentRegion() {
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : NON-EXISTENT REGION CHECK FOR CLUSTER REGION MEMBERS------");
+     if(httpclient != null){
+         try{
+           System.out.println("Test for non-existent region : /Rubbish");
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_4_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
+               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null for selectedRegionsMembers",jsonObjRegion);
+               Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return error on non-existent region",jsonObjRegion.has("errorOnRegion"));
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : NON-EXISTENT REGION CHECK FOR CLUSTER REGION MEMBERS------");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  *
+  */
+  @Test
+  public void testResponseRegionOnMemberAccessor() {
+    System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE BEGIN : ACCESSOR RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_3_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("ClusterSelectedRegionsMemberServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject clusterSelectedRegionObj = jsonObj.getJSONObject("ClusterSelectedRegionsMember");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for ClusterSelectedRegionsMember",clusterSelectedRegionObj);
+               JSONObject jsonObjRegion = clusterSelectedRegionObj.getJSONObject("selectedRegionsMembers");
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null response for selectedRegionsMembers",jsonObjRegion);
+               Iterator<String> itrMemberNames = jsonObjRegion.keys();
+               Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null region on member info", itrMemberNames);
+               while(itrMemberNames.hasNext()){
+                 String szMemberName = itrMemberNames.next();
+                 Assert.assertNotNull("ClusterSelectedRegionsMemberServiceTest :: Server returned null member name", szMemberName);
+                 Assert.assertTrue("Server did not return member details",jsonObjRegion.has(szMemberName));
+                 JSONObject jsonMemberObj = jsonObjRegion.getJSONObject(szMemberName);
+
+                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server did not return 'accessor' of region on member",jsonMemberObj.has("accessor"));
+                 String szAccessor = jsonMemberObj.getString("accessor");
+                 Assert.assertTrue("ClusterSelectedRegionsMemberServiceTest :: Server returned non-boolean value for accessor attribute", ((szAccessor.equalsIgnoreCase("True"))
+                         || (szAccessor.equalsIgnoreCase("False"))) );
+               }
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("ClusterSelectedRegionsMemberServiceTest :: No Http connection was established.");
+     }
+     System.out.println("ClusterSelectedRegionsMemberServiceTest ::  ------TESTCASE END : ACCESSOR RESPONSE CHECK FOR CLUSTER REGION MEMBERS------");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
new file mode 100644
index 0000000..be774b5
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/junit/MemberGatewayHubServiceTest.java
@@ -0,0 +1,412 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests.junit;
+
+import java.io.BufferedReader;
+import java.io.InputStreamReader;
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.net.URI;
+
+import org.apache.http.HttpEntity;
+import org.apache.http.client.methods.CloseableHttpResponse;
+import org.apache.http.client.methods.HttpUriRequest;
+import org.apache.http.client.methods.RequestBuilder;
+import org.apache.http.util.EntityUtils;
+import org.junit.*;
+
+import org.apache.geode.tools.pulse.internal.json.JSONArray;
+import org.apache.geode.tools.pulse.internal.json.JSONObject;
+
+/**
+ * JUnit Tests for MemberGatewayHubService in the back-end server for region detail page
+ *
+ *
+ */
+@Ignore
+public class MemberGatewayHubServiceTest extends BaseServiceTest {
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @BeforeClass
+  public static void setUpBeforeClass() throws Exception {
+    doLogin();
+    System.out.println("\n\nMemberGatewayHubServiceTest :: Setup done");
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @AfterClass
+  public static void tearDownAfterClass() throws Exception {
+    doLogout();
+    System.out.println("MemberGatewayHubServiceTest :: Teardown done");
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @Override
+  @Before
+  public void setUp() throws Exception {
+  }
+
+  /**
+   *
+   * @throws java.lang.Exception
+   */
+  @Override
+  @After
+  public void tearDown() throws Exception {
+  }
+
+  /**
+   * Tests that service returns json object
+   *
+   */
+  @Test
+  public void testResponseNotNull() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : NULL RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE --------");
+    if(httpclient != null){
+        try{
+            HttpUriRequest pulseupdate = RequestBuilder.post()
+                .setUri(new URI(PULSE_UPDATE_URL))
+                .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
+                .build();
+            CloseableHttpResponse response = httpclient.execute(pulseupdate);
+            try {
+              HttpEntity entity = response.getEntity();
+
+              System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+              BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+              StringWriter sw = new StringWriter();
+              PrintWriter pw = new PrintWriter(sw);
+              String sz = null;
+              while((sz = respReader.readLine()) != null){
+                pw.print(sz);
+              }
+              String jsonResp = sw.getBuffer().toString();
+              System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+              EntityUtils.consume(entity);
+
+              JSONObject jsonObj = new JSONObject(jsonResp);
+              Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", jsonObj.getJSONObject("MemberGatewayHub"));
+            } finally {
+              response.close();
+            }
+        } catch(Exception failed) {
+          logException(failed);
+          Assert.fail("Exception ! ");
+        }
+    } else {
+      Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+    }
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : NULL RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+ /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseIsGatewaySender() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : IS GATEWAY SENDER IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
+               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
+               Assert.assertEquals("MemberGatewayHubServiceTest :: Server returned wrong value for 'isGatewaySender'. Expected 'isGatewaySender' = true, actual 'isGatewaySender' = " + boolIsGatewaySender, boolIsGatewaySender, true);
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+     }
+     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : IS GATEWAY SENDER IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseGatewaySenderCount() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : GATEWAY SENDER COUNT IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
+               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'gatewaySenders' for member", memberGatewayHubObj.has("gatewaySenders"));
+               JSONArray arrGatewaySender = memberGatewayHubObj.getJSONArray("gatewaySenders");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'gatewaySenders'", arrGatewaySender);
+               Assert.assertTrue( "MemberGatewayHubServiceTest :: Server returned mis-matched values for 'isGatewaySender' and gateway senders array count", ((boolIsGatewaySender && (arrGatewaySender.length() > 0)) || ((! boolIsGatewaySender) && (arrGatewaySender.length() == 0))) );
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+     }
+     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : GATEWAY SENDER COUNT IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseGatewaySenderProperties() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : GATEWAY SENDER PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'isGatewaySender' for member", memberGatewayHubObj.has("isGatewaySender"));
+               Boolean boolIsGatewaySender = memberGatewayHubObj.getBoolean("isGatewaySender");
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'gatewaySenders' for member", memberGatewayHubObj.has("gatewaySenders"));
+               JSONArray arrGatewaySender = memberGatewayHubObj.getJSONArray("gatewaySenders");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'gatewaySenders'", arrGatewaySender);
+               Assert.assertTrue( "MemberGatewayHubServiceTest :: Server returned mis-matched values for 'isGatewaySender' and gateway senders array count", ((boolIsGatewaySender && (arrGatewaySender.length() > 0)) || ((! boolIsGatewaySender) && (arrGatewaySender.length() == 0))) );
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'remoteDSId' for member", ((JSONObject)arrGatewaySender.get(0)).has("remoteDSId"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'eventsExceedingAlertThreshold' for member", ((JSONObject)arrGatewaySender.get(0)).has("eventsExceedingAlertThreshold"));
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+     }
+     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : GATEWAY SENDER PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseAsyncEventQueueProperties() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : ASYNC EVENT QUEUE PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_5_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventQueues' for member", memberGatewayHubObj.has("asyncEventQueues"));
+               JSONArray arrAsyncEventQueues = memberGatewayHubObj.getJSONArray("asyncEventQueues");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'asyncEventQueues'", arrAsyncEventQueues);
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'id' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("id"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'primary' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("primary"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'senderType' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("senderType"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchSize' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchSize"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchTimeInterval' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchTimeInterval"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'batchConflationEnabled' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("batchConflationEnabled"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventListener' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("asyncEventListener"));
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'queueSize' for member", ((JSONObject)arrAsyncEventQueues.get(0)).has("queueSize"));
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+     }
+     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : ASYNC EVENT QUEUE PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+  /**
+  *
+  * Tests that response is for same region
+  *
+  * Test method for {@link org.apache.geode.tools.pulse.internal.service.MemberGatewayHubService#execute(javax.servlet.http.HttpServletRequest)}.
+  *
+  */
+  @Test
+  public void testResponseNoAsyncEventQueues() {
+    System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE BEGIN : NO ASYNC EVENT QUEUES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE------");
+     if(httpclient != null){
+         try{
+             HttpUriRequest pulseupdate = RequestBuilder.post()
+                 .setUri(new URI(PULSE_UPDATE_URL))
+                 .addParameter(PULSE_UPDATE_PARAM, PULSE_UPDATE_6_VALUE)
+                 .build();
+             CloseableHttpResponse response = httpclient.execute(pulseupdate);
+             try {
+               HttpEntity entity = response.getEntity();
+
+               System.out.println("MemberGatewayHubServiceTest :: HTTP request status : " + response.getStatusLine());
+
+               BufferedReader respReader = new BufferedReader(new InputStreamReader(entity.getContent()));
+               StringWriter sw = new StringWriter();
+               PrintWriter pw = new PrintWriter(sw);
+               String sz = null;
+               while((sz = respReader.readLine()) != null){
+                 pw.print(sz);
+               }
+               String jsonResp = sw.getBuffer().toString();
+               System.out.println("MemberGatewayHubServiceTest :: JSON response returned : " + jsonResp);
+               EntityUtils.consume(entity);
+
+               JSONObject jsonObj = new JSONObject(jsonResp);
+               JSONObject memberGatewayHubObj = jsonObj.getJSONObject("MemberGatewayHub");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for MemberGatewayHub", memberGatewayHubObj);
+
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server did not return 'asyncEventQueues' for member", memberGatewayHubObj.has("asyncEventQueues"));
+               JSONArray arrAsyncEventQueues = memberGatewayHubObj.getJSONArray("asyncEventQueues");
+               Assert.assertNotNull("MemberGatewayHubServiceTest :: Server returned null response for 'asyncEventQueues'", arrAsyncEventQueues);
+               Assert.assertTrue("MemberGatewayHubServiceTest :: Server returned non-empty array for member 'pnq-visitor2' which has no event queues", (arrAsyncEventQueues.length() == 0));
+             } finally {
+               response.close();
+             }
+         } catch(Exception failed) {
+           logException(failed);
+           Assert.fail("Exception ! ");
+         }
+     } else {
+       Assert.fail("MemberGatewayHubServiceTest :: No Http connection was established.");
+     }
+     System.out.println("MemberGatewayHubServiceTest ::  ------TESTCASE END : NO ASYNC EVENT QUEUES PROPERTIES IN RESPONSE CHECK FOR MEMBER GATEWAY HUB SERVICE ------\n");
+  }
+
+
+}


[59/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAbstractTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAbstractTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAbstractTest.java
deleted file mode 100644
index b2ce160..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAbstractTest.java
+++ /dev/null
@@ -1,1047 +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 com.vmware.geode.tools.pulse.tests;
-
-import static org.junit.Assert.*;
-
-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;
-
-import com.jayway.awaitility.Awaitility;
-import org.junit.AfterClass;
-import org.junit.Before;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.openqa.selenium.By;
-import org.openqa.selenium.JavascriptExecutor;
-import org.openqa.selenium.WebDriver;
-import org.openqa.selenium.WebElement;
-import org.openqa.selenium.firefox.FirefoxDriver;
-import org.openqa.selenium.interactions.Actions;
-import org.openqa.selenium.support.ui.ExpectedCondition;
-import org.openqa.selenium.support.ui.ExpectedConditions;
-import org.openqa.selenium.support.ui.WebDriverWait;
-
-import org.apache.geode.management.internal.JettyHelper;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-
-@SuppressWarnings("deprecated")
-public abstract class PulseAbstractTest extends PulseBaseTest {
-
-  private static String jmxPropertiesFile;
-  private static String path;
-
-  private static org.eclipse.jetty.server.Server jetty = null;
-  private static Server server = null;
-  private static String pulseURL = null;
-  public static WebDriver driver;
-
-  /* Constants for executing Data Browser queries */
-  public static final String QUERY_TYPE_ONE = "query1";
-  public static final String QUERY_TYPE_TWO = "query2";
-  public static final String QUERY_TYPE_THREE = "query3";
-  public static final String QUERY_TYPE_FOUR = "query4";
-  public static final String QUERY_TYPE_FIVE = "query5";
-  public static final String QUERY_TYPE_SIX = "query6";
-  public static final String QUERY_TYPE_SEVENE = "query7";
-
-  private static final String DATA_VIEW_LABEL = "Data View";
-  private static final String CLUSTER_VIEW_MEMBERS_ID = "clusterTotalMembersText";
-  private static final String CLUSTER_VIEW_SERVERS_ID = "clusterServersText";
-  private static final String CLUSTER_VIEW_LOCATORS_ID = "clusterLocatorsText";
-  private static final String CLUSTER_VIEW_REGIONS_ID = "clusterTotalRegionsText";
-  private static final String CLUSTER_CLIENTS_ID = "clusterClientsText";
-  private static final String CLUSTER_FUNCTIONS_ID = "clusterFunctions";
-  private static final String CLUSTER_UNIQUECQS_ID = "clusterUniqueCQs";
-  private static final String CLUSTER_SUBSCRIPTION_ID = "clusterSubscriptionsText";
-  private static final String CLUSTER_MEMORY_USAGE_ID = "currentMemoryUsage";
-  private static final String CLUSTER_THROUGHPUT_WRITES_ID = "currentThroughputWrites";
-  private static final String CLUSTER_GCPAUSES_ID = "currentGCPauses";
-  private static final String CLUSTER_WRITEPERSEC_ID = "writePerSec";
-  private static final String CLUSTER_READPERSEC_ID = "readPerSec";
-  private static final String CLUSTER_QUERIESPERSEC_ID = "queriesPerSec";
-  private static final String CLUSTER_PROCEDURE_ID = "clusterTxnCommittedText";
-  private static final String CLUSTER_TXNCOMMITTED_ID = "clusterTxnCommittedText";
-  private static final String CLUSTER_TXNROLLBACK_ID = "clusterTxnRollbackText";
-  private static final String MEMBER_VIEW_MEMBERNAME_ID = "memberName";
-  private static final String MEMBER_VIEW_REGION_ID = "memberRegionsCount";
-  private static final String MEMBER_VIEW_THREAD_ID = "threads";
-  private static final String MEMBER_VIEW_SOCKETS_ID = "sockets";
-  private static final String MEMBER_VIEW_LOADAVG_ID = "loadAverage";
-  private static final String MEMBER_VIEW_LISTENINGPORT_ID = "receiverListeningPort";
-  private static final String MEMBER_VIEW_LINKTHROUGHPUT_ID = "receiverLinkThroughput";
-  private static final String MEMBER_VIEW_AVGBATCHLATENCY_ID = "receiverAvgBatchLatency";
-  private static final String MEMBER_VIEW_HEAPUSAGE_ID = "memberHeapUsageAvg";
-  private static final String MEMBER_VIEW_JVMPAUSES_ID = "memberGcPausesAvg";
-  private static final String MEMBER_VIEW_CPUUSAGE_ID = "memberCPUUsageValue";
-  private static final String MEMBER_VIEW_READPERSEC_ID = "memberGetsPerSecValue";
-  private static final String MEMBER_VIEW_WRITEPERSEC_ID = "memberPutsPerSecValue";
-  private static final String MEMBER_VIEW_OFFHEAPFREESIZE_ID = "offHeapFreeSize";
-  private static final String MEMBER_VIEW_OFFHEAPUSEDSIZE_ID = "offHeapUsedSize";
-  private static final String MEMBER_VIEW_CLIENTS_ID = "clusterClientsText";
-
-  private static final String REGION_NAME_LABEL = "regionName";
-  private static final String REGION_PATH_LABEL = "regionPath";
-  private static final String REGION_TYPE_LABEL = "regionType";
-  private static final String DATA_VIEW_WRITEPERSEC = "regionWrites";
-  private static final String DATA_VIEW_READPERSEC = "regionReads";
-  private static final String DATA_VIEW_EMPTYNODES = "regionEmptyNodes";
-  private static final String DATA_VIEW_ENTRYCOUNT = "regionEntryCount";
-  private static final String REGION_PERSISTENCE_LABEL = "regionPersistence";
-  private static final String DATA_VIEW_USEDMEMORY = "memoryUsed";
-  private static final String DATA_VIEW_TOTALMEMORY = "totalMemory";
-
-  private static final String DATA_BROWSER_LABEL = "Data Browser";
-  private static final String DATA_BROWSER_REGIONName1 = "treeDemo_1_span";
-  private static final String DATA_BROWSER_REGIONName2 = "treeDemo_2_span";
-  private static final String DATA_BROWSER_REGIONName3 = "treeDemo_3_span";
-  private static final String DATA_BROWSER_REGION1_CHECKBOX = "treeDemo_1_check";
-  private static final String DATA_BROWSER_REGION2_CHECKBOX = "treeDemo_2_check";
-  private static final String DATA_BROWSER_REGION3_CHECKBOX = "treeDemo_3_check";
-  private static final String DATA_BROWSER_COLOCATED_REGION = "Colocated Regions";
-  private static final String DATA_BROWSER_COLOCATED_REGION_NAME1 = "treeDemo_1_span";
-  private static final String DATA_BROWSER_COLOCATED_REGION_NAME2 = "treeDemo_2_span";
-  private static final String DATA_BROWSER_COLOCATED_REGION_NAME3 = "treeDemo_3_span";
-
-  private static final String QUERY_STATISTICS_LABEL = "Query Statistics";
-  private static final String CLUSTER_VIEW_LABEL = "Cluster View";
-  private static final String CLUSTER_VIEW_GRID_ID = "default_treemap_button";
-  private static final String SERVER_GROUP_GRID_ID = "servergroups_treemap_button";
-  private static final String REDUNDANCY_GRID_ID = "redundancyzones_treemap_button";
-  private static final String MEMBER_DROPDOWN_ID = "Members";
-  private static final String DATA_DROPDOWN_ID = "Data";
-
-  private static final DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
-
-  public static void setUpServer(String username, String password, String jsonAuthFile) throws Exception {
-    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-
-    jmxPropertiesFile = classLoader.getResource("test.properties").getPath();
-    path = getPulseWarPath();
-    server = Server.createServer(9999, jmxPropertiesFile, jsonAuthFile);
-
-    String host = "localhost";
-    int port = 8080;
-    String context = "/pulse";
-
-    jetty = JettyHelper.initJetty(host, port, false, false, null, null, null);
-    JettyHelper.addWebApplication(jetty, context, getPulseWarPath());
-    jetty.start();
-
-    pulseURL = "http://" + host + ":" + port + context;
-
-    Awaitility.await().until(()->jetty.isStarted());
-
-    driver = new FirefoxDriver();
-    driver.manage().window().maximize();
-    driver.manage().timeouts().implicitlyWait(5, TimeUnit.SECONDS);
-    driver.get(pulseURL);
-    WebElement userNameElement = driver.findElement(By.id("user_name"));
-    WebElement passwordElement = driver.findElement(By.id("user_password"));
-    userNameElement.sendKeys(username);
-    passwordElement.sendKeys(password);
-    passwordElement.submit();
-
-    Thread.sleep(3000);
-    WebElement userNameOnPulsePage = (new WebDriverWait(driver, 10))
-      .until(new ExpectedCondition<WebElement>() {
-        @Override
-        public WebElement apply(WebDriver d) {
-          return d.findElement(By.id("userName"));
-        }
-      });
-    assertNotNull(userNameOnPulsePage);
-    driver.navigate().refresh();
-    Thread.sleep(7000);
-  }
-
-  @AfterClass
-  public static void tearDownAfterClass() throws Exception {
-    driver.close();
-    jetty.stop();
-  }
-
-  @Before
-  public void setup() throws Exception {
-    // Make sure we go to the home page first
-    searchByXPathAndClick(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-  }
-
-  public static String getPulseWarPath() throws Exception {
-    String warPath = null;
-    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
-    InputStream inputStream = classLoader.getResourceAsStream("GemFireVersion.properties");
-    Properties properties = new Properties();
-    properties.load(inputStream);
-    String version = properties.getProperty("Product-Version");
-    warPath = "geode-pulse-" + version + ".war";
-    String propFilePath = classLoader.getResource("GemFireVersion.properties").getPath();
-    warPath = propFilePath.substring(0, propFilePath.indexOf("generated-resources")) + "libs/" + warPath;
-    return warPath;
-  }
-
-  protected void searchByLinkAndClick(String linkText) {
-    WebElement element = By.linkText(linkText).findElement(driver);
-    assertNotNull(element);
-    element.click();
-  }
-
-  protected void searchByIdAndClick(String id) {
-    WebElement element = driver.findElement(By.id(id));
-    assertNotNull(element);
-    element.click();
-  }
-
-  protected void searchByClassAndClick(String Class) {
-    WebElement element = driver.findElement(By.className(Class));
-    assertNotNull(element);
-    element.click();
-  }
-
-  protected void searchByXPathAndClick(String xpath) {
-    WebElement element = driver.findElement(By.xpath(xpath));
-    assertNotNull(element);
-    element.click();
-  }
-
-  protected void waitForElementByClassName(final String className, int seconds) {
-    WebElement linkTextOnPulsePage1 = (new WebDriverWait(driver, seconds))
-      .until(new ExpectedCondition<WebElement>() {
-        @Override
-        public WebElement apply(WebDriver d) {
-          return d.findElement(By.className(className));
-        }
-      });
-    assertNotNull(linkTextOnPulsePage1);
-  }
-
-  protected void waitForElementById(final String id, int seconds) {
-    WebElement element = (new WebDriverWait(driver, 10))
-      .until(new ExpectedCondition<WebElement>() {
-        @Override
-        public WebElement apply(WebDriver d) {
-          return d.findElement(By.id(id));
-        }
-      });
-    assertNotNull(element);
-  }
-
-  protected void scrollbarVerticalDownScroll() {
-    JavascriptExecutor js = (JavascriptExecutor) driver;
-    js.executeScript("javascript:window.scrollBy(250,700)");
-    WebElement pickerScroll = driver.findElement(By.className("jspDrag"));
-    WebElement pickerScrollCorner = driver.findElement(By
-      .className("jspCorner"));
-    Actions builder = new Actions(driver);
-    Actions movePicker = builder.dragAndDrop(pickerScroll, pickerScrollCorner);
-    // pickerscroll is the web element
-    movePicker.perform();
-  }
-
-  protected void scrollbarHorizontalRightScroll() {
-    JavascriptExecutor js = (JavascriptExecutor) driver;
-    js.executeScript("javascript:window.scrollBy(250,700)");
-    WebElement pickerScroll = driver
-      .findElement(By
-        .xpath("//div[@id='gview_queryStatisticsList']/div[3]/div/div[3]/div[2]/div"));
-    WebElement pickerScrollCorner = driver.findElement(By
-      .className("jspCorner"));
-    Actions builder = new Actions(driver);
-    Actions movePicker = builder.dragAndDrop(pickerScroll, pickerScrollCorner);
-    // pickerscroll is the web element
-    movePicker.perform();
-  }
-
-
-  @Test
-  public void testClusterLocatorCount() throws IOException {
-    String clusterLocators = driver
-      .findElement(By.id(CLUSTER_VIEW_LOCATORS_ID)).getText();
-
-    String totallocators = JMXProperties.getInstance().getProperty("server.S1.locatorCount");
-    assertEquals(totallocators, clusterLocators);
-  }
-
-  @Test
-  public void testClusterRegionCount() {
-    String clusterRegions = driver.findElement(By.id(CLUSTER_VIEW_REGIONS_ID))
-      .getText();
-    String totalregions = JMXProperties.getInstance().getProperty(
-      "server.S1.totalRegionCount");
-    assertEquals(totalregions, clusterRegions);
-  }
-
-  @Test
-  public void testClusterMemberCount() {
-    String clusterMembers = driver.findElement(By.id(CLUSTER_VIEW_MEMBERS_ID)).getText();
-    String totalMembers = JMXProperties.getInstance().getProperty("server.S1.memberCount");
-    assertEquals(totalMembers, clusterMembers);
-  }
-
-  @Test
-  public void testClusterNumClient() {
-    String clusterClients = driver.findElement(By.id(CLUSTER_CLIENTS_ID))
-      .getText();
-    String totalclients = JMXProperties.getInstance().getProperty(
-      "server.S1.numClients");
-    assertEquals(totalclients, clusterClients);
-  }
-
-  @Test
-  public void testClusterNumRunningFunction() {
-    String clusterFunctions = driver.findElement(By.id(CLUSTER_FUNCTIONS_ID))
-      .getText();
-    String totalfunctions = JMXProperties.getInstance().getProperty(
-      "server.S1.numRunningFunctions");
-    assertEquals(totalfunctions, clusterFunctions);
-  }
-
-  @Test
-  public void testClusterRegisteredCQCount() {
-    String clusterUniqueCQs = driver.findElement(By.id(CLUSTER_UNIQUECQS_ID))
-      .getText();
-    String totaluniqueCQs = JMXProperties.getInstance().getProperty(
-      "server.S1.registeredCQCount");
-    assertEquals(totaluniqueCQs, clusterUniqueCQs);
-  }
-
-  @Test
-  public void testClusterNumSubscriptions() {
-    String clusterSubscriptions = driver.findElement(
-      By.id(CLUSTER_SUBSCRIPTION_ID)).getText();
-    String totalSubscriptions = JMXProperties.getInstance().getProperty(
-      "server.S1.numSubscriptions");
-    assertEquals(totalSubscriptions, clusterSubscriptions);
-  }
-
-  @Test
-  public void testClusterJVMPausesWidget() {
-    String clusterJVMPauses = driver.findElement(By.id(CLUSTER_GCPAUSES_ID))
-      .getText();
-    String totalgcpauses = JMXProperties.getInstance().getProperty(
-      "server.S1.jvmPauses");
-    assertEquals(totalgcpauses, clusterJVMPauses);
-  }
-
-  @Test
-  public void testClusterAverageWritesWidget() {
-    String clusterWritePerSec = driver.findElement(
-      By.id(CLUSTER_WRITEPERSEC_ID)).getText();
-    String totalwritepersec = JMXProperties.getInstance().getProperty(
-      "server.S1.averageWrites");
-    assertEquals(totalwritepersec, clusterWritePerSec);
-  }
-
-  @Test
-  public void testClusterAverageReadsWidget() {
-    String clusterReadPerSec = driver.findElement(By.id(CLUSTER_READPERSEC_ID))
-      .getText();
-    String totalreadpersec = JMXProperties.getInstance().getProperty(
-      "server.S1.averageReads");
-    assertEquals(totalreadpersec, clusterReadPerSec);
-  }
-
-  @Test
-  public void testClusterQuerRequestRateWidget() {
-    String clusterQueriesPerSec = driver.findElement(
-      By.id(CLUSTER_QUERIESPERSEC_ID)).getText();
-    String totalqueriespersec = JMXProperties.getInstance().getProperty(
-      "server.S1.queryRequestRate");
-    assertEquals(totalqueriespersec, clusterQueriesPerSec);
-  }
-
-  @Test
-  public void testClusterGridViewMemberID() throws InterruptedException {
-    searchByIdAndClick("default_grid_button");
-    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr")); //gives me 11 rows
-
-    for (int memberCount = 1; memberCount < elements.size(); memberCount++) {
-      String memberId = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberCount + 1) + "]/td")).getText();
-      String propertMemeberId = JMXProperties.getInstance().getProperty("member.M" + memberCount + ".id");
-      assertEquals(memberId, propertMemeberId);
-    }
-  }
-
-  @Test
-  public void testClusterGridViewMemberName() {
-    searchByIdAndClick("default_grid_button");
-    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
-    for (int memberNameCount = 1; memberNameCount < elements.size(); memberNameCount++) {
-      String gridMemberName = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberNameCount + 1) + "]/td[2]")).getText();
-      String memberName = JMXProperties.getInstance().getProperty("member.M" + memberNameCount + ".member");
-      assertEquals(gridMemberName, memberName);
-    }
-  }
-
-
-  @Test
-  public void testClusterGridViewMemberHost() {
-    searchByIdAndClick("default_grid_button");
-    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
-    for (int memberHostCount = 1; memberHostCount < elements.size(); memberHostCount++) {
-      String MemberHost = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberHostCount + 1) + "]/td[3]")).getText();
-      String gridMemberHost = JMXProperties.getInstance().getProperty("member.M" + memberHostCount + ".host");
-      assertEquals(gridMemberHost, MemberHost);
-    }
-  }
-
-  @Test
-  public void testClusterGridViewHeapUsage() {
-    searchByIdAndClick("default_grid_button");
-    for (int i = 1; i <= 3; i++) {
-      Float HeapUsage = Float.parseFloat(driver
-        .findElement(
-          By.xpath("//table[@id='memberList']/tbody/tr[" + (i + 1) + "]/td[5]")).getText());
-      Float gridHeapUsagestring = Float.parseFloat(JMXProperties.getInstance()
-        .getProperty("member.M" + i + ".UsedMemory"));
-      assertEquals(gridHeapUsagestring, HeapUsage);
-    }
-  }
-
-  @Test
-  public void testClusterGridViewCPUUsage() throws Exception {
-    searchByIdAndClick("default_grid_button");
-    for (int i = 1; i <= 3; i++) {
-      String CPUUsage = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (i + 1) + "]/td[6]"))
-        .getText();
-      String gridCPUUsage = JMXProperties.getInstance().getProperty("member.M" + i + ".cpuUsage");
-      gridCPUUsage = gridCPUUsage.trim();
-      assertEquals(gridCPUUsage, CPUUsage);
-    }
-  }
-
-
-  public void testRgraphWidget() throws InterruptedException {
-    searchByIdAndClick("default_rgraph_button");
-    searchByIdAndClick("h1");
-    searchByIdAndClick("M1");
-  }
-
-  @Test  // region count in properties file is 2 and UI is 1
-  public void testMemberTotalRegionCount() throws InterruptedException {
-    testRgraphWidget();
-    String RegionCount = driver.findElement(By.id(MEMBER_VIEW_REGION_ID)).getText();
-    String memberRegionCount = JMXProperties.getInstance().getProperty("member.M1.totalRegionCount");
-    assertEquals(memberRegionCount, RegionCount);
-  }
-
-  @Test
-  public void testMemberNumThread() throws InterruptedException {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    String ThreadCount = driver.findElement(By.id(MEMBER_VIEW_THREAD_ID)).getText();
-    String memberThreadCount = JMXProperties.getInstance().getProperty("member.M1.numThreads");
-    assertEquals(memberThreadCount, ThreadCount);
-  }
-
-  @Test
-  public void testMemberTotalFileDescriptorOpen() throws InterruptedException {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    String SocketCount = driver.findElement(By.id(MEMBER_VIEW_SOCKETS_ID))
-      .getText();
-    String memberSocketCount = JMXProperties.getInstance().getProperty(
-      "member.M1.totalFileDescriptorOpen");
-    assertEquals(memberSocketCount, SocketCount);
-  }
-
-  @Test
-  public void testMemberLoadAverage() throws InterruptedException {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    String LoadAvg = driver.findElement(By.id(MEMBER_VIEW_LOADAVG_ID))
-      .getText();
-    String memberLoadAvg = JMXProperties.getInstance().getProperty(
-      "member.M1.loadAverage");
-    assertEquals(df2.format(Double.valueOf(memberLoadAvg)), LoadAvg);
-  }
-
-  @Ignore("WIP") // May be useful in near future
-  @Test
-  public void testOffHeapFreeSize() {
-
-    String OffHeapFreeSizeString = driver.findElement(
-      By.id(MEMBER_VIEW_OFFHEAPFREESIZE_ID)).getText();
-    String OffHeapFreeSizetemp = OffHeapFreeSizeString.replaceAll("[a-zA-Z]",
-      "");
-    float OffHeapFreeSize = Float.parseFloat(OffHeapFreeSizetemp);
-    float memberOffHeapFreeSize = Float.parseFloat(JMXProperties.getInstance()
-      .getProperty("member.M1.OffHeapFreeSize"));
-    if (memberOffHeapFreeSize < 1048576) {
-      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024;
-
-    }
-    else if (memberOffHeapFreeSize < 1073741824) {
-      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024 / 1024;
-    }
-    else {
-      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024 / 1024 / 1024;
-    }
-    memberOffHeapFreeSize = Float.parseFloat(new DecimalFormat("##.##")
-      .format(memberOffHeapFreeSize));
-    assertEquals(memberOffHeapFreeSize, OffHeapFreeSize);
-
-  }
-
-  @Ignore("WIP") // May be useful in near future
-  @Test
-  public void testOffHeapUsedSize() throws InterruptedException {
-
-    String OffHeapUsedSizeString = driver.findElement(
-      By.id(MEMBER_VIEW_OFFHEAPUSEDSIZE_ID)).getText();
-    String OffHeapUsedSizetemp = OffHeapUsedSizeString.replaceAll("[a-zA-Z]",
-      "");
-    float OffHeapUsedSize = Float.parseFloat(OffHeapUsedSizetemp);
-    float memberOffHeapUsedSize = Float.parseFloat(JMXProperties.getInstance()
-      .getProperty("member.M1.OffHeapUsedSize"));
-    if (memberOffHeapUsedSize < 1048576) {
-      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024;
-
-    }
-    else if (memberOffHeapUsedSize < 1073741824) {
-      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024 / 1024;
-    }
-    else {
-      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024 / 1024 / 1024;
-    }
-    memberOffHeapUsedSize = Float.parseFloat(new DecimalFormat("##.##")
-      .format(memberOffHeapUsedSize));
-    assertEquals(memberOffHeapUsedSize, OffHeapUsedSize);
-  }
-
-  @Test
-  public void testMemberJVMPauses() throws Exception {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    String JVMPauses = driver.findElement(By.id(MEMBER_VIEW_JVMPAUSES_ID))
-      .getText();
-    String memberGcPausesAvg = JMXProperties.getInstance().getProperty(
-      "member.M1.JVMPauses");
-    assertEquals(memberGcPausesAvg, JVMPauses);
-  }
-
-  @Test
-  public void testMemberCPUUsage() {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    String CPUUsagevalue = driver.findElement(By.id(MEMBER_VIEW_CPUUSAGE_ID))
-      .getText();
-    String memberCPUUsage = JMXProperties.getInstance().getProperty(
-      "member.M1.cpuUsage");
-    assertEquals(memberCPUUsage, CPUUsagevalue);
-  }
-
-  @Test  // difference between UI and properties file
-  public void testMemberAverageReads() {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    float ReadPerSec = Float.parseFloat(driver.findElement(By.id(MEMBER_VIEW_READPERSEC_ID)).getText());
-    float memberReadPerSec = Float.parseFloat(JMXProperties.getInstance().getProperty("member.M1.averageReads"));
-    memberReadPerSec = Float.parseFloat(new DecimalFormat("##.##")
-      .format(memberReadPerSec));
-    assertEquals(memberReadPerSec, ReadPerSec);
-  }
-
-  @Test
-  public void testMemberAverageWrites() throws InterruptedException {
-    testRgraphWidget();
-    String WritePerSec = driver.findElement(By.id(MEMBER_VIEW_WRITEPERSEC_ID))
-      .getText();
-    String memberWritePerSec = JMXProperties.getInstance().getProperty(
-      "member.M1.averageWrites");
-    assertEquals(memberWritePerSec, WritePerSec);
-  }
-
-
-  @Test
-  public void testMemberGridViewData() throws InterruptedException {
-    testRgraphWidget();
-    searchByXPathAndClick(PulseTestLocators.MemberDetailsView.gridButtonXpath);
-    // get the number of rows on the grid
-    List<WebElement> noOfRows = driver.findElements(By.xpath("//table[@id='memberRegionsList']/tbody/tr"));
-    String MemberRegionName = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[1]")).getText();
-    String memberRegionName = JMXProperties.getInstance().getProperty("region.R1.name");
-    assertEquals(memberRegionName, MemberRegionName);
-
-    String MemberRegionType = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[2]")).getText();
-    String memberRegionType = JMXProperties.getInstance().getProperty("region.R1.regionType");
-    assertEquals(memberRegionType, MemberRegionType);
-
-    String MemberRegionEntryCount = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[3]")).getText();
-    String memberRegionEntryCount = JMXProperties.getInstance().getProperty("regionOnMember./R1.M1.entryCount");
-    assertEquals(memberRegionEntryCount, MemberRegionEntryCount);
-  }
-
-  @Test
-  public void testDropDownList() throws InterruptedException {
-    searchByIdAndClick("default_grid_button");
-    searchByIdAndClick("M1&M1");
-    searchByIdAndClick("memberName");
-    searchByLinkAndClick("M3");
-    searchByIdAndClick("memberName");
-    searchByLinkAndClick("M2");
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewRegionName() throws InterruptedException {
-    searchByLinkAndClick(DATA_VIEW_LABEL);
-    Thread.sleep(7000);
-    searchByIdAndClick("default_grid_button");
-    String regionName = driver.findElement(By.id(REGION_NAME_LABEL)).getText();
-    String dataviewregionname = JMXProperties.getInstance().getProperty("region.R1.name");
-    assertEquals(dataviewregionname, regionName);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewRegionPath() {
-    String regionPath = driver.findElement(By.id(REGION_PATH_LABEL)).getText();
-    String dataviewregionpath = JMXProperties.getInstance().getProperty(
-      "region.R1.fullPath");
-    assertEquals(dataviewregionpath, regionPath);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewRegionType() {
-    String regionType = driver.findElement(By.id(REGION_TYPE_LABEL)).getText();
-    String dataviewregiontype = JMXProperties.getInstance().getProperty(
-      "region.R1.regionType");
-    assertEquals(dataviewregiontype, regionType);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewEmptyNodes() {
-    String regionEmptyNodes = driver.findElement(By.id(DATA_VIEW_EMPTYNODES))
-      .getText();
-    String dataviewEmptyNodes = JMXProperties.getInstance().getProperty(
-      "region.R1.emptyNodes");
-    assertEquals(dataviewEmptyNodes, regionEmptyNodes);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewSystemRegionEntryCount() {
-    String regionEntryCount = driver.findElement(By.id(DATA_VIEW_ENTRYCOUNT))
-      .getText();
-    String dataviewEntryCount = JMXProperties.getInstance().getProperty(
-      "region.R1.systemRegionEntryCount");
-    assertEquals(dataviewEntryCount, regionEntryCount);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewPersistentEnabled() {
-    String regionPersistence = driver.findElement(
-      By.id(REGION_PERSISTENCE_LABEL)).getText();
-    String dataviewregionpersistence = JMXProperties.getInstance().getProperty(
-      "region.R1.persistentEnabled");
-    assertEquals(dataviewregionpersistence, regionPersistence);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewDiskWritesRate() {
-    String regionWrites = driver.findElement(By.id(DATA_VIEW_WRITEPERSEC))
-      .getText();
-    String dataviewRegionWrites = JMXProperties.getInstance().getProperty(
-      "region.R1.diskWritesRate");
-    assertEquals(dataviewRegionWrites, regionWrites);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewDiskReadsRate() {
-    String regionReads = driver.findElement(By.id(DATA_VIEW_READPERSEC))
-      .getText();
-    String dataviewRegionReads = JMXProperties.getInstance().getProperty(
-      "region.R1.diskReadsRate");
-    assertEquals(dataviewRegionReads, regionReads);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewDiskUsage() {
-    String regionMemoryUsed = driver.findElement(By.id(DATA_VIEW_USEDMEMORY))
-      .getText();
-    String dataviewMemoryUsed = JMXProperties.getInstance().getProperty(
-      "region.R1.diskUsage");
-    assertEquals(dataviewMemoryUsed, regionMemoryUsed);
-    searchByLinkAndClick(QUERY_STATISTICS_LABEL);
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataViewGridValue() {
-    String DataViewRegionName = driver.findElement(
-      By.xpath("//*[id('6')/x:td[1]]")).getText();
-    String dataViewRegionName = JMXProperties.getInstance().getProperty(
-      "region.R1.name");
-    assertEquals(dataViewRegionName, DataViewRegionName);
-
-    String DataViewRegionType = driver.findElement(
-      By.xpath("//*[id('6')/x:td[2]")).getText();
-    String dataViewRegionType = JMXProperties.getInstance().getProperty(
-      "region.R2.regionType");
-    assertEquals(dataViewRegionType, DataViewRegionType);
-
-    String DataViewEntryCount = driver.findElement(
-      By.xpath("//*[id('6')/x:td[3]")).getText();
-    String dataViewEntryCount = JMXProperties.getInstance().getProperty(
-      "region.R2.systemRegionEntryCount");
-    assertEquals(dataViewEntryCount, DataViewEntryCount);
-
-    String DataViewEntrySize = driver.findElement(
-      By.xpath("//*[id('6')/x:td[4]")).getText();
-    String dataViewEntrySize = JMXProperties.getInstance().getProperty(
-      "region.R2.entrySize");
-    assertEquals(dataViewEntrySize, DataViewEntrySize);
-
-  }
-
-
-  public void loadDataBrowserpage() {
-    searchByLinkAndClick(DATA_BROWSER_LABEL);
-    //Thread.sleep(7000);
-  }
-
-  @Test
-  public void testDataBrowserRegionName() throws InterruptedException {
-    loadDataBrowserpage();
-    String DataBrowserRegionName1 = driver.findElement(By.id(DATA_BROWSER_REGIONName1))
-      .getText();
-    String databrowserRegionNametemp1 = JMXProperties.getInstance().getProperty(
-      "region.R1.name");
-    String databrowserRegionName1 = databrowserRegionNametemp1.replaceAll("[\\/]", "");
-    assertEquals(databrowserRegionName1, DataBrowserRegionName1);
-
-    String DataBrowserRegionName2 = driver.findElement(By.id(DATA_BROWSER_REGIONName2))
-      .getText();
-    String databrowserRegionNametemp2 = JMXProperties.getInstance().getProperty(
-      "region.R2.name");
-    String databrowserRegionName2 = databrowserRegionNametemp2.replaceAll("[\\/]", "");
-    assertEquals(databrowserRegionName2, DataBrowserRegionName2);
-
-    String DataBrowserRegionName3 = driver.findElement(By.id(DATA_BROWSER_REGIONName3))
-      .getText();
-    String databrowserRegionNametemp3 = JMXProperties.getInstance().getProperty(
-      "region.R3.name");
-    String databrowserRegionName3 = databrowserRegionNametemp3.replaceAll("[\\/]", "");
-    assertEquals(databrowserRegionName3, DataBrowserRegionName3);
-
-  }
-
-  @Test
-  public void testDataBrowserRegionMembersVerificaition() throws InterruptedException {
-    loadDataBrowserpage();
-    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
-    String DataBrowserMember1Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
-      .getText();
-    String DataBrowserMember1Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
-      .getText();
-    String DataBrowserMember1Name3 = driver.findElement(By.xpath("//label[@for='Member2']"))
-      .getText();
-    String databrowserMember1Names = JMXProperties.getInstance().getProperty(
-      "region.R1.members");
-
-    String databrowserMember1Names1 = databrowserMember1Names.substring(0, 2);
-    assertEquals(databrowserMember1Names1, DataBrowserMember1Name1);
-
-    String databrowserMember1Names2 = databrowserMember1Names.substring(3, 5);
-    assertEquals(databrowserMember1Names2, DataBrowserMember1Name2);
-
-    String databrowserMember1Names3 = databrowserMember1Names.substring(6, 8);
-    assertEquals(databrowserMember1Names3, DataBrowserMember1Name3);
-    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
-
-    searchByIdAndClick(DATA_BROWSER_REGION2_CHECKBOX);
-    String DataBrowserMember2Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
-      .getText();
-    String DataBrowserMember2Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
-      .getText();
-    String databrowserMember2Names = JMXProperties.getInstance().getProperty(
-      "region.R2.members");
-
-    String databrowserMember2Names1 = databrowserMember2Names.substring(0, 2);
-    assertEquals(databrowserMember2Names1, DataBrowserMember2Name1);
-
-    String databrowserMember2Names2 = databrowserMember2Names.substring(3, 5);
-    assertEquals(databrowserMember2Names2, DataBrowserMember2Name2);
-    searchByIdAndClick(DATA_BROWSER_REGION2_CHECKBOX);
-
-    searchByIdAndClick(DATA_BROWSER_REGION3_CHECKBOX);
-    String DataBrowserMember3Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
-      .getText();
-    String DataBrowserMember3Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
-      .getText();
-    String databrowserMember3Names = JMXProperties.getInstance().getProperty(
-      "region.R3.members");
-
-    String databrowserMember3Names1 = databrowserMember3Names.substring(0, 2);
-    assertEquals(databrowserMember3Names1, DataBrowserMember3Name1);
-
-    String databrowserMember3Names2 = databrowserMember3Names.substring(3, 5);
-    assertEquals(databrowserMember3Names2, DataBrowserMember3Name2);
-    searchByIdAndClick(DATA_BROWSER_REGION3_CHECKBOX);
-  }
-
-  @Test
-  public void testDataBrowserColocatedRegions() throws InterruptedException {
-    loadDataBrowserpage();
-    String databrowserMemberNames1 = JMXProperties.getInstance().getProperty(
-      "region.R1.members");
-    String databrowserMemberNames2 = JMXProperties.getInstance().getProperty(
-      "region.R2.members");
-    String databrowserMemberNames3 = JMXProperties.getInstance().getProperty(
-      "region.R3.members");
-
-    if ((databrowserMemberNames1.matches(databrowserMemberNames2 + "(.*)"))) {
-      if ((databrowserMemberNames1.matches(databrowserMemberNames3 + "(.*)"))) {
-        if ((databrowserMemberNames2.matches(databrowserMemberNames3 + "(.*)"))) {
-          System.out.println("R1, R2 and R3 are colocated regions");
-        }
-      }
-    }
-    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
-    searchByLinkAndClick(DATA_BROWSER_COLOCATED_REGION);
-    String DataBrowserColocatedRegion1 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME1))
-      .getText();
-    String DataBrowserColocatedRegion2 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME2))
-      .getText();
-    String DataBrowserColocatedRegion3 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME3))
-      .getText();
-
-    String databrowserColocatedRegiontemp1 = JMXProperties.getInstance().getProperty(
-      "region.R1.name");
-    String databrowserColocatedRegion1 = databrowserColocatedRegiontemp1.replaceAll("[\\/]", "");
-
-    String databrowserColocatedRegiontemp2 = JMXProperties.getInstance().getProperty(
-      "region.R2.name");
-    String databrowserColocatedRegion2 = databrowserColocatedRegiontemp2.replaceAll("[\\/]", "");
-
-    String databrowserColocatedRegiontemp3 = JMXProperties.getInstance().getProperty(
-      "region.R3.name");
-    String databrowserColocatedRegion3 = databrowserColocatedRegiontemp3.replaceAll("[\\/]", "");
-
-    assertEquals(databrowserColocatedRegion1, DataBrowserColocatedRegion1);
-    assertEquals(databrowserColocatedRegion2, DataBrowserColocatedRegion2);
-    assertEquals(databrowserColocatedRegion3, DataBrowserColocatedRegion3);
-
-  }
-
-  @Ignore("WIP") // clusterDetails element not found on Data Browser page. No assertions in test
-  @Test
-  public void testDataBrowserQueryValidation() throws IOException, InterruptedException {
-    loadDataBrowserpage();
-    WebElement textArea = driver.findElement(By.id("dataBrowserQueryText"));
-    textArea.sendKeys("query1");
-    WebElement executeButton = driver.findElement(By.id("btnExecuteQuery"));
-    executeButton.click();
-    String QueryResultHeader1 = driver.findElement(By.xpath("//div[@id='clusterDetails']/div/div/span[@class='n-title']")).getText();
-    double count = 0, countBuffer = 0, countLine = 0;
-    String lineNumber = "";
-    String filePath = "E:\\springsource\\springsourceWS\\Pulse-Cedar\\src\\main\\resources\\testQueryResultSmall.txt";
-    BufferedReader br;
-    String line = "";
-    br = new BufferedReader(new FileReader(filePath));
-    while ((line = br.readLine()) != null) {
-      countLine++;
-      String[] words = line.split(" ");
-
-      for (String word : words) {
-        if (word.equals(QueryResultHeader1)) {
-          count++;
-          countBuffer++;
-        }
-      }
-    }
-  }
-
-  public void testTreeMapPopUpData(String S1, String gridIcon) {
-    for (int i = 1; i <= 3; i++) {
-      searchByLinkAndClick(CLUSTER_VIEW_LABEL);
-      if (gridIcon.equals(SERVER_GROUP_GRID_ID)) {
-        WebElement ServerGroupRadio = driver.findElement(By.xpath("//label[@for='radio-servergroups']"));
-        ServerGroupRadio.click();
-      }
-      if (gridIcon.equals(REDUNDANCY_GRID_ID)) {
-        WebElement ServerGroupRadio = driver.findElement(By.xpath("//label[@for='radio-redundancyzones']"));
-        ServerGroupRadio.click();
-      }
-      searchByIdAndClick(gridIcon);
-      WebElement TreeMapMember = driver.findElement(By.xpath("//div[@id='" + S1 + "M" + (i) + "']/div"));
-      Actions builder = new Actions(driver);
-      builder.clickAndHold(TreeMapMember).perform();
-      int j = 1;
-      String CPUUsageM1temp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div/div[2]/div"))
-        .getText();
-      String CPUUsageM1 = CPUUsageM1temp.replaceAll("[\\%]", "");
-      String cpuUsageM1 = JMXProperties.getInstance().getProperty(
-        "member.M" + (i) + ".cpuUsage");
-      assertEquals(cpuUsageM1, CPUUsageM1);
-
-      String MemoryUsageM1temp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 1) + "]/div[2]/div"))
-        .getText();
-      String MemoryUsageM1 = MemoryUsageM1temp.replaceAll("MB", "");
-      String memoryUsageM1 = JMXProperties.getInstance().getProperty(
-        "member.M" + (i) + ".UsedMemory");
-      assertEquals(memoryUsageM1, MemoryUsageM1);
-
-      String LoadAvgM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 2) + "]/div[2]/div"))
-        .getText();
-      String loadAvgM1 = JMXProperties.getInstance().getProperty(
-        "member.M" + (i) + ".loadAverage");
-      assertEquals(df2.format(Double.valueOf(loadAvgM1)), LoadAvgM1);
-
-
-      String ThreadsM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 3) + "]/div[2]/div"))
-        .getText();
-      String threadsM1 = JMXProperties.getInstance().getProperty(
-        "member.M" + (i) + ".numThreads");
-      assertEquals(threadsM1, ThreadsM1);
-
-      String SocketsM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 4) + "]/div[2]/div"))
-        .getText();
-      String socketsM1 = JMXProperties.getInstance().getProperty(
-        "member.M" + (i) + ".totalFileDescriptorOpen");
-      assertEquals(socketsM1, SocketsM1);
-      builder.moveToElement(TreeMapMember).release().perform();
-    }
-  }
-
-  @Test
-  public void testTopologyPopUpData() {
-    testTreeMapPopUpData("", CLUSTER_VIEW_GRID_ID);
-  }
-
-  @Test
-  public void testServerGroupTreeMapPopUpData() {
-    testTreeMapPopUpData("SG1(!)", SERVER_GROUP_GRID_ID);
-  }
-
-  @Test
-  public void testDataViewTreeMapPopUpData() {
-    searchByLinkAndClick(CLUSTER_VIEW_LABEL);
-    searchByLinkAndClick(DATA_DROPDOWN_ID);
-    WebElement TreeMapMember = driver.findElement(By.id("GraphTreeMapClusterData-canvas"));
-    Actions builder = new Actions(driver);
-    builder.clickAndHold(TreeMapMember).perform();
-    String RegionType = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div/div[2]/div"))
-      .getText();
-    String regionType = JMXProperties.getInstance().getProperty(
-      "region.R2.regionType");
-    assertEquals(regionType, RegionType);
-
-    String EntryCount = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div"))
-      .getText();
-    String entryCount = JMXProperties.getInstance().getProperty(
-      "region.R2.systemRegionEntryCount");
-    assertEquals(entryCount, EntryCount);
-
-    String EntrySizetemp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div"))
-      .getText();
-    float EntrySize = Float.parseFloat(EntrySizetemp);
-    float entrySize = Float.parseFloat(JMXProperties.getInstance().getProperty(
-      "region.R2.entrySize"));
-    entrySize = entrySize / 1024 / 1024;
-    entrySize = Float.parseFloat(new DecimalFormat("##.####")
-      .format(entrySize));
-    assertEquals(entrySize, EntrySize);
-    builder.moveToElement(TreeMapMember).release().perform();
-  }
-
-  @Test
-  public void testRegionViewTreeMapPopUpData() {
-    searchByLinkAndClick(CLUSTER_VIEW_LABEL);
-    searchByLinkAndClick(DATA_DROPDOWN_ID);
-    WebElement TreeMapMember = driver.findElement(By.id("GraphTreeMapClusterData-canvas"));
-    TreeMapMember.click();
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testNumberOfRegions() throws InterruptedException {
-
-    driver.findElement(By.xpath("//a[text()='Data Browser']")).click();
-
-    Thread.sleep(1000);
-    List<WebElement> regionList = driver.findElements(By.xpath("//ul[@id='treeDemo']/li"));
-    String regions = JMXProperties.getInstance().getProperty("regions");
-    String[] regionName = regions.split(" ");
-    for (String string : regionName) {
-    }
-    //JMXProperties.getInstance().getProperty("region.R1.regionType");
-    int i = 1;
-    for (WebElement webElement : regionList) {
-      //webElement.getAttribute(arg0)
-      i++;
-    }
-
-    driver.findElement(By.id("treeDemo_1_check")).click();
-
-    List<WebElement> memeberList = driver.findElements(By.xpath("//ul[@id='membersList']/li"));
-    int j = 0;
-    for (WebElement webElement : memeberList) {
-      j++;
-    }
-  }
-
-  @Ignore("WIP")
-  @Test
-  public void testDataBrowser() {
-
-    driver.findElement(By.linkText("Data Browser")).click();
-    // WebElement dataBrowserLabel = driver.findElement(By.xpath(""));
-    WebDriverWait wait = new WebDriverWait(driver, 20);
-    wait.until(ExpectedConditions.visibilityOf(driver.findElement(By.xpath("//label[text()='Data Browser']"))));
-
-
-    // Verify all elements must be displayed on data browser screen
-    assertTrue(driver.findElement(By.xpath("//a[text()='Data Regions']")).isDisplayed());
-    assertTrue(driver.findElement(By.id("linkColocatedRegions")).isDisplayed());
-    assertTrue(driver.findElement(By.linkText("All Regions")).isDisplayed());
-
-    assertTrue(driver.findElement(By.xpath("//a[text()='Region Members']")).isDisplayed());
-
-    assertTrue(driver.findElement(By.xpath("//a[text()='Queries']")).isDisplayed());
-    assertTrue(driver.findElement(By.xpath("//label[text()='Query Editor']")).isDisplayed());
-    assertTrue(driver.findElement(By.xpath("//label[text()='Result']")).isDisplayed());
-    assertTrue(driver.findElement(By.xpath("//input[@value='Export Result']")).isDisplayed());
-    assertTrue(driver.findElement(By.id("btnExecuteQuery")).isDisplayed());
-    assertTrue(driver.findElement(By.xpath("//input[@value='Clear']")).isDisplayed());
-    assertTrue(driver.findElement(By.id("dataBrowserQueryText")).isDisplayed());
-
-    assertTrue(driver.findElement(By.id("historyIcon")).isDisplayed());
-
-    //Actual query execution
-
-    driver.findElement(By.id("dataBrowserQueryText")).sendKeys("Query1");
-
-    // Assert data regions are displayed
-    assertTrue(driver.findElement(By.id("treeDemo_1")).isDisplayed());
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAuthTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAuthTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAuthTest.java
deleted file mode 100644
index e5e30d2..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAuthTest.java
+++ /dev/null
@@ -1,33 +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 com.vmware.geode.tools.pulse.tests;
-
-import org.apache.geode.test.junit.categories.UITest;
-import org.junit.BeforeClass;
-import org.junit.FixMethodOrder;
-import org.junit.experimental.categories.Category;
-import org.junit.runners.MethodSorters;
-
-@Category(UITest.class)
-@FixMethodOrder(MethodSorters.JVM)
-public class PulseAuthTest extends PulseAbstractTest {
-
-  @BeforeClass
-  public static void beforeClassSetup() throws Exception {
-    setUpServer("pulseUser", "12345", "/pulse-auth.json");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAutomatedTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAutomatedTest.java b/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAutomatedTest.java
deleted file mode 100644
index 90e1bd9..0000000
--- a/geode-pulse/src/test/java/com/vmware/gemfire/tools/pulse/tests/PulseAutomatedTest.java
+++ /dev/null
@@ -1,784 +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.
- *
- */
-/**
-* This test class contains automated tests for Pulse application related to
-* 1. Different grid data validations for example - Topology, Server Group, Redundancy Zone
-* 2. Data Browser
-* 3. 
-* 
-*
-* @version 1.0
-* @since GemFire   2014-04-02
-*/
-package com.vmware.geode.tools.pulse.tests;
-
-import static org.junit.Assert.*;
-
-import java.text.DateFormat;
-import java.text.SimpleDateFormat;
-import java.util.List;
-
-import org.junit.BeforeClass;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.experimental.categories.Category;
-import org.openqa.selenium.By;
-import org.openqa.selenium.WebElement;
-
-import org.apache.geode.test.junit.categories.UITest;
-
-@Category(UITest.class)
-public class PulseAutomatedTest extends PulseAbstractTest {
-
-	@BeforeClass
-	public static void beforeClassSetup() throws Exception {
-		setUpServer("pulseUser", "12345", "/pulse-auth.json");
-	}
-
-	@Test
-	public void serverGroupGridDataValidation() {
-		navigateToServerGroupGridView();
-		validateServerGroupGridData();
-	}
-
-	@Test
-	public void redundancyZonesGridDataValidation() {
-		navigateToRedundancyZonesGridView();
-		validateRedundancyZonesGridData();
-	}
-
-	@Test
-	public void topologyGridDataValidation() {
-		navigateToTopologyGridView();
-		validateTopologyGridData();
-	}
-
-	@Test
-	public void dataViewGridDataValidation() {
-		navigateToDataPrespectiveGridView();
-		validateDataPrespectiveGridData();
-	}
-
-	@Test
-	public void regionDetailsGridDataValidation() {
-		navigateToRegionDetailsGridView();
-		validateRegionDetailsGridData();
-
-	}
-
-	@Test
-	public void regionDetailsNavigationTest() {
-		navigateToRegionDetailsView();
-		assertEquals("/R2", getTextUsingId(PulseTestLocators.RegionDetailsView.regionNameDivId));
-	}
-
-	@Test
-	public void regionName() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.name"), getTextUsingId(PulseTestLocators.RegionDetailsView.regionNameDivId));
-	}
-
-	@Test
-	public void regionPath() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.fullPath"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionPathId));
-	}
-
-	@Test
-	public void regionType() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.regionType"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionTypeId));
-	}
-
-	@Test
-	public void regionMembers() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.memberCount"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionMembersTextId));
-	}
-
-	@Test
-	public void regionEmptyNodes() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.emptyNodes"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionEmptyNodesId));
-	}
-
-	@Test
-	public void regionEntryCount() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.systemRegionEntryCount"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionEntryCountTextId));
-	}
-
-	@Test
-	public void regionDiskUsage() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.diskUsage"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionDiskUsageId));
-	}
-
-	@Test
-	public void regionPersistence() {
-		navigateToRegionDetailsView();
-		assertEquals(getPersistanceEnabled(getPropertyValue("region.R2.persistentEnabled")),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.regionPersistenceId));
-	}
-
-	@Ignore("WIP")
-	@Test
-	public void regionMemoryUsage() {
-		navigateToRegionDetailsView();
-		// need to check the respective property values
-	}
-
-	@Test
-	public void regionInMemoryRead() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.getsRate"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.inMemoryReadsId));
-
-	}
-
-	@Test
-	public void regionInMemoryWrites() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.putsRate"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.inMemoryWritesId));
-	}
-
-	@Test
-	public void regionDiskRead() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.diskReadsRate"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.diskReadsId));
-	}
-
-	@Test
-	public void regionDiskWrites() {
-		navigateToRegionDetailsView();
-		assertEquals(getPropertyValue("region.R2.diskWritesRate"),
-				getTextUsingId(PulseTestLocators.RegionDetailsView.diskWritesId));
-	}
-
-	@Test
-	public void clickHostShowsMemberTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
-	}
-
-	@Test
-	@Ignore("Issue with highlighting")
-	public void verifyHostTooltipsOfTopologyGraphTest() {		
-		for (int i = 1; i <=3; i++) {
-			clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-			mouseClickAndHoldOverElementById("h" + i);
-			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostNameTTXpath, getPropertyValue("member.M" + i + ".host"));
-			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.cpuUsageTTXpath, "0%");
-			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memoryUsageTTXpath, getPropertyValue("member.M" + i
-					+ ".UsedMemory"));
-			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.loadAvgTTXpath, getPropertyValue("member.M" + i
-					+ ".loadAverage"));
-			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.soketsTTXpath, getPropertyValue("member.M" + i
-					+ ".totalFileDescriptorOpen"));
-			mouseReleaseById("h" + i);
-			driver.navigate().refresh();
-		}
-	}
-
-	@Ignore("Issues with member tooltip xpath")
-	@Test
-	public void verifyMemberTooltipsOfTopologyGraphTest() {
-
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH1Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
-		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM1Id);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M1.member"));
-		//verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M1.cpuUsage") + "%");
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M1.JVMPauses"));
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M1.totalRegionCount"));
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH2Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
-		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM2Id);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M2.member"));
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M2.cpuUsage") + "%");
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M2.JVMPauses"));
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M2.totalRegionCount"));
-
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH3Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
-		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM3Id);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M3.member"));
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M3.cpuUsage") + "%");
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M3.JVMPauses"));
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M3.totalRegionCount"));
-
-	}
-
-	@Test
-	public void VerifyRGraphTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH1Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH2Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH3Id);
-	}
-
-	@Test
-	public void clickMembersOfTopologyGraphTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM1Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM3Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-	@Test
-	public void clickTreeMapViewShowingTreeMapTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
-	}
-
-	@Test
-	public void verifyMembersPresentInTreeMapTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM1Id, "M1");
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM2Id, "M2");
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM3Id, "M3");
-	}
-
-	@Test
-	public void clickMemberNavigatingToCorrespondingRegionTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM1Id, "M1");
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM1Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM2Id, "M2");
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
-		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM3Id, "M3");
-		clickElementUsingId(PulseTestLocators.TopologyView.memberM3Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-	@Test
-	public void clickGridButtonShowsGridTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM1Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM1Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH1Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM3Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM3Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH3Xpath);
-	}
-
-	@Test
-	public void verifyMembersPresentInGridTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM1Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM1Xpath, "M1");
-
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM2Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM2Xpath, "M2");
-
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM3Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM3Xpath, "M3");
-	}
-
-	@Test
-	public void verifyHostNamesInGridTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH1Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH1Xpath, "h1");
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH2Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH2Xpath, "h2");
-		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH3Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH3Xpath, "h3");
-	}
-
-	@Test
-	public void clickOnGridMemNameNavigatingToCorrespondingRegionTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM1Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM2Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM3Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-	@Test
-	public void verifyMembersPresentInSvrGrpTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp1Id);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp2Id);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp3Id);
-
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M1Id);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M2Id);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M3Id);
-
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg2M1Id);
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg2M2Id);
-
-		verifyElementPresentById(PulseTestLocators.ServerGroups.sg3M3Id);
-	}
-
-	@Test
-	public void expandAndCloseServerGroupsTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		//waitForElement(findElementByXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath));
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp1Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp1Id, "style", "width: 720px; height: 415px;");
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp1Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp1Id, "style", "width: 239.667px; height: 399px;");
-
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp2Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp2Id, "style", "width: 720px; height: 415px;");
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp2Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp2Id, "style", "width: 239.667px; height: 399px;");
-
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp3Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp3Id, "style", "width: 720px; height: 415px;");
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp3Xpath);
-		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp3Id, "style", "width: 239.667px; height: 399px;");
-	}
-
-	@Test
-	public void verifyMembersInServGrpTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
-
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp1Id, "SG1");
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp2Id, "SG2");
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp3Id, "SG3");
-
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M1Id, "M1");
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M2Id, "M2");
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M3Id, "M3");
-
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg2M1Id, "M1");
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg2M2Id, "M2");
-
-		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg3M3Id, "M3");
-	}
-
-	@Test
-	public void memberNavigationFromServGrpTest() {
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M1Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M3Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg2M1Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg2M2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.sg3M3Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-	@Test
-	public void clickServGrpGridButtonShowsGridTest() {
-		navigateToServerGroupGridView();
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M3Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M1Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM3Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM1Xpath);
-
-	}
-
-	@Test
-	public void memberNavigationFromServGrpGridTest() {
-		navigateToServerGroupGridView();
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M3Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-		navigateToServerGroupGridView();
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M1Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		navigateToServerGroupGridView();
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M2Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-	}
-
-	@Test
-	public void verifyZonePresentTest() {
-		navigateToRedundancyZonesTreeView();
-		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
-		verifyElementPresentById(PulseTestLocators.RedundancyZone.zoneRZ2Id);
-	}
-
-	@Test
-	public void expandAndCloseRdncyZoneTest() {
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
-		verifyElementAttributeById(PulseTestLocators.RedundancyZone.zoneRZ1Id, "style", "width: 720px; height: 415px;");
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ2Xpath);
-		verifyElementAttributeById(PulseTestLocators.RedundancyZone.zoneRZ2Id, "style", "width: 720px; height: 415px;");
-
-	}
-
-	@Test
-	public void clickRZMembersNavigationTest() {
-		navigateToRedundancyZonesTreeView();		
-		clickElementUsingId(PulseTestLocators.RedundancyZone.m1RZ1RZ2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.m2RZ1Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.m3RZ2Id);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-	@Test
-	public void clickRZGridShowingGridTest() {
-		navigateToRedundancyZonesGridView();
-		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM2Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM1Xpath);
-		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM3Xpath);
-		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM2Xpath, "M2");
-		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM1Xpath, "M1");
-		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM3Xpath, "M3");
-	}
-
-	@Test
-	public void clickRZGridMembersNavigationTest() {
-		navigateToRedundancyZonesGridView();
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM2Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
-		navigateToRedundancyZonesGridView();
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM1Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
-		navigateToRedundancyZonesGridView();
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM3Xpath);
-		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
-	}
-
-
-	@Test
-	public void verifySortingOptionsTest(){
-		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
-		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
-		verifyElementPresentById(PulseTestLocators.TopologyView.hotSpotId);
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);			
-		verifyElementPresentByLinkText("Heap Usage");
-		verifyElementPresentByLinkText("CPU Usage");		
-	}
-	
-	/* 
-	 * HotSpot test scripts - 
-	 */
-	//--- Topology view
-	
-	@Test
-	public void testHotSpotOptPrsntOnTopologyView(){
-		navigateToTopologyTreeView();
-	    assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));	
-	}
-	
-	@Test
-	public void testHotSpotOptionsTopologyView(){	
-		navigateToTopologyTreeView();
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
-		assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath));
-		assertEquals(PulseTestData.Topology.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath));
-	}
-	
-	@Test
-	public void testCpuUsageNavigationOnTopologyView(){
-		navigateToTopologyTreeView();
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath);
-		assertEquals(PulseTestData.Topology.hotSpotCPULbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));
-	}
-	
-	@Test
-	public void testHeapUsageNavigationOnTopologyView(){
-		navigateToTopologyTreeView();
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath);
-		assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));
-	}
-
-	@Test
-	public void testSortingUsingCpuUsageOnTopologyView(){
-		navigateToTopologyTreeView();
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath);
-		assertMemberSortingByCpuUsage();
-	}
-	
-	@Test
-	public void testSortingUsingHeapUsageOnTopologyView(){
-		navigateToTopologyTreeView();
-		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath);
-		assertMemberSortingByHeapUsage();
-	}
-	
-	//--- Server Group view
-	
-	@Test
-	public void testHotSpotOptPrsntOnServerGroupView(){
-		navigateToServerGroupTreeView();
-	    assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));	
-	}
-	
-	@Test
-	public void testHotSpotOptionsServerGroupView(){	
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
-		assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath));
-		assertEquals(PulseTestData.ServerGroups.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath));		
-	}
-	
-	@Test
-	public void testCpuUsageNavigationOnServerGroupView(){
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath);
-		assertEquals(PulseTestData.ServerGroups.hotSpotCPULbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));
-	}
-	
-	@Test
-	public void testHeapUsageNavigationOnServerGroupView(){
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath);
-		assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));
-	}	
-
-	@Test
-	public void testSortingUsingHeapUsageOnServerGroupView(){
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath);
-		assertMemberSortingBySgHeapUsage();
-	}
-	
-	@Test
-	public void testSortingUsingCpuUsageOnServerGroupView(){
-		navigateToServerGroupTreeView();
-		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath);
-		assertMemberSortingBySgCpuUsage();
-	}
-	
-	//--- Redundancy Zone view
-	
-	@Test
-	public void testHotSpotOptPrsntOnRedundancyZoneView(){
-		navigateToRedundancyZonesTreeView();
-	    assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));	
-	}
-	
-	
-	@Test
-	public void testHotSpotOptionsRedundancyZoneView(){	
-		// navigate to Redundancy Zones - Tree View
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
-		assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath));
-		assertEquals(PulseTestData.RedundancyZone.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath));		
-	}
-	
-	@Test
-	public void testCpuUsageNavigationOnRedundancyZoneView(){
-		// navigate to Redundancy Zones - Tree View
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath);
-		assertEquals(PulseTestData.RedundancyZone.hotSpotCPULbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));
-	}
-	
-	@Test
-	public void testHeapUsageNavigationOnRedundancyZoneView(){
-		// navigate to Redundancy Zones - Tree View
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath);
-		assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));
-	}
-	
-	@Test
-	public void testSortingUsingHeapUsageOnRedundancyView(){
-		// navigate to Redundancy Zones - Tree View
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath);
-		assertMemberSortingByRzHeapUsage();
-	}
-	
-	@Test
-	public void testSortingUsingCpuUsageOnRedundancyView(){
-		// navigate to Redundancy Zones - Tree View
-		navigateToRedundancyZonesTreeView();
-		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
-		clickElementUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath);
-		assertMemeberSortingByRzCpuUsage();
-	}	
-	
-	@Test
-	public void testDataBrowserFilterFeature(){
-		// navigate to Data browser page
-		loadDataBrowserpage();		
-		List<WebElement> regionLst = getRegionsFromDataBrowser();		
-		String []regionNames = new String[regionLst.size()];		
-		for(int regionIndex = 0; regionIndex < regionLst.size(); regionIndex++){
-			regionNames[regionIndex] = findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + (regionIndex + 1 ) + PulseTestLocators.DataBrowser.rgnSpanSecondPart).getText();
-		}	
-		// type each region name in region filter and verify respective region(s) are displayed in region list
-		for (String region : regionNames) {
-				findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).clear();
-				findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).sendKeys(region);				
-				
-				List<WebElement> regionLst1 = getRegionsFromDataBrowser();									
-				
-				for(int regionIndex = 1; regionIndex <= regionLst1.size(); regionIndex++){
-					assertEquals(region,  findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + regionIndex + PulseTestLocators.DataBrowser.rgnSpanSecondPart).getText());
-				}
-		}
-	}
-	
-	@Test
-	public void testDataBrowserFilterPartialRegionName(){
-		// navigate to Data browser page
-		loadDataBrowserpage();		
-		findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).clear();
-		
-		// type partial region name in region filter and verify that all the regions that contains that  text displays
-		findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).sendKeys(PulseTestData.DataBrowser.partialRgnName);
-		List<WebElement> regionLst = getRegionsFromDataBrowser();		
-		
-		for(int regionIndex = 0; regionIndex < regionLst.size(); regionIndex++){			
-			assertTrue(findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + 
-					(regionIndex + 1 ) + 
-					PulseTestLocators.DataBrowser.rgnSpanSecondPart).
-					getText().
-					contains(PulseTestData.DataBrowser.partialRgnName));
-		}	
-	}
-	
-	@Test
-	public void testDataBrowserClearButton(){
-		// navigate to Data browser page
-		loadDataBrowserpage();		
-		
-		sendKeysUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId, PulseTestData.DataBrowser.query1Text);		
-		String editorTextBeforeClear = getTextUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId);
-		clickElementUsingXpath(PulseTestLocators.DataBrowser.btnClearXpath);
-		String editorTextAfterClear = getTextUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId);
-		
-		assertFalse(PulseTestData.DataBrowser.query1Text.equals(editorTextAfterClear));
-	}
-	
-	@Ignore("WIP") // Data Browser's Query History not showing any data on button click, therefore this test is failing
-	@Test
-	public void testDataBrowserHistoryQueue(){
-		// navigate to Data browser page
-		loadDataBrowserpage();	
-						
-		List<WebElement> numOfReg = driver.findElements(By.xpath(PulseTestLocators.DataBrowser.divDataRegions));
-		   
-	    for(int i = 1;  i <= numOfReg.size(); i ++){
-	    	if(getTextUsingId("treeDemo_" + i + "_span").equals( PulseTestData.DataBrowser.regName)){	  	    		
-	    		searchByIdAndClick("treeDemo_" + i + "_check"); 	//driver.findElement(By.id("treeDemo_" + i + "_check")).click();
-	    	}
-	    }	
-		
-		sendKeysUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId, PulseAbstractTest.QUERY_TYPE_ONE);
-		clickElementUsingId(PulseTestLocators.DataBrowser.btnExecuteQueryId);
-			
-		//Get required datetime format and extract date and hours from date time.
-	    DateFormat dateFormat = new SimpleDateFormat(PulseTestData.DataBrowser.datePattern);
-	    String queryDateTime = dateFormat.format(System.currentTimeMillis());
-	    String queryTime[] = queryDateTime.split(":");
-		System.out.println("Query Time from System: " + queryTime[0]);
-
-	    
-	    clickElementUsingId(PulseTestLocators.DataBrowser.historyIcon);	    
-	    List<WebElement> historyLst = driver.findElements(By.xpath(PulseTestLocators.DataBrowser.historyLst));
-		String queryText       = findElementByXpath(PulseTestLocators.DataBrowser.historyLst)
-						.findElement(By.cssSelector(PulseTestLocators.DataBrowser.queryText)).getText();
-  	String historyDateTime = findElementByXpath(PulseTestLocators.DataBrowser.historyLst)
-						.findElement(By.cssSelector(PulseTestLocators.DataBrowser.historyDateTime)).getText();
-	  System.out.println("Query Text from History Table: " + queryText);
-		System.out.println("Query Time from History Table: " + historyDateTime);
-  	    //verify the query text, query datetime in history panel
-	    assertTrue(PulseAbstractTest.QUERY_TYPE_ONE.equals(queryText));
-	    assertTrue(historyDateTime.contains(queryTime[0]));
-	   
-	}	
-}


[02/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXOriginatorRecoveryProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXOriginatorRecoveryProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXOriginatorRecoveryProcessor.java
index cc8e6bc..6b12022 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXOriginatorRecoveryProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXOriginatorRecoveryProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,20 +26,20 @@ import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.PooledDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.locks.DLockGrantor;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.PooledDistributionMessage;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.locks.DLockGrantor;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Sends <code>TXOriginatorRecoveryMessage</code> to all participants of
@@ -173,7 +173,7 @@ public class TXOriginatorRecoveryProcessor extends ReplyProcessor21  {
         // when the grantor receives reply it will release txLock...
         /* TODO: implement waitToReleaseTXLockId here
            testTXOriginatorRecoveryProcessor in 
-           com.gemstone.gemfire.internal.cache.locks.TXLockServiceTest
+           org.apache.geode.internal.cache.locks.TXLockServiceTest
            should be expanded upon also...
         */
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRecoverGrantorMessageProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRecoverGrantorMessageProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRecoverGrantorMessageProcessor.java
index 2d116a3..f90e4eb 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRecoverGrantorMessageProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRecoverGrantorMessageProcessor.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
 import java.util.concurrent.RejectedExecutionException;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRecoverGrantorProcessor;
-import com.gemstone.gemfire.distributed.internal.locks.DLockRemoteToken;
-import com.gemstone.gemfire.distributed.internal.locks.DLockService;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.TXCommitMessage;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.locks.DLockRecoverGrantorProcessor;
+import org.apache.geode.distributed.internal.locks.DLockRemoteToken;
+import org.apache.geode.distributed.internal.locks.DLockService;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.TXCommitMessage;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
 
 /**
  * Provides processing of DLockRecoverGrantorProcessor. Reply will not be

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRegionLockRequest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRegionLockRequest.java b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRegionLockRequest.java
index 9d6c32c..cbb6f88 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRegionLockRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/locks/TXRegionLockRequest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.locks;
+package org.apache.geode.internal.cache.locks;
 
-import com.gemstone.gemfire.DataSerializable;
-//import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.DataSerializable;
+//import org.apache.geode.cache.Region;
 import java.util.Set;
 
 /** Specifies a set of keys to try-lock within the scope of a region */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/EnableLRU.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/EnableLRU.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/EnableLRU.java
index e57dcc2..276e886 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/EnableLRU.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/EnableLRU.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.Region;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.Region;
 
 /**
  *  Marker interface to eviction controller that determines if LRU list

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapEvictor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapEvictor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapEvictor.java
index b4bba96..6b65ab0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapEvictor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapEvictor.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.distributed.internal.OverflowQueueWithDMStats;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.control.HeapMemoryMonitor;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.cache.control.MemoryEvent;
-import com.gemstone.gemfire.internal.cache.control.ResourceListener;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.OverflowQueueWithDMStats;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.control.HeapMemoryMonitor;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.cache.control.MemoryEvent;
+import org.apache.geode.internal.cache.control.ResourceListener;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
 import it.unimi.dsi.fastutil.objects.Object2LongOpenHashMap;
 import org.apache.logging.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUCapacityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUCapacityController.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUCapacityController.java
index a2a7be1..4499b00 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUCapacityController.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUCapacityController.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
-
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.control.InternalResourceManager;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.internal.cache.lru;
+
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.control.InternalResourceManager;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUStatistics.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUStatistics.java
index cc0e494..0f6da6e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/HeapLRUStatistics.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.*;
-//import com.gemstone.gemfire.internal.*;
+import org.apache.geode.*;
+//import org.apache.geode.internal.*;
 
 /**
  * Statistics for the HeapLRUCapacityController, which treats the
  * counter statistic differently than other flavors of
  * <code>LRUAlgorithms</code>
  *
- * @see com.gemstone.gemfire.internal.cache.lru.MemLRUCapacityController
- * @see com.gemstone.gemfire.internal.cache.lru.LRUCapacityController
+ * @see org.apache.geode.internal.cache.lru.MemLRUCapacityController
+ * @see org.apache.geode.internal.cache.lru.LRUCapacityController
  * @since GemFire 4.0
  */
 public class HeapLRUStatistics extends LRUStatistics {
@@ -46,7 +46,7 @@ public class HeapLRUStatistics extends LRUStatistics {
    *  about <code>Region</code> changes, it only considers heap
    *  changes and uses <code>Runtime</code> to determine how much to
    *  evict.
-   * @see com.gemstone.gemfire.internal.cache.lru.HeapLRUCapacityController#createLRUHelper
+   * @see org.apache.geode.internal.cache.lru.HeapLRUCapacityController#createLRUHelper
    * @see EnableLRU#mustEvict
    */
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUAlgorithm.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUAlgorithm.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUAlgorithm.java
index 3e440ca..dfaec61 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUAlgorithm.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUAlgorithm.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.InternalGemFireException;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.cache.BucketRegion;
-import com.gemstone.gemfire.internal.cache.PlaceHolderDiskRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireException;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.cache.BucketRegion;
+import org.apache.geode.internal.cache.PlaceHolderDiskRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.util.*;
@@ -39,7 +39,7 @@ import java.util.*;
  *
  * <LI>If the capacity of a region is to be controlled by an LRU
  * algorithm, then the region must be <b>created</b> with 
- * {@link com.gemstone.gemfire.cache.EvictionAttributes}
+ * {@link org.apache.geode.cache.EvictionAttributes}
  *
  * <LI>The eviction controller of a region governed by an LRU
  * algorithm cannot be changed.</LI>
@@ -50,17 +50,17 @@ import java.util.*;
  * </UL> 
  *
  * LRU algorithms also specify what {@linkplain 
- * com.gemstone.gemfire.cache.EvictionAction
+ * org.apache.geode.cache.EvictionAction
  * action} should be performed upon the least recently used entry when
  * the capacity is reached.  Currently, there are two supported
- * actions: {@linkplain com.gemstone.gemfire.cache.EvictionAction#LOCAL_DESTROY locally destroying} the entry
- * (which is the {@linkplain com.gemstone.gemfire.cache.EvictionAction#DEFAULT_EVICTION_ACTION default}), thus
- * freeing up space in the VM, and {@linkplain com.gemstone.gemfire.cache.EvictionAction#OVERFLOW_TO_DISK
+ * actions: {@linkplain org.apache.geode.cache.EvictionAction#LOCAL_DESTROY locally destroying} the entry
+ * (which is the {@linkplain org.apache.geode.cache.EvictionAction#DEFAULT_EVICTION_ACTION default}), thus
+ * freeing up space in the VM, and {@linkplain org.apache.geode.cache.EvictionAction#OVERFLOW_TO_DISK
  * overflowing} the value of the entry to disk.
  *
  * <P>
  *
- * {@link com.gemstone.gemfire.cache.EvictionAttributes Eviction controllers} that use an LRU
+ * {@link org.apache.geode.cache.EvictionAttributes Eviction controllers} that use an LRU
  * algorithm maintain certain region-dependent state (such as the
  * maximum number of entries allowed in the region).  As a result, an
  * instance of <code>LRUAlgorithm</code> cannot be shared among

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUCapacityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUCapacityController.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUCapacityController.java
index ffbc4ad..0baa3b6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUCapacityController.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUCapacityController.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.*;
+import org.apache.geode.cache.*;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.util.*;
 
@@ -45,7 +45,7 @@ import java.util.*;
  *  <pre>
  *  &lt;region-attributes&gt;
  *    &lt;capacity-controller&gt;
- *      &lt;classname&gt;com.gemstone.gemfire.cache.LRUCapacityController&lt;/classname&gt;
+ *      &lt;classname&gt;org.apache.geode.cache.LRUCapacityController&lt;/classname&gt;
  *      &lt;parameter name="maximum-entries"&gt;1000&lt;/parameter&gt;
  *    &lt;/capacity-controller&gt;
  *  &lt;/region-attributes&gt;
@@ -113,7 +113,7 @@ public final class LRUCapacityController extends LRUAlgorithm
    * Creates an LRU capacity controller that allows the {@link
    * #DEFAULT_MAXIMUM_ENTRIES default} maximum number of entries and
    * the {@link 
-   * com.gemstone.gemfire.cache.EvictionAction#DEFAULT_EVICTION_ACTION default} 
+   * org.apache.geode.cache.EvictionAction#DEFAULT_EVICTION_ACTION default} 
    * eviction action.
    *
    * @see #LRUCapacityController(int,Region)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUClockNode.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUClockNode.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUClockNode.java
index fd11644..c4720fc 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUClockNode.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUClockNode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
 public interface LRUClockNode {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUEntry.java
index f904ef9..9f81fa0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUEntry.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
 
 /**
  * Represents an entry in an LRU map

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUMapCallbacks.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUMapCallbacks.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUMapCallbacks.java
index c061888..f6c4d19 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUMapCallbacks.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUMapCallbacks.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-//import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-//import com.gemstone.gemfire.internal.cache.LocalRegion;
+//import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.RegionEntry;
+//import org.apache.geode.internal.cache.LocalRegion;
 
 /** The lru action on the map for evicting items must be called while the current thread is free of any map synchronizations.
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUStatistics.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUStatistics.java
index 67cca9b..df81190 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/LRUStatistics.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
 import java.util.concurrent.atomic.AtomicLong;
 
-import com.gemstone.gemfire.Statistics;
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.Statistics;
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.internal.Assert;
 
 /**
  * Statistics for both the LocalLRUClockHand.  Note that all its instance fields are

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/MemLRUCapacityController.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/MemLRUCapacityController.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/MemLRUCapacityController.java
index 6cfa582..593d26c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/MemLRUCapacityController.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/MemLRUCapacityController.java
@@ -14,26 +14,26 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.StatisticDescriptor;
-import com.gemstone.gemfire.StatisticsType;
-import com.gemstone.gemfire.StatisticsTypeFactory;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EvictionAction;
-import com.gemstone.gemfire.cache.EvictionAlgorithm;
-import com.gemstone.gemfire.cache.EvictionAttributes;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.internal.ClassPathLoader;
-import com.gemstone.gemfire.internal.statistics.StatisticsTypeFactoryImpl;
-import com.gemstone.gemfire.internal.cache.AbstractLRURegionMap.CDValueWrapper;
-import com.gemstone.gemfire.internal.cache.CachedDeserializableFactory;
-import com.gemstone.gemfire.internal.cache.Token;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.StatisticDescriptor;
+import org.apache.geode.StatisticsType;
+import org.apache.geode.StatisticsTypeFactory;
+import org.apache.geode.cache.Declarable;
+import org.apache.geode.cache.EvictionAction;
+import org.apache.geode.cache.EvictionAlgorithm;
+import org.apache.geode.cache.EvictionAttributes;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.internal.ClassPathLoader;
+import org.apache.geode.internal.statistics.StatisticsTypeFactoryImpl;
+import org.apache.geode.internal.cache.AbstractLRURegionMap.CDValueWrapper;
+import org.apache.geode.internal.cache.CachedDeserializableFactory;
+import org.apache.geode.internal.cache.Token;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 
 /**
@@ -64,7 +64,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  *  <pre>
  *  &lt;region-attributes&gt;
  *    &lt;capacity-controller&gt;
- *      &lt;classname&gt;com.gemstone.gemfire.cache.MemLRUCapacityController&lt;/classname&gt;
+ *      &lt;classname&gt;org.apache.geode.cache.MemLRUCapacityController&lt;/classname&gt;
  *         &lt;parameter name="maximum-megabytes"&gt;
  *           &lt;string&gt;50&lt;/string&gt;
  *         &lt;/parameter&gt;
@@ -168,11 +168,11 @@ public final class MemLRUCapacityController extends LRUAlgorithm
    *                megabytes.<br>
    *                <p>
    *                For a region with
-   *                {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}, it
+   *                {@link org.apache.geode.cache.DataPolicy#PARTITION}, it
    *                is overridden by
-   *                {@link  com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
+   *                {@link  org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
    *                specified for the
-   *                {@link com.gemstone.gemfire.cache.PartitionAttributes}. It
+   *                {@link org.apache.geode.cache.PartitionAttributes}. It
    *                signifies the amount of memory allowed in the region,
    *                collectively for its primary buckets and redundant copies
    *                for this VM. It can be different for the same region in
@@ -191,11 +191,11 @@ public final class MemLRUCapacityController extends LRUAlgorithm
    *                megabytes.<br>
    *                <p>
    *                For a region with
-   *                {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}, it
+   *                {@link org.apache.geode.cache.DataPolicy#PARTITION}, it
    *                is overridden by
-   *                {@link  com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
+   *                {@link  org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
    *                specified for the
-   *                {@link com.gemstone.gemfire.cache.PartitionAttributes}. It
+   *                {@link org.apache.geode.cache.PartitionAttributes}. It
    *                signifies the amount of memory allowed in the region,
    *                collectively for its primary buckets and redundant copies
    *                for this VM. It can be different for the same region in
@@ -216,11 +216,11 @@ public final class MemLRUCapacityController extends LRUAlgorithm
    *                megabytes.<br>
    *                <p>
    *                For a region with
-   *                {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}, it
+   *                {@link org.apache.geode.cache.DataPolicy#PARTITION}, it
    *                is overridden by
-   *                {@link  com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
+   *                {@link  org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int)  " local max memory "}
    *                specified for the
-   *                {@link com.gemstone.gemfire.cache.PartitionAttributes}. It
+   *                {@link org.apache.geode.cache.PartitionAttributes}. It
    *                signifies the amount of memory allowed in the region,
    *                collectively for its primary buckets and redundant copies
    *                for this VM. It can be different for the same region in
@@ -413,7 +413,7 @@ public final class MemLRUCapacityController extends LRUAlgorithm
           keySize = sizeof(key);
         }
         int valueSize = sizeof(value);
-//         com.gemstone.gemfire.internal.cache.GemFireCacheImpl.getInstance().getLogger().info("DEBUG MemLRUCC: overhead=" + size
+//         org.apache.geode.internal.cache.GemFireCacheImpl.getInstance().getLogger().info("DEBUG MemLRUCC: overhead=" + size
 //                                                     + " keySize=" + keySize
 //                                                     + " valueSize=" + valueSize);
         size += keySize;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLIFOClockHand.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLIFOClockHand.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLIFOClockHand.java
index 4299f1c..a8153e6 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLIFOClockHand.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLIFOClockHand.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
-import com.gemstone.gemfire.internal.cache.AbstractRegionEntry;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.cache.InternalRegionArguments;
+import org.apache.geode.internal.cache.AbstractRegionEntry;
 
 /**
  * NewLIFOClockHand holds the behavior for LIFO logic , Overwriting

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLRUClockHand.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLRUClockHand.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLRUClockHand.java
index 7d2591c..d9f61ab 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLRUClockHand.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/NewLRUClockHand.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.lru;
-
-import com.gemstone.gemfire.StatisticsFactory;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.*;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+package org.apache.geode.internal.cache.lru;
+
+import org.apache.geode.StatisticsFactory;
+import org.apache.geode.cache.Region;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.*;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 import org.apache.logging.log4j.Logger;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/OffHeapEvictor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/OffHeapEvictor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/OffHeapEvictor.java
index d147c57..5d80fa9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/OffHeapEvictor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/OffHeapEvictor.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-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.internal.cache.control.InternalResourceManager.ResourceType;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.offheap.MemoryAllocator;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.control.InternalResourceManager.ResourceType;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.offheap.MemoryAllocator;
 
 /**
  * Triggers centralized eviction(asynchronously) when the ResourceManager sends

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/lru/Sizeable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/Sizeable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/Sizeable.java
index be67ebe..84085c0 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/lru/Sizeable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/lru/Sizeable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.lru;
+package org.apache.geode.internal.cache.lru;
 
 /**
  * An interface that allows an object to define its own size.<br>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/operations/ContainsKeyOperationContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/operations/ContainsKeyOperationContext.java b/geode-core/src/main/java/org/apache/geode/internal/cache/operations/ContainsKeyOperationContext.java
index da2fcc7..31fd1a9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/operations/ContainsKeyOperationContext.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/operations/ContainsKeyOperationContext.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache.operations;
+package org.apache.geode.internal.cache.operations;
 
-import com.gemstone.gemfire.cache.operations.KeyOperationContext;
+import org.apache.geode.cache.operations.KeyOperationContext;
 
 /**
- * Encapsulates a {@link com.gemstone.gemfire.cache.operations.OperationContext.OperationCode#CONTAINS_KEY} region operation having the
+ * Encapsulates a {@link org.apache.geode.cache.operations.OperationContext.OperationCode#CONTAINS_KEY} region operation having the
  * key object for the pre-operation case.
  * 
  * @since GemFire 5.5

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/package.html b/geode-core/src/main/java/org/apache/geode/internal/cache/package.html
index bd8713e..650c0c7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/package.html
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/package.html
@@ -190,7 +190,7 @@ triggered.  Migration may also occur when a <code>Cache</code> exceeds
 its <code>maxParitionedData</code> threshold and when a new member
 that can host partitioned data joins the distributed system.  Each
 member is consulted to determine how much partitioned region data it
-is currently hosting and the com.gemstone.gemfire.cache.Cache#getMaxPartitionedData maximum amount of
+is currently hosting and the org.apache.geode.cache.Cache#getMaxPartitionedData maximum amount of
 partitioned region data it can host.  The largest bucket hosted by the
 VM is migrated to the member with the large percentage of space
 available for partitioned data.  This ensures that data is spread
@@ -199,13 +199,13 @@ available partitioned region data fills consistently.  Migration will
 continue until the amount of partitioned data hosted by the member
 initiating the migration falls below the average for all members.
 When a member that hosts partitions {@linkplain
-com.gemstone.gemfire.cache.Cache#close closes} its <code>Cache</code>,
+org.apache.geode.cache.Cache#close closes} its <code>Cache</code>,
 the partitions are migrated to other hosts.</P>
 
 <h3>High Availability</h3>
 
 The high availability (
-com.gemstone.gemfire.cache.PartitionAttributes#getRedundancy
+org.apache.geode.cache.PartitionAttributes#getRedundancy
 redundancy) feature of partitioned regions effects the implementation
 in a number of ways.  When a bucket is created, the implementation
 uses the migration algorithm to determine the location(s) of any

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/AllBucketProfilesUpdateMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/AllBucketProfilesUpdateMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/AllBucketProfilesUpdateMessage.java
index 8951a50..95aefa4 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/AllBucketProfilesUpdateMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/AllBucketProfilesUpdateMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,19 +24,19 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A Partitioned Region meta-data update message.  This is used to send 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BecomePrimaryBucketMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BecomePrimaryBucketMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BecomePrimaryBucketMessage.java
index 6cd5f2d..39d66d2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BecomePrimaryBucketMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BecomePrimaryBucketMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,22 +23,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * This message is sent to a recipient to make it become the primary for a

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/Bucket.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/Bucket.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/Bucket.java
index 77b1cd3..810a7e1 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/Bucket.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/Bucket.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisee;
-import com.gemstone.gemfire.internal.cache.DiskRegion;
-import com.gemstone.gemfire.internal.cache.persistence.PersistenceAdvisor;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.CacheDistributionAdvisee;
+import org.apache.geode.internal.cache.DiskRegion;
+import org.apache.geode.internal.cache.persistence.PersistenceAdvisor;
+import org.apache.geode.internal.cache.PartitionedRegion;
 
 /**
  * Represents a storage or meta-data container for a 
@@ -50,7 +50,7 @@ public interface Bucket extends CacheDistributionAdvisee {
   
   /**
    * Returns true if this bucket is currently backed by a {@link 
-   * com.gemstone.gemfire.internal.cache.BucketRegion}.
+   * org.apache.geode.internal.cache.BucketRegion}.
    */
   public boolean isHosting();
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
index d6eff09..ed5b208 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,15 +23,15 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message sent requesting that an evaluation of buckets be made to determine
@@ -47,7 +47,7 @@ public final class BucketBackupMessage extends PartitionMessage
   
   private int bucketId;
   /**
-   * Empty contstructor provided for {@link com.gemstone.gemfire.DataSerializer}
+   * Empty contstructor provided for {@link org.apache.geode.DataSerializer}
    */
   public BucketBackupMessage() {
     super();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketCountLoadProbe.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketCountLoadProbe.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketCountLoadProbe.java
index 07c9a1f..a0b766d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketCountLoadProbe.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketCountLoadProbe.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
 
 /**
  * A load probe which calculates the load of a pr using

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketProfileUpdateMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketProfileUpdateMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketProfileUpdateMessage.java
index 1cba153..aa5dbff 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketProfileUpdateMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketProfileUpdateMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,20 +23,20 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.RegionDestroyedException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor.BucketProfile;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.RegionDestroyedException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.BucketAdvisor.BucketProfile;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * A Partitioned Region meta-data update message.  This is used to send 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketSizeMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketSizeMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketSizeMessage.java
index 5309f1f..08f3892 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketSizeMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketSizeMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,23 +24,23 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-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.Assert;
-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.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message used to determine the number of bytes a Bucket consumes.
@@ -55,7 +55,7 @@ public final class BucketSizeMessage extends PartitionMessage
   private int bucketId;
   
   /**
-   * Empty contstructor provided for {@link com.gemstone.gemfire.DataSerializer}
+   * Empty contstructor provided for {@link org.apache.geode.DataSerializer}
    */
   public BucketSizeMessage() {
     super();
@@ -231,7 +231,7 @@ public final class BucketSizeMessage extends PartitionMessage
   }
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.partitioned.GetMessage.GetReplyMessage}
+   * org.apache.geode.internal.cache.partitioned.GetMessage.GetReplyMessage}
    * @since GemFire 5.0
    */
   public static class BucketSizeResponse extends ReplyProcessor21  {
@@ -267,7 +267,7 @@ public final class BucketSizeMessage extends PartitionMessage
       }
       catch (ReplyException e) {
         Throwable t = e.getCause();
-        if (t instanceof com.gemstone.gemfire.CancelException) {
+        if (t instanceof org.apache.geode.CancelException) {
           logger.debug("BucketSizeResponse got remote cancellation; forcing reattempt. {}", t.getMessage(), t);
           throw new ForceReattemptException(LocalizedStrings.BucketSizeMessage_BUCKETSIZERESPONSE_GOT_REMOTE_CACHECLOSEDEXCEPTION_FORCING_REATTEMPT.toLocalizedString(), t);
         }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/ContainsKeyValueMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/ContainsKeyValueMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/ContainsKeyValueMessage.java
index ffdfde0..c87127c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/ContainsKeyValueMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/ContainsKeyValueMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,27 +24,27 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-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.PrimaryBucketException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.cache.PrimaryBucketException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 public final class ContainsKeyValueMessage extends PartitionMessageWithDirectReply
   {
@@ -70,8 +70,8 @@ public final class ContainsKeyValueMessage extends PartitionMessageWithDirectRep
 
   /**
    * Sends a PartitionedRegion message for either
-   * {@link com.gemstone.gemfire.cache.Region#containsKey(Object)}or
-   * {@link com.gemstone.gemfire.cache.Region#containsValueForKey(Object)}
+   * {@link org.apache.geode.cache.Region#containsKey(Object)}or
+   * {@link org.apache.geode.cache.Region#containsValueForKey(Object)}
    * depending on the <code>valueCheck</code> argument
    * 
    * @param recipient
@@ -84,9 +84,9 @@ public final class ContainsKeyValueMessage extends PartitionMessageWithDirectRep
    *          the identity of the bucket to be queried
    * @param valueCheck
    *          true if
-   *          {@link com.gemstone.gemfire.cache.Region#containsValueForKey(Object)}
+   *          {@link org.apache.geode.cache.Region#containsValueForKey(Object)}
    *          is desired, false if
-   *          {@link com.gemstone.gemfire.cache.Region#containsKey(Object)}is
+   *          {@link org.apache.geode.cache.Region#containsKey(Object)}is
    *          desired
    * @return the processor used to read the returned keys
    * @throws ForceReattemptException if the peer is no longer available
@@ -276,7 +276,7 @@ public final class ContainsKeyValueMessage extends PartitionMessageWithDirectRep
 
   /**
    * A processor to capture the value returned by {@link 
-   * com.gemstone.gemfire.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueReplyMessage}
+   * org.apache.geode.internal.cache.partitioned.ContainsKeyValueMessage.ContainsKeyValueReplyMessage}
    * 
    * @since GemFire 5.0
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateBucketMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateBucketMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateBucketMessage.java
index 6a3f4c0..64d785b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateBucketMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateBucketMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,27 +23,27 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.PartitionedRegionStorageException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.DistributionStats;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.FixedPartitionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.Node;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.PartitionedRegionStorageException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.DistributionStats;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.FixedPartitionAttributesImpl;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.Node;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A request from an accessor to a datastore telling 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateMissingBucketsTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateMissingBucketsTask.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateMissingBucketsTask.java
index 8c0b8a0..d063404 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateMissingBucketsTask.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/CreateMissingBucketsTask.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
-import com.gemstone.gemfire.internal.cache.ColocationHelper;
-import com.gemstone.gemfire.internal.cache.PRHARedundancyProvider;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionStats;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion.RecoveryLock;
+import org.apache.geode.internal.cache.ColocationHelper;
+import org.apache.geode.internal.cache.PRHARedundancyProvider;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionStats;
+import org.apache.geode.internal.cache.PartitionedRegion.RecoveryLock;
 
 /**
  * A task for creating buckets in a child colocated region that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DeposePrimaryBucketMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DeposePrimaryBucketMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DeposePrimaryBucketMessage.java
index 0bda88f..c54fb7d 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DeposePrimaryBucketMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DeposePrimaryBucketMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -23,22 +23,22 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-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.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.BucketAdvisor;
-import com.gemstone.gemfire.internal.cache.ForceReattemptException;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.BucketAdvisor;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * Usage:

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyMessage.java
index 3bd32cc..2efa2d9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyMessage.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -24,42 +24,42 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryExistsException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Operation;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplySender;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.NanoTimer;
-import com.gemstone.gemfire.internal.cache.DataLocationException;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
-import com.gemstone.gemfire.internal.cache.EventID;
-import com.gemstone.gemfire.internal.cache.FilterRoutingInfo;
-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.PartitionedRegionHelper;
-import com.gemstone.gemfire.internal.cache.PrimaryBucketException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.versions.DiskVersionTag;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryExistsException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Operation;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplySender;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.NanoTimer;
+import org.apache.geode.internal.cache.DataLocationException;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EnumListenerEvent;
+import org.apache.geode.internal.cache.EventID;
+import org.apache.geode.internal.cache.FilterRoutingInfo;
+import org.apache.geode.internal.cache.ForceReattemptException;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.internal.cache.PartitionedRegionHelper;
+import org.apache.geode.internal.cache.PrimaryBucketException;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.versions.DiskVersionTag;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * A class that specifies a destroy operation.
@@ -192,7 +192,7 @@ public class DestroyMessage extends PartitionMessageWithDirectReply {
   
   /**
    * Sends a DestroyMessage
-   * {@link com.gemstone.gemfire.cache.Region#destroy(Object)}message to the
+   * {@link org.apache.geode.cache.Region#destroy(Object)}message to the
    * recipient
    * 
    * @param recipient the recipient of the message
@@ -200,7 +200,7 @@ public class DestroyMessage extends PartitionMessageWithDirectReply {
    *          the PartitionedRegion for which the destroy was performed
    * @param event the event causing this message
    * @return the processor used to await the potential
-   *         {@link com.gemstone.gemfire.cache.CacheException}
+   *         {@link org.apache.geode.cache.CacheException}
    * @throws ForceReattemptException if the peer is no longer available
    */
   public static DestroyResponse send(DistributedMember recipient,
@@ -593,7 +593,7 @@ public class DestroyMessage extends PartitionMessageWithDirectReply {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.ReplyMessage#getInlineProcess()
+     * @see org.apache.geode.distributed.internal.ReplyMessage#getInlineProcess()
      */
     @Override
     public boolean getInlineProcess() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyRegionOnDataStoreMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyRegionOnDataStoreMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyRegionOnDataStoreMessage.java
index 4454f81..0c4dec6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyRegionOnDataStoreMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DestroyRegionOnDataStoreMessage.java
@@ -14,28 +14,28 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.i18n.LogWriterI18n;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.i18n.LogWriterI18n;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.cache.PartitionedRegionDataStore;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.cache.PartitionedRegionDataStore;
 
 /**
  * A message sent to a data store telling that data store to globally
@@ -49,7 +49,7 @@ public final class DestroyRegionOnDataStoreMessage extends PartitionMessage
   private Object callbackArg;
 
   /**
-   * Empty contstructor provided for {@link com.gemstone.gemfire.DataSerializer}
+   * Empty contstructor provided for {@link org.apache.geode.DataSerializer}
    */
   public DestroyRegionOnDataStoreMessage() {
     super();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpAllPRConfigMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpAllPRConfigMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpAllPRConfigMessage.java
index ad725e1..1de43c8 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpAllPRConfigMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/DumpAllPRConfigMessage.java
@@ -14,25 +14,25 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache.partitioned;
+package org.apache.geode.internal.cache.partitioned;
 
 import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.cache.CacheException;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
+import org.apache.geode.cache.CacheException;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.log4j.LogMarker;
 
 /**
  * A message used for debugging purposes.  For example if a test
- * fails it can call {@link com.gemstone.gemfire.internal.cache.PartitionedRegion#sendDumpAllPartitionedRegions()} 
+ * fails it can call {@link org.apache.geode.internal.cache.PartitionedRegion#sendDumpAllPartitionedRegions()} 
  * which sends this message to all VMs that have that PartitionedRegion defined.
  * 
- * @see com.gemstone.gemfire.internal.cache.PartitionedRegion#sendDumpAllPartitionedRegions()
+ * @see org.apache.geode.internal.cache.PartitionedRegion#sendDumpAllPartitionedRegions()
  */
 public final class DumpAllPRConfigMessage extends PartitionMessage
   {


[10/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateStub.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateStub.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateStub.java
index 0b226e0..197111a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateStub.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXStateStub.java
@@ -17,7 +17,7 @@
 /**
  * File comment
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Collection;
 import java.util.HashMap;
@@ -26,24 +26,24 @@ import java.util.Map;
 import java.util.Set;
 import java.util.concurrent.locks.ReentrantLock;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.CommitConflictException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.Region.Entry;
-import com.gemstone.gemfire.cache.SynchronizationCommitConflictException;
-import com.gemstone.gemfire.cache.TransactionDataNodeHasDepartedException;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.TransactionException;
-import com.gemstone.gemfire.cache.TransactionId;
-import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyException;
-import com.gemstone.gemfire.distributed.internal.ReliableReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
-import com.gemstone.gemfire.internal.cache.tx.TXRegionStub;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.CommitConflictException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.Region.Entry;
+import org.apache.geode.cache.SynchronizationCommitConflictException;
+import org.apache.geode.cache.TransactionDataNodeHasDepartedException;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.TransactionException;
+import org.apache.geode.cache.TransactionId;
+import org.apache.geode.cache.UnsupportedOperationInTransactionException;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.ReliableReplyException;
+import org.apache.geode.distributed.internal.ReliableReplyProcessor21;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.cache.tier.sockets.VersionedObjectList;
+import org.apache.geode.internal.cache.tx.TXRegionStub;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * TXStateStub lives on the accessor node when we are remoting
@@ -146,7 +146,7 @@ public abstract class TXStateStub implements TXStateInterface {
 
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#destroyExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#destroyExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, java.lang.Object)
    */
   public void destroyExistingEntry(EntryEventImpl event, boolean cacheWrite,
       Object expectedOldValue) throws EntryNotFoundException {
@@ -159,7 +159,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getBeginTime()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getBeginTime()
    */
   public long getBeginTime() {
     // TODO Auto-generated method stub
@@ -167,14 +167,14 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getCache()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getCache()
    */
   public Cache getCache() {
     return this.proxy.getTxMgr().getCache();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getChanges()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getChanges()
    */
   public int getChanges() {
     // TODO Auto-generated method stub
@@ -182,7 +182,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getDeserializedValue(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getDeserializedValue(KeyInfo keyInfo,
                                      LocalRegion localRegion,
@@ -203,7 +203,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntry(KeyInfo keyInfo, LocalRegion r, boolean allowTombstones) {
     return getTXRegionStub(r).getEntry(keyInfo, allowTombstones);
@@ -216,35 +216,35 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEvent()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEvent()
    */
   public TXEvent getEvent() {
     throw new UnsupportedOperationException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getEvents()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getEvents()
    */
   public List getEvents() {
     throw new UnsupportedOperationException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getRegions()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getRegions()
    */
   public Collection<LocalRegion> getRegions() {
     throw new UnsupportedOperationException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getTransactionId()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getTransactionId()
    */
   public TransactionId getTransactionId() {
     return this.proxy.getTxId();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#invalidateExistingEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#invalidateExistingEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateExistingEntry(EntryEventImpl event,
       boolean invokeCallbacks, boolean forceNewEntry) {
@@ -257,21 +257,21 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgress()
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgress()
    */
   public boolean isInProgress() {
     return this.proxy.isInProgress();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#isInProgressAndSameAs(com.gemstone.gemfire.internal.cache.TXStateInterface)
+   * @see org.apache.geode.internal.cache.TXStateInterface#isInProgressAndSameAs(org.apache.geode.internal.cache.TXStateInterface)
    */
   public boolean isInProgressAndSameAs(TXStateInterface state) {
     throw new UnsupportedOperationException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#needsLargeModCount()
+   * @see org.apache.geode.internal.cache.TXStateInterface#needsLargeModCount()
    */
   public boolean needsLargeModCount() {
     // TODO Auto-generated method stub
@@ -279,7 +279,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#nextModSerialNum()
+   * @see org.apache.geode.internal.cache.TXStateInterface#nextModSerialNum()
    */
   public int nextModSerialNum() {
     // TODO Auto-generated method stub
@@ -287,14 +287,14 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#readRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#readRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState readRegion(LocalRegion r) {
     throw new UnsupportedOperationException();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#rmRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#rmRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public void rmRegion(LocalRegion r) {
     throw new UnsupportedOperationException();
@@ -315,7 +315,7 @@ public abstract class TXStateStub implements TXStateInterface {
   
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txPutEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txPutEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, boolean)
    */
   public boolean txPutEntry(EntryEventImpl event, boolean ifNew,
       boolean requireOldValue, boolean checkResources, Object expectedOldValue) {
@@ -323,7 +323,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txReadEntry(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txReadEntry(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public TXEntryState txReadEntry(KeyInfo entryKey, LocalRegion localRegion,
       boolean rememberRead,boolean createTxEntryIfAbsent) {
@@ -332,7 +332,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txReadRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txReadRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState txReadRegion(LocalRegion localRegion) {
     // TODO Auto-generated method stub
@@ -340,7 +340,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#txWriteRegion(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object)
+   * @see org.apache.geode.internal.cache.TXStateInterface#txWriteRegion(org.apache.geode.internal.cache.LocalRegion, java.lang.Object)
    */
   public TXRegionState txWriteRegion(LocalRegion localRegion, KeyInfo entryKey) {
     // TODO Auto-generated method stub
@@ -348,7 +348,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#writeRegion(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.TXStateInterface#writeRegion(org.apache.geode.internal.cache.LocalRegion)
    */
   public TXRegionState writeRegion(LocalRegion r) {
     // TODO Auto-generated method stub
@@ -356,28 +356,28 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#containsKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#containsKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsKey(KeyInfo keyInfo, LocalRegion localRegion) {
     return getTXRegionStub(localRegion).containsKey(keyInfo);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#containsValueForKey(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#containsValueForKey(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public boolean containsValueForKey(KeyInfo keyInfo, LocalRegion localRegion) {
     return getTXRegionStub(localRegion).containsValueForKey( keyInfo);
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#entryCount(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#entryCount(org.apache.geode.internal.cache.LocalRegion)
    */
   public int entryCount(LocalRegion localRegion) {
     return getTXRegionStub(localRegion).entryCount();
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#findObject(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#findObject(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object, boolean, boolean, java.lang.Object)
    */
   public Object findObject(KeyInfo keyInfo,
                            LocalRegion r,
@@ -393,7 +393,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getAdditionalKeysForIterator(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getAdditionalKeysForIterator(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getAdditionalKeysForIterator(LocalRegion currRgn) {
     // TODO Auto-generated method stub
@@ -401,7 +401,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryForIterator(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryForIterator(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, boolean)
    */
   public Object getEntryForIterator(KeyInfo keyInfo, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -409,7 +409,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getKeyForIterator(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getKeyForIterator(KeyInfo keyInfo, LocalRegion currRgn,
       boolean rememberReads, boolean allowTombstones) {
@@ -417,7 +417,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getValueInVM(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#getValueInVM(java.lang.Object, org.apache.geode.internal.cache.LocalRegion, boolean)
    */
   public Object getValueInVM(KeyInfo keyInfo, LocalRegion localRegion,
       boolean rememberRead) {
@@ -426,14 +426,14 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#isDeferredStats()
+   * @see org.apache.geode.internal.cache.InternalDataView#isDeferredStats()
    */
   public boolean isDeferredStats() {
     return true;
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntry(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntry(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntry(EntryEventImpl event, boolean ifNew, boolean ifOld,
       Object expectedOldValue, boolean requireOldValue, long lastModified,
@@ -443,7 +443,7 @@ public abstract class TXStateStub implements TXStateInterface {
 
   /*
    * (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getSerializedValue(com.gemstone.gemfire.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#getSerializedValue(org.apache.geode.internal.cache.LocalRegion, java.lang.Object, java.lang.Object)
    */
   public Object getSerializedValue(LocalRegion localRegion,
                                    KeyInfo key,
@@ -455,7 +455,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#putEntryOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#putEntryOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean, java.lang.Object, boolean, long, boolean)
    */
   public boolean putEntryOnRemote(EntryEventImpl event, boolean ifNew,
       boolean ifOld, Object expectedOldValue, boolean requireOldValue,
@@ -469,7 +469,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#destroyOnRemote(java.lang.Integer, com.gemstone.gemfire.internal.cache.EntryEventImpl, java.lang.Object)
+   * @see org.apache.geode.internal.cache.InternalDataView#destroyOnRemote(java.lang.Integer, org.apache.geode.internal.cache.EntryEventImpl, java.lang.Object)
    */
   public void destroyOnRemote(EntryEventImpl event, boolean cacheWrite,
       Object expectedOldValue) throws DataLocationException {
@@ -477,7 +477,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#invalidateOnRemote(com.gemstone.gemfire.internal.cache.EntryEventImpl, boolean, boolean)
+   * @see org.apache.geode.internal.cache.InternalDataView#invalidateOnRemote(org.apache.geode.internal.cache.EntryEventImpl, boolean, boolean)
    */
   public void invalidateOnRemote(EntryEventImpl event, boolean invokeCallbacks,
       boolean forceNewEntry) throws DataLocationException {
@@ -501,7 +501,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getBucketKeys(com.gemstone.gemfire.internal.cache.LocalRegion, int)
+   * @see org.apache.geode.internal.cache.InternalDataView#getBucketKeys(org.apache.geode.internal.cache.LocalRegion, int)
    */
   public Set getBucketKeys(LocalRegion localRegion, int bucketId, boolean allowTombstones) {
     PartitionedRegion pr = (PartitionedRegion)localRegion;
@@ -512,7 +512,7 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getEntryOnRemote(java.lang.Object, org.apache.geode.internal.cache.LocalRegion)
    */
   public Entry getEntryOnRemote(KeyInfo key, LocalRegion localRegion, boolean allowTombstones)
       throws DataLocationException {
@@ -520,14 +520,14 @@ public abstract class TXStateStub implements TXStateInterface {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.TXStateInterface#getSemaphore()
+   * @see org.apache.geode.internal.cache.TXStateInterface#getSemaphore()
    */
   public ReentrantLock getLock() {
     return proxy.getLock();
   }
   
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.InternalDataView#getRegionKeysForIteration(com.gemstone.gemfire.internal.cache.LocalRegion)
+   * @see org.apache.geode.internal.cache.InternalDataView#getRegionKeysForIteration(org.apache.geode.internal.cache.LocalRegion)
    */
   public Set getRegionKeysForIteration(LocalRegion currRegion) {
     return getTXRegionStub(currRegion).getRegionKeysForIteration(currRegion);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TXSynchronizationRunnable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXSynchronizationRunnable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXSynchronizationRunnable.java
index c353be9..5f80d5e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXSynchronizationRunnable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXSynchronizationRunnable.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * TXSynchronizationThread manages beforeCompletion and afterCompletion

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TestHeapThresholdObserver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TestHeapThresholdObserver.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TestHeapThresholdObserver.java
index f8a867d..f942536 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TestHeapThresholdObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TestHeapThresholdObserver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Test only hand back object passed to

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TimestampedEntryEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TimestampedEntryEventImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TimestampedEntryEventImpl.java
index ce5cfab..b1138da 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TimestampedEntryEventImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TimestampedEntryEventImpl.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.cache.util.TimestampedEntryEvent;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.cache.util.TimestampedEntryEvent;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * A subclass of EntryEventImpl used in WAN conflict resolution
@@ -40,7 +40,7 @@ public class TimestampedEntryEventImpl extends EntryEventImpl implements
     this.oldTimestamp = oldTimestamp;
   }
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.util.TimestampedEntryEvent#getNewDistributedSystemID()
+   * @see org.apache.geode.internal.cache.util.TimestampedEntryEvent#getNewDistributedSystemID()
    */
   @Override
   public int getNewDistributedSystemID() {
@@ -48,7 +48,7 @@ public class TimestampedEntryEventImpl extends EntryEventImpl implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.util.TimestampedEntryEvent#getOldDistributedSystemID()
+   * @see org.apache.geode.internal.cache.util.TimestampedEntryEvent#getOldDistributedSystemID()
    */
   @Override
   public int getOldDistributedSystemID() {
@@ -56,7 +56,7 @@ public class TimestampedEntryEventImpl extends EntryEventImpl implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.util.TimestampedEntryEvent#getNewTimestamp()
+   * @see org.apache.geode.internal.cache.util.TimestampedEntryEvent#getNewTimestamp()
    */
   @Override
   public long getNewTimestamp() {
@@ -64,7 +64,7 @@ public class TimestampedEntryEventImpl extends EntryEventImpl implements
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.util.TimestampedEntryEvent#getOldTimestamp()
+   * @see org.apache.geode.internal.cache.util.TimestampedEntryEvent#getOldTimestamp()
    */
   @Override
   public long getOldTimestamp() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/Token.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/Token.java b/geode-core/src/main/java/org/apache/geode/internal/cache/Token.java
index 0f731e0..5be802d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/Token.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/Token.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.DSCODE;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
+import org.apache.geode.internal.DSCODE;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
 
 import java.io.DataInput;
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TombstoneService.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TombstoneService.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TombstoneService.java
index 2241b33..ede2e89 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TombstoneService.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TombstoneService.java
@@ -14,24 +14,24 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
-
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.distributed.internal.CacheTime;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.cache.versions.CompactVersionHolder;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.logging.LoggingThreadGroup;
-import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
-import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
-import com.gemstone.gemfire.internal.size.ReflectionSingleObjectSizer;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantLock;
+package org.apache.geode.internal.cache;
+
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.CancelException;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.distributed.internal.CacheTime;
+import org.apache.geode.distributed.internal.DistributionConfig;
+import org.apache.geode.internal.cache.versions.CompactVersionHolder;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.logging.LoggingThreadGroup;
+import org.apache.geode.internal.logging.log4j.LocalizedMessage;
+import org.apache.geode.internal.logging.log4j.LogMarker;
+import org.apache.geode.internal.size.ReflectionSingleObjectSizer;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantLock;
 import org.apache.logging.log4j.Logger;
 
 import java.util.*;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TransactionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TransactionMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TransactionMessage.java
index 3c7c93a..b1ea33e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TransactionMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TransactionMessage.java
@@ -17,10 +17,10 @@
 /**
  * 
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
 
 /**
  * Messages that carry transaction information will implement this interface

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/TxEntryFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TxEntryFactory.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TxEntryFactory.java
index db93886..f80236b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TxEntryFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TxEntryFactory.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UnsharedImageState.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UnsharedImageState.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UnsharedImageState.java
index 9920388..ca1fcc7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UnsharedImageState.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UnsharedImageState.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.Iterator;
 import java.util.Set;
@@ -24,15 +24,15 @@ import java.util.concurrent.ConcurrentMap;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelCriterion;
-import com.gemstone.gemfire.cache.DiskAccessException;
-import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
-import com.gemstone.gemfire.internal.cache.versions.VersionSource;
-import com.gemstone.gemfire.internal.cache.versions.VersionTag;
-import com.gemstone.gemfire.internal.concurrent.ConcurrentHashSet;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableNonReentrantLock;
-import com.gemstone.gemfire.internal.util.concurrent.StoppableReentrantReadWriteLock;
+import org.apache.geode.CancelCriterion;
+import org.apache.geode.cache.DiskAccessException;
+import org.apache.geode.internal.cache.versions.RegionVersionVector;
+import org.apache.geode.internal.cache.versions.VersionSource;
+import org.apache.geode.internal.cache.versions.VersionTag;
+import org.apache.geode.internal.concurrent.ConcurrentHashSet;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.util.concurrent.StoppableNonReentrantLock;
+import org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock;
 
 /**
  * Used on distributed replicated regions to track GII and various state.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateAttributesProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateAttributesProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateAttributesProcessor.java
index 9754ab9..bf543b6 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateAttributesProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateAttributesProcessor.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -27,25 +27,25 @@ import java.util.Set;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.CancelException;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisee;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor;
-import com.gemstone.gemfire.distributed.internal.DistributionAdvisor.Profile;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.distributed.internal.DistributionMessage;
-import com.gemstone.gemfire.distributed.internal.HighPriorityDistributionMessage;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.distributed.internal.MessageWithReply;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.distributed.internal.ReplyProcessor21;
-import com.gemstone.gemfire.distributed.internal.membership.InternalDistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.DSFIDFactory;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.CancelException;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DistributionAdvisee;
+import org.apache.geode.distributed.internal.DistributionAdvisor;
+import org.apache.geode.distributed.internal.DistributionAdvisor.Profile;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.distributed.internal.DistributionMessage;
+import org.apache.geode.distributed.internal.HighPriorityDistributionMessage;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.distributed.internal.MessageWithReply;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.distributed.internal.ReplyProcessor21;
+import org.apache.geode.distributed.internal.membership.InternalDistributedMember;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.DSFIDFactory;
+import org.apache.geode.internal.logging.LogService;
 
 /**
  * This class is a bit misnamed. It really has more with pushing
@@ -438,7 +438,7 @@ public class UpdateAttributesProcessor {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.ReplyMessage#getInlineProcess()
+     * @see org.apache.geode.distributed.internal.ReplyMessage#getInlineProcess()
      * ProfileReplyMessages must be processed in-line and not in a pool to
      * keep partitioned region bucket profile exchange from swamping the
      * high priority pool and not allowing other profile exchanges through.
@@ -530,7 +530,7 @@ public class UpdateAttributesProcessor {
     }
 
     /* (non-Javadoc)
-     * @see com.gemstone.gemfire.distributed.internal.ReplyMessage#getInlineProcess()
+     * @see org.apache.geode.distributed.internal.ReplyMessage#getInlineProcess()
      * ProfilesReplyMessages must be processed in-line and not in a pool to
      * keep partitioned region bucket profile exchange from swamping the
      * high priority pool and not allowing other profile exchanges through.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateEntryVersionOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateEntryVersionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateEntryVersionOperation.java
index 23fb300..984f245 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateEntryVersionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateEntryVersionOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -25,17 +25,17 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.CacheEvent;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.cache.TimeoutException;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.DistributionManager;
-import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.CacheEvent;
+import org.apache.geode.cache.CacheWriterException;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.cache.TimeoutException;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.DistributionManager;
+import org.apache.geode.internal.cache.versions.ConcurrentCacheModificationException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.annotations.Retained;
 
 /**
  * This operation updates Version stamp of an entry if entry is available and
@@ -54,7 +54,7 @@ public class UpdateEntryVersionOperation extends DistributedCacheOperation {
   }
 
   /* (non-Javadoc)
-   * @see com.gemstone.gemfire.internal.cache.DistributedCacheOperation#createMessage()
+   * @see org.apache.geode.internal.cache.DistributedCacheOperation#createMessage()
    */
   @Override
   protected CacheOperationMessage createMessage() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateOperation.java
index e60cda3..90d9a1a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UpdateOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -26,30 +26,30 @@ import java.util.List;
 
 import org.apache.logging.log4j.Logger;
 
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.InvalidDeltaException;
-import com.gemstone.gemfire.cache.DataPolicy;
-import com.gemstone.gemfire.cache.EntryNotFoundException;
-import com.gemstone.gemfire.distributed.internal.ConflationKey;
-import com.gemstone.gemfire.distributed.internal.DM;
-import com.gemstone.gemfire.distributed.internal.DirectReplyProcessor;
-import com.gemstone.gemfire.distributed.internal.ReplyException;
-import com.gemstone.gemfire.distributed.internal.ReplyMessage;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.InternalDataSerializer;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.NewValueImporter;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl.SerializedCacheValueImpl;
-import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.logging.LogService;
-import com.gemstone.gemfire.internal.offheap.MemoryAllocatorImpl;
-import com.gemstone.gemfire.internal.offheap.StoredObject;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.BlobHelper;
-import com.gemstone.gemfire.internal.util.Breadcrumbs;
-import static com.gemstone.gemfire.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.InvalidDeltaException;
+import org.apache.geode.cache.DataPolicy;
+import org.apache.geode.cache.EntryNotFoundException;
+import org.apache.geode.distributed.internal.ConflationKey;
+import org.apache.geode.distributed.internal.DM;
+import org.apache.geode.distributed.internal.DirectReplyProcessor;
+import org.apache.geode.distributed.internal.ReplyException;
+import org.apache.geode.distributed.internal.ReplyMessage;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.InternalDataSerializer;
+import org.apache.geode.internal.cache.EntryEventImpl.NewValueImporter;
+import org.apache.geode.internal.cache.EntryEventImpl.SerializedCacheValueImpl;
+import org.apache.geode.internal.cache.tier.sockets.ClientProxyMembershipID;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.logging.LogService;
+import org.apache.geode.internal.offheap.MemoryAllocatorImpl;
+import org.apache.geode.internal.offheap.StoredObject;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.BlobHelper;
+import org.apache.geode.internal.util.Breadcrumbs;
+import static org.apache.geode.internal.offheap.annotations.OffHeapIdentifier.ENTRY_EVENT_NEW_VALUE;
 
 /**
  * Handles distribution messaging for updating an entry in a region.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedDiskStoreAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedDiskStoreAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedDiskStoreAttributes.java
index ea403b0..559a97e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedDiskStoreAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedDiskStoreAttributes.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.lang.reflect.Field;
 import java.lang.reflect.InvocationTargetException;
 import java.lang.reflect.Method;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.internal.Assert;
 
 /**
  * UserSpecifiedDiskStoreAttributes provides an way to detect departures from default attribute values.
  * It may be used when collecting attributes from an XML parser or from attribute changes made using the
- * {@link com.gemstone.gemfire.cache.DiskStoreFactory}.  Its initial usage was to validate
+ * {@link org.apache.geode.cache.DiskStoreFactory}.  Its initial usage was to validate
  * when a user set a value which should not be set (for DiskStore).
  * 
  * @since GemFire prPersistSprint2

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedRegionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedRegionAttributes.java b/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedRegionAttributes.java
index 1a35812..0c0242b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedRegionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/UserSpecifiedRegionAttributes.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.lang.reflect.Field;
 import java.lang.reflect.InvocationTargetException;
 import java.lang.reflect.Method;
 import java.util.List;
 
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.internal.Assert;
 
 /**
  * UserSpecifiedRegionAttributes provides an way to detect departures from default attribute values.
  * It may be used when collecting attributes from an XML parser or from attribute changes made using the
- * {@link com.gemstone.gemfire.cache.AttributesFactory}.  Its initial usage was to validate
+ * {@link org.apache.geode.cache.AttributesFactory}.  Its initial usage was to validate
  * when a user set a value which should not be set (for PartitionedRegions).
  * 
  * @since GemFire 5.1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMCachedDeserializable.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMCachedDeserializable.java
index 61ac6f3..c598eec 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMCachedDeserializable.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMCachedDeserializable.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 
-import com.gemstone.gemfire.CopyHelper;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.internal.DataSerializableFixedID;
-import com.gemstone.gemfire.internal.Version;
-import com.gemstone.gemfire.internal.cache.lru.LRUEntry;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.lang.StringUtils;
-import com.gemstone.gemfire.pdx.PdxInstance;
+import org.apache.geode.CopyHelper;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.cache.Region;
+import org.apache.geode.internal.DataSerializableFixedID;
+import org.apache.geode.internal.Version;
+import org.apache.geode.internal.cache.lru.LRUEntry;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.lang.StringUtils;
+import org.apache.geode.pdx.PdxInstance;
 
 /**
  * The first time someone asks this instance for its Object it will deserialize
@@ -86,7 +86,7 @@ public final class VMCachedDeserializable implements CachedDeserializable, DataS
   public Object getDeserializedValue(Region r, RegionEntry re) {
     Object v = this.value;
     if (v instanceof byte[]) {
-//       com.gemstone.gemfire.internal.cache.GemFireCache.getInstance().getLogger().info("DEBUG getDeserializedValue r=" + r + " re=" + re, new RuntimeException("STACK"));
+//       org.apache.geode.internal.cache.GemFireCache.getInstance().getLogger().info("DEBUG getDeserializedValue r=" + r + " re=" + re, new RuntimeException("STACK"));
       LRUEntry le = null;
       if (re != null) {
         assert r != null;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMLRURegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMLRURegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMLRURegionMap.java
index 8adcb06..5909eda 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMLRURegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMLRURegionMap.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
-import com.gemstone.gemfire.internal.cache.lru.*;
-//import com.gemstone.gemfire.internal.util.Sizeof;
+import org.apache.geode.internal.cache.lru.*;
+//import org.apache.geode.internal.util.Sizeof;
 
 /**
  * Internal implementation of {@link RegionMap} for regions stored

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMRegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMRegionMap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMRegionMap.java
index d5122c7..8996adf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMRegionMap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMRegionMap.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Internal implementation of {@link RegionMap} for regions stored

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntry.java
index 817567b..1b27494 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeap.java
index cb8898d..776cb2b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapIntKey.java
index cfd1e2b..5f1188e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapIntKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapLongKey.java
index 12492ad..de85fcf 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapLongKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapObjectKey.java
index 5e2dc46..6009848 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapObjectKey.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey1.java
index 99fe18a..4b23625 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey1.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey2.java
index 2fa5d34..215d96b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapStringKey2.java
@@ -14,16 +14,16 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapUUIDKey.java
index b92166d..562ef9d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryHeapUUIDKey.java
@@ -14,17 +14,17 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeap.java
index e00bcb8..0f32d0e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapIntKey.java
index d3809cf..f861a37 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapIntKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapLongKey.java
index c100fbb..3e3bca9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapLongKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapObjectKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapObjectKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapObjectKey.java
index ea2d9df..f83fae7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapObjectKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapObjectKey.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey1.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey1.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey1.java
index 84a5349..38d44a2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey1.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey1.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey2.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey2.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey2.java
index 6ada0c4..039523c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey2.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapStringKey2.java
@@ -14,20 +14,20 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapUUIDKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapUUIDKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapUUIDKey.java
index 7013e68..333a459 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapUUIDKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskLRURegionEntryOffHeapUUIDKey.java
@@ -14,21 +14,21 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.UUID;
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.cache.lru.LRUClockNode;
-import com.gemstone.gemfire.internal.cache.lru.NewLRUClockHand;
-import com.gemstone.gemfire.internal.offheap.OffHeapRegionEntryHelper;
-import com.gemstone.gemfire.internal.offheap.annotations.Released;
-import com.gemstone.gemfire.internal.offheap.annotations.Retained;
-import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.cache.lru.LRUClockNode;
+import org.apache.geode.internal.cache.lru.NewLRUClockHand;
+import org.apache.geode.internal.offheap.OffHeapRegionEntryHelper;
+import org.apache.geode.internal.offheap.annotations.Released;
+import org.apache.geode.internal.offheap.annotations.Retained;
+import org.apache.geode.internal.offheap.annotations.Unretained;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntry.java
index 6efa75a..4652d84 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 /**
  * Implementation class of RegionEntry interface.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeap.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeap.java
index 879ffb0..fb3d6f9 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeap.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeap.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapIntKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapIntKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapIntKey.java
index 2a2cf72..e83284a 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapIntKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapIntKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapLongKey.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapLongKey.java b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapLongKey.java
index dd883fa..23855de 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapLongKey.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/VMStatsDiskRegionEntryHeapLongKey.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.internal.cache;
+package org.apache.geode.internal.cache;
 // DO NOT modify this class. It was generated from LeafRegionEntry.cpp
 import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
 import java.util.concurrent.atomic.AtomicLongFieldUpdater;
-import com.gemstone.gemfire.internal.cache.lru.EnableLRU;
-import com.gemstone.gemfire.internal.cache.persistence.DiskRecoveryStore;
-import com.gemstone.gemfire.internal.InternalStatisticsDisabledException;
-import com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
+import org.apache.geode.internal.cache.lru.EnableLRU;
+import org.apache.geode.internal.cache.persistence.DiskRecoveryStore;
+import org.apache.geode.internal.InternalStatisticsDisabledException;
+import org.apache.geode.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry;
 // macros whose definition changes this class:
 // disk: DISK
 // lru: LRU


[42/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
index e21b45b..9b631a1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
index 4292d03..610eb4c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 
 /** Thrown when attempting to create a {@link Cache} if one already exists.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheFactory.java b/geode-core/src/main/java/org/apache/geode/cache/CacheFactory.java
index 991b27f..6d3fd4b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheFactory.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.distributed.ConfigurationProperties;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.GemFireVersion;
-import com.gemstone.gemfire.internal.cache.CacheConfig;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.internal.jndi.JNDIInvoker;
-import com.gemstone.gemfire.pdx.PdxInstance;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+import org.apache.geode.distributed.ConfigurationProperties;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.GemFireVersion;
+import org.apache.geode.internal.cache.CacheConfig;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.jndi.JNDIInvoker;
+import org.apache.geode.pdx.PdxInstance;
+import org.apache.geode.pdx.PdxSerializer;
 
 
 /**
- * Factory class used to create the singleton {@link Cache cache} and connect to the GemFire singleton {@link DistributedSystem distributed system}. If the application wants to connect to GemFire as a client it should use {@link com.gemstone.gemfire.cache.client.ClientCacheFactory} instead.
+ * Factory class used to create the singleton {@link Cache cache} and connect to the GemFire singleton {@link DistributedSystem distributed system}. If the application wants to connect to GemFire as a client it should use {@link org.apache.geode.cache.client.ClientCacheFactory} instead.
 <p> Once the factory has been configured using its {@link #set(String, String)} method you produce a {@link Cache} by calling the {@link #create()} method.
  * <p>
  * To get the existing unclosed singleton cache instance call {@link #getAnyInstance}.
@@ -323,7 +323,7 @@ public class CacheFactory {
    *  @param readSerialized true to prefer PdxInstance
    *  @return this CacheFactory 
    *  @since GemFire 6.6
-   *  @see com.gemstone.gemfire.pdx.PdxInstance 
+   *  @see org.apache.geode.pdx.PdxInstance 
    */
   public  CacheFactory setPdxReadSerialized(boolean readSerialized) {
     this.cacheConfig.setPdxReadSerialized(readSerialized);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheListener.java b/geode-core/src/main/java/org/apache/geode/cache/CacheListener.java
index 16966ff..db4bb3c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheListener.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * <p>
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.cache;
  * 
  * <p>
  * Instead of implementing this interface it is recommended that you extend the
- * {@link com.gemstone.gemfire.cache.util.CacheListenerAdapter} class.
+ * {@link org.apache.geode.cache.util.CacheListenerAdapter} class.
  * </p>
  * 
  * <h4>Avoiding the risk of deadlock</h4>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheLoader.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheLoader.java b/geode-core/src/main/java/org/apache/geode/cache/CacheLoader.java
index 2def607..7bb30c7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheLoader.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheLoader.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Allows data from outside of the VM to be placed into a region.  
- * When {@link com.gemstone.gemfire.cache.Region#get(Object)} is called for a region
+ * When {@link org.apache.geode.cache.Region#get(Object)} is called for a region
  * entry that has a <code>null</code> value, the 
  * {@link CacheLoader#load load} method of the
  * region's cache loader is invoked.  The <code>load</code> method

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheLoaderException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheLoaderException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheLoaderException.java
index 6261923..30e8ebe 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheLoaderException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheLoaderException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown from the {@link CacheLoader#load} method indicating that an error
  * occurred when a CacheLoader was attempting to load a value. This
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.cache;
  *
  *
  *
- * @see com.gemstone.gemfire.cache.Region#get(Object)
+ * @see org.apache.geode.cache.Region#get(Object)
  * @see CacheLoader#load
  * @since GemFire 3.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheRuntimeException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheRuntimeException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheRuntimeException.java
index 5f8c71e..9040596 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheRuntimeException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheRuntimeException.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /** A generic runtime exception that indicates
  * a cache error has occurred. All the other runtime cache exceptions are the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheStatistics.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/CacheStatistics.java
index a996ae8..5738c30 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Defines common statistics information

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java b/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
index ef9a93e..90651f3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.concurrent.TimeUnit;
 
@@ -66,7 +66,7 @@ import java.util.concurrent.TimeUnit;
  * 
  *  <p>To aid in creating copies, the "copy on read"
  *  <code>Cache</code> attribute and the {@link
- *  com.gemstone.gemfire.CopyHelper#copy} method are provided.
+ *  org.apache.geode.CopyHelper#copy} method are provided.
  *  The following is a Read Committed safe example using the
  *  <code>CopyHelper.copy</code> method.
  * 
@@ -87,7 +87,7 @@ import java.util.concurrent.TimeUnit;
  * (see {@link AttributesFactory} for Scope).  For both scopes, a
  * consistent configuration (per VM) is enforced.
  * 
- * <p>Global Regions, client Regions (see com.gemstone.gemfire.cache.client package)
+ * <p>Global Regions, client Regions (see org.apache.geode.cache.client package)
  * and persistent Regions (see {@link DiskWriteAttributes}) do not
  * support transactions.
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java b/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
index 574cc3b..318fed0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** A user-defined object defined in the {@link RegionAttributes} that is
  * called synchronously before a region or entry in the cache is

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
index ca672ff..081cbc3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * An exception thrown by a <code>CacheWriter</code> method. This exception
@@ -24,11 +24,11 @@ package com.gemstone.gemfire.cache;
  *
  *
  * @see CacheWriter
- * @see com.gemstone.gemfire.cache.Region#put(Object, Object)
- * @see com.gemstone.gemfire.cache.Region#destroy(Object)
- * @see com.gemstone.gemfire.cache.Region#create(Object, Object)
- * @see com.gemstone.gemfire.cache.Region#destroyRegion()
- * @see com.gemstone.gemfire.cache.Region#get(Object)
+ * @see org.apache.geode.cache.Region#put(Object, Object)
+ * @see org.apache.geode.cache.Region#destroy(Object)
+ * @see org.apache.geode.cache.Region#create(Object, Object)
+ * @see org.apache.geode.cache.Region#destroyRegion()
+ * @see org.apache.geode.cache.Region#get(Object)
  * @since GemFire 3.0
  */
 public class CacheWriterException extends OperationAbortedException {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
index 69f2430..c6db5c7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Thrown when a problem is encountered while parsing a <A

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java b/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
index 60673b8..321791e 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Class <code>ClientSession</code> represents a client connection on the
@@ -36,9 +36,9 @@ package com.gemstone.gemfire.cache;
  * </pre>
  * 
  * @since GemFire 6.0
- * @see com.gemstone.gemfire.cache.server.CacheServer#getClientSession(String)
+ * @see org.apache.geode.cache.server.CacheServer#getClientSession(String)
  *      getClientSession
- * @see com.gemstone.gemfire.cache.server.CacheServer#getClientSession(com.gemstone.gemfire.distributed.DistributedMember)
+ * @see org.apache.geode.cache.server.CacheServer#getClientSession(org.apache.geode.distributed.DistributedMember)
  *      getClientSession
  *
  */
@@ -52,7 +52,7 @@ public interface ClientSession {
    * @param keyOfInterest
    *          The key on which to register interest
    * @param policy
-   *          The {@link com.gemstone.gemfire.cache.InterestResultPolicy}. Note:
+   *          The {@link org.apache.geode.cache.InterestResultPolicy}. Note:
    *          For the special token 'ALL_KEYS' and lists of keys, values are not
    *          pushed to the client.
    * @param isDurable
@@ -71,7 +71,7 @@ public interface ClientSession {
    * @param keyOfInterest
    *          The key to on which to register interest
    * @param policy
-   *          The {@link com.gemstone.gemfire.cache.InterestResultPolicy}. Note:
+   *          The {@link org.apache.geode.cache.InterestResultPolicy}. Note:
    *          For the special token 'ALL_KEYS' and lists of keys, values are not
    *          pushed to the client.
    * @param isDurable

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
index 7e271e5..be3575f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown when a commit fails due to a write conflict.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
index 9649bac..eea0b56 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
index a708f42..26544e8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Thrown when a commit fails to complete due to errors

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java b/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
index 94b73c0..25f89eb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * This is the contract that a <code>custom-expiry</code> element must honor.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
index e9bde30..8d1c2e0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
@@ -16,8 +16,8 @@
  */
 
 
-package com.gemstone.gemfire.cache;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+package org.apache.geode.cache;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Declarable.java b/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
index 57d0dd4..113d098 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Properties;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java b/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
index e8787da..9571f93 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.IOException;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java b/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
index 2ccb84c..f425b90 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.File;
 import java.util.UUID;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DiskStoreFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskStoreFactory.java b/geode-core/src/main/java/org/apache/geode/cache/DiskStoreFactory.java
index 620c79f..3956682 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskStoreFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskStoreFactory.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
+import org.apache.geode.distributed.internal.DistributionConfig;
 
 import java.io.File;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributes.java
index 426b402..bc42112 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributes.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Immutable parameter object for describing how {@linkplain

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
index 4060ffb..f56fc8d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 import java.util.Properties;
 
-import com.gemstone.gemfire.internal.cache.DiskWriteAttributesImpl;
-import com.gemstone.gemfire.internal.cache.xmlcache.CacheXml;
+import org.apache.geode.internal.cache.DiskWriteAttributesImpl;
+import org.apache.geode.internal.cache.xmlcache.CacheXml;
 
 /**
  * Factory for getting DiskWriteAttribute objects

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DuplicatePrimaryPartitionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DuplicatePrimaryPartitionException.java b/geode-core/src/main/java/org/apache/geode/cache/DuplicatePrimaryPartitionException.java
index f5ecd76..74a1753 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DuplicatePrimaryPartitionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DuplicatePrimaryPartitionException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.GemFireException;
+import org.apache.geode.GemFireException;
 
 /**
  * This exception is thrown when two nodes are defined with same primary

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
index 1f449cd..3cfa73b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.File;
 import java.io.IOException;
@@ -26,29 +26,29 @@ import java.util.List;
 import java.util.Set;
 import java.util.TreeMap;
 
-import com.gemstone.gemfire.InternalGemFireError;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.client.Pool;
-import com.gemstone.gemfire.cache.client.PoolManager;
-import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
-import com.gemstone.gemfire.cache.wan.GatewaySender;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.DistributedRegion;
-import com.gemstone.gemfire.internal.cache.DynamicRegionAttributes;
-import com.gemstone.gemfire.internal.cache.DynamicRegionFactoryImpl;
-import com.gemstone.gemfire.internal.cache.EntryEventImpl;
-import com.gemstone.gemfire.internal.cache.EnumListenerEvent;
-import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
-import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.InitialImageOperation;
-import com.gemstone.gemfire.internal.cache.InternalRegionArguments;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.RegionEventImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.security.GemFireSecurityException;
+import org.apache.geode.InternalGemFireError;
+import org.apache.geode.SystemFailure;
+import org.apache.geode.cache.client.Pool;
+import org.apache.geode.cache.client.PoolManager;
+import org.apache.geode.cache.client.internal.ServerRegionProxy;
+import org.apache.geode.cache.wan.GatewaySender;
+import org.apache.geode.distributed.DistributedMember;
+import org.apache.geode.distributed.internal.InternalDistributedSystem;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.internal.cache.DistributedRegion;
+import org.apache.geode.internal.cache.DynamicRegionAttributes;
+import org.apache.geode.internal.cache.DynamicRegionFactoryImpl;
+import org.apache.geode.internal.cache.EntryEventImpl;
+import org.apache.geode.internal.cache.EnumListenerEvent;
+import org.apache.geode.internal.cache.EvictionAttributesImpl;
+import org.apache.geode.internal.cache.GemFireCacheImpl;
+import org.apache.geode.internal.cache.InitialImageOperation;
+import org.apache.geode.internal.cache.InternalRegionArguments;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.RegionEventImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.security.GemFireSecurityException;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionListener.java b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionListener.java
index e679cb7..b8a47de 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DynamicRegionListener.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * <code>DynamicRegionListener</code> is an interface that can be

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryDestroyedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryDestroyedException.java b/geode-core/src/main/java/org/apache/geode/cache/EntryDestroyedException.java
index 6ae0227..2958ad0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryDestroyedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryDestroyedException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 /**
  * Indicates that a method was invoked on an entry that has been destroyed.
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryEvent.java b/geode-core/src/main/java/org/apache/geode/cache/EntryEvent.java
index 84eec6e..8dda363 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryEvent.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 //import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/EntryExistsException.java
index 14e4146..15f915f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryExistsException.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown when attempting to create a <code>Region.Entry</code> that already
  * exists in the <code>Region</code>.
  *
- * @see com.gemstone.gemfire.cache.Region#create(Object, Object)
+ * @see org.apache.geode.cache.Region#create(Object, Object)
  * @see Region.Entry
  * @since GemFire 3.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundException.java b/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundException.java
index 8415f49..ddc666a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundException.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Thrown when an operation is invoked on <code>Region</code> for an entry that
  * doesn't exist in the <code>Region</code>. This exception is <i>not</i>
- * thrown by {@link com.gemstone.gemfire.cache.Region#get(Object)} or {@link Region#getEntry}.
+ * thrown by {@link org.apache.geode.cache.Region#get(Object)} or {@link Region#getEntry}.
  *
  *
  *
- * @see com.gemstone.gemfire.cache.Region#invalidate(Object)
- * @see com.gemstone.gemfire.cache.Region#destroy(Object)
+ * @see org.apache.geode.cache.Region#invalidate(Object)
+ * @see org.apache.geode.cache.Region#destroy(Object)
  * @see Region.Entry
  * @since GemFire 3.0
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundInRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundInRegion.java b/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundInRegion.java
index 2b848ef..17105b1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundInRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryNotFoundInRegion.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.GemFireException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.InternalGemFireError;
+import org.apache.geode.GemFireException;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.InternalGemFireError;
 
 /**
  * @deprecated this class is no longer in use

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EntryOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EntryOperation.java b/geode-core/src/main/java/org/apache/geode/cache/EntryOperation.java
index 2e44ef8..90b0485 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/EntryOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EntryOperation.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Gemfire Context passed to <code>PartitionResolver</code> to compute the

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
index 8bc1aaf..d9812f7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import javax.print.attribute.EnumSyntax;
 /**
- * The action that an {@link com.gemstone.gemfire.cache.EvictionAlgorithm} takes.
+ * The action that an {@link org.apache.geode.cache.EvictionAlgorithm} takes.
  * @since GemFire 5.0
- * @see com.gemstone.gemfire.cache.EvictionAlgorithm
- * @see com.gemstone.gemfire.internal.cache.EvictionAttributesImpl
+ * @see org.apache.geode.cache.EvictionAlgorithm
+ * @see org.apache.geode.internal.cache.EvictionAttributesImpl
  */
 public final class EvictionAction extends EnumSyntax
 {
@@ -30,7 +30,7 @@ public final class EvictionAction extends EnumSyntax
    */
   public static final EvictionAction NONE = new EvictionAction(0);
   
-  /** Perform a {@link com.gemstone.gemfire.cache.Region#localDestroy(Object)
+  /** Perform a {@link org.apache.geode.cache.Region#localDestroy(Object)
    * localDestory} on the least recently used region entry. */
   public static final EvictionAction LOCAL_DESTROY = new EvictionAction(1);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
index 0ec010e..e9be783 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAlgorithm.java
@@ -14,15 +14,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import javax.print.attribute.EnumSyntax;
 
-/** The algorithm used to determine when to perform an {@link com.gemstone.gemfire.cache.EvictionAction}
+/** The algorithm used to determine when to perform an {@link org.apache.geode.cache.EvictionAction}
  * 
  * @since GemFire 5.0
- * @see com.gemstone.gemfire.cache.EvictionAction
- * @see com.gemstone.gemfire.internal.cache.EvictionAttributesImpl
+ * @see org.apache.geode.cache.EvictionAction
+ * @see org.apache.geode.internal.cache.EvictionAttributesImpl
  */
 public final class EvictionAlgorithm extends EnumSyntax
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributes.java
index 5f086ca..bd65fd8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributes.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.cache.util.ObjectSizer;
-import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.cache.util.ObjectSizer;
+import org.apache.geode.internal.cache.EvictionAttributesImpl;
 
 /**
  * <p>Attributes that describe how a <code>Region</code>'s size is managed through an eviction controller. Eviction
- * controllers are defined by an {@link com.gemstone.gemfire.cache.EvictionAlgorithm} and a {@link
- * com.gemstone.gemfire.cache.EvictionAction}. Once a <code>Region</code> is created with an eviction controller, it can
- * not be removed, however it can be changed through an {@link com.gemstone.gemfire.cache.EvictionAttributesMutator}.
+ * controllers are defined by an {@link org.apache.geode.cache.EvictionAlgorithm} and a {@link
+ * org.apache.geode.cache.EvictionAction}. Once a <code>Region</code> is created with an eviction controller, it can
+ * not be removed, however it can be changed through an {@link org.apache.geode.cache.EvictionAttributesMutator}.
  *
- * @see com.gemstone.gemfire.cache.AttributesFactory#setEvictionAttributes(EvictionAttributes)
- * @see com.gemstone.gemfire.cache.AttributesMutator
+ * @see org.apache.geode.cache.AttributesFactory#setEvictionAttributes(EvictionAttributes)
+ * @see org.apache.geode.cache.AttributesMutator
  * @since GemFire 5.0
  */
 @SuppressWarnings("serial")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributesMutator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributesMutator.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributesMutator.java
index 9f4af59..672ddd4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributesMutator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAttributesMutator.java
@@ -14,14 +14,14 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.cache.EvictionAttributesImpl;
+import org.apache.geode.internal.cache.EvictionAttributesImpl;
 
 /**
  * The EvictionAttributesMutator allows changes to be made to a 
- * {@link com.gemstone.gemfire.cache.EvictionAttributes}. It is returned
- * by {@link com.gemstone.gemfire.cache.AttributesMutator#getEvictionAttributesMutator()}
+ * {@link org.apache.geode.cache.EvictionAttributes}. It is returned
+ * by {@link org.apache.geode.cache.AttributesMutator#getEvictionAttributesMutator()}
  * @since GemFire 5.0
  */
 public interface EvictionAttributesMutator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/ExpirationAction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ExpirationAction.java b/geode-core/src/main/java/org/apache/geode/cache/ExpirationAction.java
index dace6c0..c958b34 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/ExpirationAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ExpirationAction.java
@@ -16,7 +16,7 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/ExpirationAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ExpirationAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/ExpirationAttributes.java
index ad854e7..22d507e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/ExpirationAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ExpirationAttributes.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 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.internal.InternalDataSerializer;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.internal.InternalDataSerializer;
 
 /** Immutable parameter object for accessing and setting the attributes associated with 
  * <code>timeToLive</code> and <code>idleTimeout</code>. If the expiration

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/FailedSynchronizationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/FailedSynchronizationException.java b/geode-core/src/main/java/org/apache/geode/cache/FailedSynchronizationException.java
index 7c44307..9cff54f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/FailedSynchronizationException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/FailedSynchronizationException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import javax.transaction.Status;
 import javax.transaction.Transaction;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionAttributes.java
index cb648db..4ada70d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionAttributes.java
@@ -14,22 +14,22 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.cache.FixedPartitionAttributesImpl;
+import org.apache.geode.internal.cache.FixedPartitionAttributesImpl;
 
 /**
  * Composite date type used to distribute the attributes for a fixed partition.
  * </p>
  * 
- * {@link com.gemstone.gemfire.cache.PartitionAttributes#getFixedPartitionAttributes()}
+ * {@link org.apache.geode.cache.PartitionAttributes#getFixedPartitionAttributes()}
  * returns all fixed partitions in Partitioned Region attributes. </p>
- * {@link com.gemstone.gemfire.cache.PartitionAttributesFactory#addFixedPartitionAttributes(FixedPartitionAttributes)}
+ * {@link org.apache.geode.cache.PartitionAttributesFactory#addFixedPartitionAttributes(FixedPartitionAttributes)}
  * configures <code>FixedPartitionAttributes</Code> in
  * <code>PartitionedRegionAttributes</code> </p>
  * 
- * @see com.gemstone.gemfire.cache.PartitionAttributes
- * @see com.gemstone.gemfire.cache.PartitionAttributesFactory
+ * @see org.apache.geode.cache.PartitionAttributes
+ * @see org.apache.geode.cache.PartitionAttributesFactory
  * 
  * @since GemFire 6.6
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionResolver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionResolver.java b/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionResolver.java
index db77807..23fddd8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionResolver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/FixedPartitionResolver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Set;
 
@@ -26,7 +26,7 @@ import java.util.Set;
  * which member the data is being managed. Say, for example, you want to
  * partition all Trades according to quarters. You can implement
  * FixedPartitionResolver to get the name of the quarter based on the date given
- * as part of {@link com.gemstone.gemfire.cache.EntryOperation}.
+ * as part of {@link org.apache.geode.cache.EntryOperation}.
  * </p>
  * 
  * public class QuarterPartitionResolver implements FixedPartitionResolver{<br>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/GatewayConfigurationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/GatewayConfigurationException.java b/geode-core/src/main/java/org/apache/geode/cache/GatewayConfigurationException.java
index 954d6c8..d7760a8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/GatewayConfigurationException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/GatewayConfigurationException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/GatewayException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/GatewayException.java b/geode-core/src/main/java/org/apache/geode/cache/GatewayException.java
index f8a9d0e..e47c51d 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/GatewayException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/GatewayException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * An exception thrown by a <code>Gateway</code>.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/GemFireCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/GemFireCache.java b/geode-core/src/main/java/org/apache/geode/cache/GemFireCache.java
index b1ac678..05daa38 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/GemFireCache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/GemFireCache.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.io.InputStream;
 import java.util.Map;
@@ -23,13 +23,13 @@ import java.util.Properties;
 
 import javax.naming.Context;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.client.ClientCache;
-import com.gemstone.gemfire.cache.client.ClientCacheFactory;
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.cache.wan.GatewaySenderFactory;
-import com.gemstone.gemfire.distributed.DistributedSystem;
-import com.gemstone.gemfire.pdx.PdxSerializer;
+import org.apache.geode.LogWriter;
+import org.apache.geode.cache.client.ClientCache;
+import org.apache.geode.cache.client.ClientCacheFactory;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.cache.wan.GatewaySenderFactory;
+import org.apache.geode.distributed.DistributedSystem;
+import org.apache.geode.pdx.PdxSerializer;
 
 /**
  * GemFireCache represents the singleton cache that must be created
@@ -185,8 +185,8 @@ public interface GemFireCache extends RegionService {
   
   /**
    * Returns whether { @link PdxInstance} is preferred for PDX types instead of Java object.
-   * @see com.gemstone.gemfire.cache.CacheFactory#setPdxReadSerialized(boolean)
-   * @see com.gemstone.gemfire.cache.client.ClientCacheFactory#setPdxReadSerialized(boolean)
+   * @see org.apache.geode.cache.CacheFactory#setPdxReadSerialized(boolean)
+   * @see org.apache.geode.cache.client.ClientCacheFactory#setPdxReadSerialized(boolean)
    * 
    * @since GemFire 6.6
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/IncompatibleVersionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/IncompatibleVersionException.java b/geode-core/src/main/java/org/apache/geode/cache/IncompatibleVersionException.java
index 7f76bd9..96afd80 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/IncompatibleVersionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/IncompatibleVersionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * An <code>IncompatibleVersionException</code> that the client version

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/InterestPolicy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/InterestPolicy.java b/geode-core/src/main/java/org/apache/geode/cache/InterestPolicy.java
index 7200bc6..185c84c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/InterestPolicy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/InterestPolicy.java
@@ -16,7 +16,7 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 import java.io.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationEvent.java b/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationEvent.java
index b2f9b0a..74ca188 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationEvent.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Set;
 
-import com.gemstone.gemfire.internal.cache.tier.InterestType;
+import org.apache.geode.internal.cache.tier.InterestType;
 
 /**
  * Interface <code>InterestRegistrationEvent</code> encapsulated interest

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationListener.java b/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationListener.java
index 370d47b..195f130 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/InterestRegistrationListener.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Interface <code>InterestRegisterationListener</code> provides the ability for
  * applications to be notified of interest registration and unregistration
  * events. Instances must be implemented by applications and registered in
  * <code>CacheServer</code> VMs using the
- * {@link com.gemstone.gemfire.cache.server.CacheServer#registerInterestRegistrationListener
+ * {@link org.apache.geode.cache.server.CacheServer#registerInterestRegistrationListener
  * registerInterestRegistrationListener} API. The methods on an
  * <code>InterestRegisterationListener</code> are invoked synchronously with the
  * interest event in any <code>CacheServer</code> VM hosting the requesting
@@ -31,8 +31,8 @@ package com.gemstone.gemfire.cache;
  * <p>Shown below is an example implementation.
  *
  * <pre>
- *import com.gemstone.gemfire.cache.InterestRegistrationEvent;
- *import com.gemstone.gemfire.cache.InterestRegistrationListener;
+ *import org.apache.geode.cache.InterestRegistrationEvent;
+ *import org.apache.geode.cache.InterestRegistrationListener;
  *
  *public class TestInterestRegistrationListener implements InterestRegistrationListener {
  *
@@ -62,8 +62,8 @@ package com.gemstone.gemfire.cache;
  *
  * @since GemFire 6.0
  * 
- * @see com.gemstone.gemfire.cache.server.CacheServer#registerInterestRegistrationListener registerInterestRegistrationListener
- * @see com.gemstone.gemfire.cache.server.CacheServer#unregisterInterestRegistrationListener unregisterInterestRegistrationListener
+ * @see org.apache.geode.cache.server.CacheServer#registerInterestRegistrationListener registerInterestRegistrationListener
+ * @see org.apache.geode.cache.server.CacheServer#unregisterInterestRegistrationListener unregisterInterestRegistrationListener
  */
 public interface InterestRegistrationListener extends CacheCallback {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/InterestResultPolicy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/InterestResultPolicy.java b/geode-core/src/main/java/org/apache/geode/cache/InterestResultPolicy.java
index 7dee649..76ed438 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/InterestResultPolicy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/InterestResultPolicy.java
@@ -16,9 +16,9 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.cache.tier.sockets.InterestResultPolicyImpl;
+import org.apache.geode.internal.cache.tier.sockets.InterestResultPolicyImpl;
 import java.io.ObjectStreamException;
 import java.io.Serializable;
 
@@ -28,8 +28,8 @@ import java.io.Serializable;
  * can be the keys and current values, just the keys or nothing.
  *
  *
- * @see com.gemstone.gemfire.cache.Region#registerInterest(Object)
- * @see com.gemstone.gemfire.cache.Region#registerInterestRegex(String)
+ * @see org.apache.geode.cache.Region#registerInterest(Object)
+ * @see org.apache.geode.cache.Region#registerInterestRegex(String)
  *
  * @since GemFire 4.2.3
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/LoaderHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/LoaderHelper.java b/geode-core/src/main/java/org/apache/geode/cache/LoaderHelper.java
index 86aa329..75d04fe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/LoaderHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/LoaderHelper.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Provides a set of APIs to help the
  * implementation of the <code>CacheLoader</code> load method. An instance of <code>LoaderHelper</code>
@@ -50,7 +50,7 @@ public interface LoaderHelper<K,V>
    *         getting a response from another cache
    * @throws CacheLoaderException
    *         If <code>netSearch</code> is attempted on a {@linkplain
-   *         com.gemstone.gemfire.cache.Scope#LOCAL local} region. 
+   *         org.apache.geode.cache.Scope#LOCAL local} region. 
    */
   public V netSearch(boolean doNetLoad)
     throws CacheLoaderException, TimeoutException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/LossAction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/LossAction.java b/geode-core/src/main/java/org/apache/geode/cache/LossAction.java
index 7c428a1..7258da4 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/LossAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/LossAction.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.util.*;
@@ -26,7 +26,7 @@ import java.util.*;
  * roles are lost. A role is lost when it is are offline and no longer
  * present in the system membership.
  * The <code>LossAction</code> is specified when configuring a region's
- * {@link com.gemstone.gemfire.cache.MembershipAttributes}.
+ * {@link org.apache.geode.cache.MembershipAttributes}.
  * 
  * @deprecated this feature is scheduled to be removed
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/LowMemoryException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/LowMemoryException.java b/geode-core/src/main/java/org/apache/geode/cache/LowMemoryException.java
index aee073a..fe4849a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/LowMemoryException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/LowMemoryException.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Collections;
 import java.util.HashSet;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.control.ResourceManager;
-import com.gemstone.gemfire.distributed.DistributedMember;
+import org.apache.geode.cache.control.ResourceManager;
+import org.apache.geode.distributed.DistributedMember;
 
 /**
  * Indicates a low memory condition either on the local or a remote {@link Cache}.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
index 5a1c451..cf87e90 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/MembershipAttributes.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.DataSerializable;
-import com.gemstone.gemfire.DataSerializer;
-import com.gemstone.gemfire.distributed.internal.membership.InternalRole;
-import com.gemstone.gemfire.distributed.Role;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.DataSerializable;
+import org.apache.geode.DataSerializer;
+import org.apache.geode.distributed.internal.membership.InternalRole;
+import org.apache.geode.distributed.Role;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 import java.util.*;
@@ -120,7 +120,7 @@ public class MembershipAttributes implements DataSerializable, Externalizable {
   }
   
   /**
-   * Returns the set of {@linkplain com.gemstone.gemfire.distributed.Role 
+   * Returns the set of {@linkplain org.apache.geode.distributed.Role 
    * Role}s that are required for the reliability of this region.
    */
   public Set<Role> getRequiredRoles() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/MirrorType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/MirrorType.java b/geode-core/src/main/java/org/apache/geode/cache/MirrorType.java
index 76b34a8..6b3d602 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/MirrorType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/MirrorType.java
@@ -16,7 +16,7 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 import java.io.*;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/NoQueueServersAvailableException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/NoQueueServersAvailableException.java b/geode-core/src/main/java/org/apache/geode/cache/NoQueueServersAvailableException.java
index 0217e91..2361c8d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/NoQueueServersAvailableException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/NoQueueServersAvailableException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerConnectivityException;
 
 /**
  * Indicates that this client cannot contact any queue servers and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/NoSubscriptionServersAvailableException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/NoSubscriptionServersAvailableException.java b/geode-core/src/main/java/org/apache/geode/cache/NoSubscriptionServersAvailableException.java
index 9c72e44..53ca591 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/NoSubscriptionServersAvailableException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/NoSubscriptionServersAvailableException.java
@@ -14,9 +14,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
-import com.gemstone.gemfire.cache.client.ServerConnectivityException;
+import org.apache.geode.cache.client.ServerConnectivityException;
 
 /**
  * Indicates that this client cannot contact any servers and

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/Operation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Operation.java b/geode-core/src/main/java/org/apache/geode/cache/Operation.java
index 2634416..283069a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Operation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Operation.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 import java.io.*;
-import com.gemstone.gemfire.internal.cache.OpType;
-import com.gemstone.gemfire.cache.execute.FunctionService;
+import org.apache.geode.internal.cache.OpType;
+import org.apache.geode.cache.execute.FunctionService;
 
 /**
  * Enumerated type for an event operation.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/OperationAbortedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/OperationAbortedException.java b/geode-core/src/main/java/org/apache/geode/cache/OperationAbortedException.java
index f596f7e..340d184 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/OperationAbortedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/OperationAbortedException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /** Indicates that the operation that
  * would have otherwise affected the cache has been aborted.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
index e2f5479..90f7b6f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
@@ -15,27 +15,27 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.List;
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.PartitionResolver;
-import com.gemstone.gemfire.cache.partition.PartitionListener;
+import org.apache.geode.cache.PartitionResolver;
+import org.apache.geode.cache.partition.PartitionListener;
 
 /**
  * 
  * Attributes that define the partitioned character of a Partitioned Region.  
  * This interface allows for the discovery of Partitioned Region attributes using 
- * {@link com.gemstone.gemfire.cache.RegionAttributes#getPartitionAttributes()} as well
- * as the configuration of a Partitioned Region using {@link com.gemstone.gemfire.cache.AttributesFactory#setPartitionAttributes(PartitionAttributes)}.
+ * {@link org.apache.geode.cache.RegionAttributes#getPartitionAttributes()} as well
+ * as the configuration of a Partitioned Region using {@link org.apache.geode.cache.AttributesFactory#setPartitionAttributes(PartitionAttributes)}.
  * 
- * PartitionAttributes are created using the {@link com.gemstone.gemfire.cache.PartitionAttributesFactory}
+ * PartitionAttributes are created using the {@link org.apache.geode.cache.PartitionAttributesFactory}
  * 
- * The default PartitionAttributes can be determined using {@link com.gemstone.gemfire.cache.PartitionAttributesFactory#create()} with out
- * calling any of its mutator methods e.g.  {@link com.gemstone.gemfire.cache.PartitionAttributesFactory#setLocalMaxMemory(int)}
+ * The default PartitionAttributes can be determined using {@link org.apache.geode.cache.PartitionAttributesFactory#create()} with out
+ * calling any of its mutator methods e.g.  {@link org.apache.geode.cache.PartitionAttributesFactory#setLocalMaxMemory(int)}
  *
- * Also see {@link com.gemstone.gemfire.cache.DataPolicy#PARTITION}.
+ * Also see {@link org.apache.geode.cache.DataPolicy#PARTITION}.
  * 
  * @since GemFire 5.0
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
index 7489b89..0fdc245 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 import java.util.Properties;
 
-import com.gemstone.gemfire.cache.partition.PartitionListener;
-import com.gemstone.gemfire.internal.cache.PartitionAttributesImpl;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.partition.PartitionListener;
+import org.apache.geode.internal.cache.PartitionAttributesImpl;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * <p>
@@ -50,10 +50,10 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  * {@link PartitionAttributes} can also be defined in a declarative fashion using a
  * <a href="package-summary.html#declarative">cache.xml</a> file. Here is an
  * example of how to configure a Partitioned Region named "pRoot" whose 
- * {@link com.gemstone.gemfire.cache.Scope} is Distributed Ack, which maintains
+ * {@link org.apache.geode.cache.Scope} is Distributed Ack, which maintains
  * a {@link #setRedundantCopies(int) redundant copy} of any given 
- * {@link com.gemstone.gemfire.cache.Region.Entry}, configures a 
- * {@link com.gemstone.gemfire.cache.CacheLoader} implementation, and sets 
+ * {@link org.apache.geode.cache.Region.Entry}, configures a 
+ * {@link org.apache.geode.cache.CacheLoader} implementation, and sets 
  * {@link #setGlobalProperties(Properties) global properties} as well as 
  * {@link #setLocalMaxMemory(int) local max memory to use}.
  * 
@@ -66,8 +66,8 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  * </pre>
  * </p>
  * 
- * @see com.gemstone.gemfire.cache.PartitionAttributes
- * @see com.gemstone.gemfire.cache.AttributesFactory#setPartitionAttributes(PartitionAttributes)
+ * @see org.apache.geode.cache.PartitionAttributes
+ * @see org.apache.geode.cache.AttributesFactory#setPartitionAttributes(PartitionAttributes)
  * @since GemFire 5.0
  */
 public class PartitionAttributesFactory<K,V>
@@ -223,7 +223,7 @@ public class PartitionAttributesFactory<K,V>
    * <em>This setting must be the same in all processes using the Region.</em>
    * <p>
    * A bucket is the smallest unit of data management in a partitioned region.
-   * {@link com.gemstone.gemfire.cache.Region.Entry Entries} are stored in
+   * {@link org.apache.geode.cache.Region.Entry Entries} are stored in
    * buckets and buckets may move from one VM to another. Buckets may also have
    * copies, depending on {@link #setRedundantCopies(int) redundancy} to provide
    * high availability in the face of VM failure.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/PartitionResolver.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionResolver.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionResolver.java
index 253a108..a286e37 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionResolver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionResolver.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Implementers of interface <code>PartitionResolver</code> enable custom

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionDistributionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionDistributionException.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionDistributionException.java
index 9a3ed77..2fc6e1c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionDistributionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionDistributionException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * Indicates a failure to perform a distributed operation on a Partitioned Region 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionStorageException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionStorageException.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionStorageException.java
index 7334f89..cdb0d18 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionStorageException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionedRegionStorageException.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache;
+package org.apache.geode.cache;
 
 /**
  * 
@@ -65,7 +65,7 @@ package com.gemstone.gemfire.cache;
  * </p>
  * 
  * 
- * @see com.gemstone.gemfire.cache.PartitionAttributesFactory
+ * @see org.apache.geode.cache.PartitionAttributesFactory
  * @since GemFire 5.0
  */
 public class PartitionedRegionStorageException extends CacheRuntimeException  {


[32/83] [abbrv] [partial] incubator-geode git commit: GEODE-37 changed import statement from com.gemstone.gemfire to org.apache.geode

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndex.java
index 718a2c4..ab3da53 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndex.java
@@ -19,7 +19,7 @@
  *
  * Created on March 20, 2005, 6:47 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
 import java.util.Iterator;
@@ -27,31 +27,31 @@ import java.util.List;
 import java.util.Map;
 import java.util.Set;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.QueryObserver;
-import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
-import com.gemstone.gemfire.cache.query.internal.QueryUtils;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.Support;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.ObjectTypeImpl;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.LocalRegion;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-import com.gemstone.gemfire.pdx.internal.PdxString;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.QueryObserver;
+import org.apache.geode.cache.query.internal.QueryObserverHolder;
+import org.apache.geode.cache.query.internal.QueryUtils;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.LocalRegion;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.i18n.LocalizedStrings;
+import org.apache.geode.pdx.internal.PdxString;
 
 /**
  * 
@@ -351,7 +351,7 @@ public class PrimaryKeyIndex extends AbstractIndex  {
   /*
    * (non-Javadoc)
    * 
-   * @see com.gemstone.gemfire.cache.query.internal.index.AbstractIndex#lockedQuery(java.lang.Object,
+   * @see org.apache.geode.cache.query.internal.index.AbstractIndex#lockedQuery(java.lang.Object,
    *      int, java.lang.Object, int, java.util.Collection, java.util.Set)
    */
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndexCreationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndexCreationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndexCreationHelper.java
index 8f1d116..c4696e8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndexCreationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PrimaryKeyIndexCreationHelper.java
@@ -19,20 +19,20 @@
  *
  * Created on March 20, 2005, 7:21 PM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import java.util.List;
 
-import com.gemstone.gemfire.cache.Cache;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.query.IndexInvalidException;
-import com.gemstone.gemfire.cache.query.internal.CompiledIteratorDef;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.internal.cache.PartitionedRegion;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Cache;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.query.IndexInvalidException;
+import org.apache.geode.cache.query.internal.CompiledIteratorDef;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.internal.cache.PartitionedRegion;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/RangeIndex.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/RangeIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/RangeIndex.java
index cae20c4..0f4b0e2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/RangeIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/RangeIndex.java
@@ -19,7 +19,7 @@
  *
  * Created on February 4, 2005, 11:10 AM
  */
-package com.gemstone.gemfire.cache.query.internal.index;
+package org.apache.geode.cache.query.internal.index;
 
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenHashMap;
 
@@ -34,32 +34,32 @@ import java.util.SortedMap;
 import java.util.concurrent.ConcurrentNavigableMap;
 import java.util.concurrent.ConcurrentSkipListMap;
 
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionAttributes;
-import com.gemstone.gemfire.cache.query.FunctionDomainException;
-import com.gemstone.gemfire.cache.query.IndexStatistics;
-import com.gemstone.gemfire.cache.query.IndexType;
-import com.gemstone.gemfire.cache.query.NameResolutionException;
-import com.gemstone.gemfire.cache.query.QueryException;
-import com.gemstone.gemfire.cache.query.QueryInvocationTargetException;
-import com.gemstone.gemfire.cache.query.QueryService;
-import com.gemstone.gemfire.cache.query.SelectResults;
-import com.gemstone.gemfire.cache.query.TypeMismatchException;
-import com.gemstone.gemfire.cache.query.internal.CompiledSortCriterion;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.ExecutionContext;
-import com.gemstone.gemfire.cache.query.internal.QueryMonitor;
-import com.gemstone.gemfire.cache.query.internal.QueryObserver;
-import com.gemstone.gemfire.cache.query.internal.QueryObserverHolder;
-import com.gemstone.gemfire.cache.query.internal.RuntimeIterator;
-import com.gemstone.gemfire.cache.query.internal.index.IndexManager.TestHook;
-import com.gemstone.gemfire.cache.query.internal.index.IndexStore.IndexStoreEntry;
-import com.gemstone.gemfire.cache.query.internal.parse.OQLLexerTokenTypes;
-import com.gemstone.gemfire.cache.query.internal.types.TypeUtils;
-import com.gemstone.gemfire.cache.query.types.ObjectType;
-import com.gemstone.gemfire.internal.cache.RegionEntry;
-import com.gemstone.gemfire.internal.cache.persistence.query.CloseableIterator;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.Region;
+import org.apache.geode.cache.RegionAttributes;
+import org.apache.geode.cache.query.FunctionDomainException;
+import org.apache.geode.cache.query.IndexStatistics;
+import org.apache.geode.cache.query.IndexType;
+import org.apache.geode.cache.query.NameResolutionException;
+import org.apache.geode.cache.query.QueryException;
+import org.apache.geode.cache.query.QueryInvocationTargetException;
+import org.apache.geode.cache.query.QueryService;
+import org.apache.geode.cache.query.SelectResults;
+import org.apache.geode.cache.query.TypeMismatchException;
+import org.apache.geode.cache.query.internal.CompiledSortCriterion;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.ExecutionContext;
+import org.apache.geode.cache.query.internal.QueryMonitor;
+import org.apache.geode.cache.query.internal.QueryObserver;
+import org.apache.geode.cache.query.internal.QueryObserverHolder;
+import org.apache.geode.cache.query.internal.RuntimeIterator;
+import org.apache.geode.cache.query.internal.index.IndexManager.TestHook;
+import org.apache.geode.cache.query.internal.index.IndexStore.IndexStoreEntry;
+import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
+import org.apache.geode.cache.query.internal.types.TypeUtils;
+import org.apache.geode.cache.query.types.ObjectType;
+import org.apache.geode.internal.cache.RegionEntry;
+import org.apache.geode.internal.cache.persistence.query.CloseableIterator;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  */
@@ -158,7 +158,7 @@ public class RangeIndex extends AbstractIndex  {
       
       if (indxResultSet != null) {
         if (indxResultSet.getClass().getName()
-            .startsWith("com.gemstone.gemfire.internal.cache.Token$")
+            .startsWith("org.apache.geode.internal.cache.Token$")
             || indxResultSet == QueryService.UNDEFINED) {
           // do nothing, Entries are either removed or invalidated or destroyed
           // by other thread.
@@ -468,7 +468,7 @@ public class RangeIndex extends AbstractIndex  {
     else if (key == QueryService.UNDEFINED) {
       if (value != null) {
         if (value.getClass().getName()
-            .startsWith("com.gemstone.gemfire.internal.cache.Token$")
+            .startsWith("org.apache.geode.internal.cache.Token$")
             || value == QueryService.UNDEFINED) {
           // do nothing, Entries are either removed or invalidated or destroyed
           // by other thread.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/package.html
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/package.html b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/package.html
index c77a3c9..515a2cf 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/package.html
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/package.html
@@ -362,7 +362,7 @@ indexes. </FONT></FONT>
 			 here should not be confused with byte-code compilation which is a
 			lower level of compilation that will most likely not be
 			implemented in this release due resource restrictions. See the
-			package.html for com.gemstone.gemfire.cache.query for further
+			package.html for org.apache.geode.cache.query for further
 			details on byte-code compilation.</FONT></FONT></P>
 			<LI><P CLASS="western" STYLE="margin-bottom: 0in; font-style: normal; font-weight: medium; widows: 0; orphans: 0">
 			<FONT FACE="Arial, sans-serif"><FONT SIZE=3>Each iterator

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
index 8c989f9..da69c90 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
@@ -14,13 +14,13 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
 
-import com.gemstone.gemfire.cache.query.QueryInvalidException;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.QueryInvalidException;
+import org.apache.geode.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAnd.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAnd.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAnd.java
index b5d1b19..bb1ab2d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAnd.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAnd.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTAnd extends GemFireAST {
   private static final long serialVersionUID = 7100190044926605881L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
index a4b4444..6519097 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCompareOp.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCompareOp.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCompareOp.java
index 8974564..1aab4b4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCompareOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCompareOp.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTCompareOp extends GemFireAST {
   private static final long serialVersionUID = 2764710765423856496L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConstruction.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConstruction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConstruction.java
index d7df084..fcfade1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConstruction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConstruction.java
@@ -16,11 +16,11 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.*;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.query.internal.*;
+import org.apache.geode.internal.Assert;
 
 public class ASTConstruction extends GemFireAST {  
   private static final long serialVersionUID = 6647545354866647845L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConversionExpr.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConversionExpr.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConversionExpr.java
index d8b3f12..f4139e8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConversionExpr.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTConversionExpr.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTConversionExpr extends GemFireAST {  
   private static final long serialVersionUID = 8713000632283704611L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTDummy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTDummy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTDummy.java
index ca251cd..c38a7e3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTDummy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTDummy.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTDummy extends GemFireAST {
 private static final long serialVersionUID = -5390937473819850292L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
index 6f4f6cd..d5c9743 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
index 3fd3069..f7f8f6e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
@@ -17,11 +17,11 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
index 0b0182e..e05784c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
@@ -17,11 +17,11 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIdentifier.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIdentifier.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIdentifier.java
index ad7b2b3..d3cf050 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIdentifier.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIdentifier.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTIdentifier extends GemFireAST {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTImport.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTImport.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTImport.java
index bc679d7..0bac276 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTImport.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTImport.java
@@ -16,11 +16,11 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 import antlr.collections.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTImport extends GemFireAST {  
   private static final long serialVersionUID = 6002078657881181949L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIn.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIn.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIn.java
index 4240596..9386f3f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIn.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIn.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTIn extends GemFireAST {  
   private static final long serialVersionUID = -7688132343283983119L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
index e4a1e19..59bd0a0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 //import antlr.collections.*;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.internal.Assert;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
index 075dfbc..ead5155 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
@@ -17,11 +17,11 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
index ad36cee..8ef1dfb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLiteral.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLiteral.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLiteral.java
index 4a5f573..226f800 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLiteral.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLiteral.java
@@ -16,14 +16,14 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 import java.util.*;
 import java.sql.*;
-import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 public class ASTLiteral extends GemFireAST {
   private static final long serialVersionUID = 8374021603235812835L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTMethodInvocation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTMethodInvocation.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTMethodInvocation.java
index 136ebf4..e0946b3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTMethodInvocation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTMethodInvocation.java
@@ -16,14 +16,14 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import org.apache.logging.log4j.Logger;
 
 import antlr.*;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.internal.logging.LogService;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.internal.logging.LogService;
 
 public class ASTMethodInvocation extends GemFireAST {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOr.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOr.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOr.java
index 5fdb1a0..0450ba2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOr.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOr.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 public class ASTOr extends GemFireAST {
   private static final long serialVersionUID = 5770135811089855867L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
index a0d1414..a744a95 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
@@ -14,10 +14,10 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTParameter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTParameter.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTParameter.java
index 6ddb1ae..d6a80ff 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTParameter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTParameter.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTParameter extends GemFireAST {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTPostfix.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTPostfix.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTPostfix.java
index 6bfd9f0..3815839 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTPostfix.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTPostfix.java
@@ -16,11 +16,11 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 import antlr.collections.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * This handles paths, method invocations, and index operators that

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTProjection.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTProjection.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTProjection.java
index 75c2ab3..c935b04 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTProjection.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTProjection.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTProjection extends GemFireAST {  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTRegionPath.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTRegionPath.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTRegionPath.java
index 67bfa46..a9decd3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTRegionPath.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTRegionPath.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTRegionPath extends GemFireAST {  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSelect.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSelect.java
index 83c1177..98e3227 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSelect.java
@@ -16,7 +16,7 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import java.util.HashMap;
 import java.util.Map;
@@ -24,8 +24,8 @@ import java.util.Map;
 import antlr.*;
 import antlr.collections.*;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.cache.query.internal.CompiledValue;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.CompiledValue;
 
 public class ASTSelect extends GemFireAST {
   private static final long serialVersionUID = 1389351692304773456L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
index ac4aa8d..f93b0c9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
@@ -14,11 +14,11 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
index 4528e8b..cc400aa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
@@ -17,9 +17,9 @@
 /**
  * 
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTType.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTType.java
index f89d411..986b439 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTType.java
@@ -16,12 +16,12 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.cache.query.types.*;
-import com.gemstone.gemfire.internal.Assert;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.types.*;
+import org.apache.geode.internal.Assert;
 
 
 public class ASTType extends GemFireAST {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTypeCast.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTypeCast.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTypeCast.java
index a01afad..6a9e6e9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTypeCast.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTypeCast.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTTypeCast extends GemFireAST {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
index 32944fc..2b6f273 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
@@ -14,12 +14,12 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.cache.query.internal.Support;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.Support;
 /**
  * 
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUndefinedExpr.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUndefinedExpr.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUndefinedExpr.java
index 72487c5..7f72693 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUndefinedExpr.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUndefinedExpr.java
@@ -16,10 +16,10 @@
  */
 
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 
 public class ASTUndefinedExpr extends GemFireAST {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnsupported.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnsupported.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnsupported.java
index ec3fa36..cf614df 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnsupported.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnsupported.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
+import org.apache.geode.cache.query.internal.QCompiler;
+import org.apache.geode.internal.i18n.LocalizedStrings;
 
 /**
  * AST class used for an AST node that cannot be compiled directly

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
index efe01da..6f2bdbe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 //import antlr.collections.*;
-//import com.gemstone.gemfire.cache.query.*;
-import com.gemstone.gemfire.cache.query.internal.QCompiler;
+//import org.apache.geode.cache.query.*;
+import org.apache.geode.cache.query.internal.QCompiler;
 
 /**
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexer.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexer.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexer.java
index 2ada98d..c508705 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexer.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexer.java
@@ -1,8 +1,8 @@
 // $ANTLR 2.7.4: "oql.g" -> "OQLLexer.java"$
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 import java.util.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
+import org.apache.geode.cache.query.internal.types.*;
 
 import java.io.InputStream;
 import antlr.TokenStreamException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/939fcf2f/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexerTokenTypes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexerTokenTypes.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexerTokenTypes.java
index f30f3c0..ed03fb1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexerTokenTypes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/OQLLexerTokenTypes.java
@@ -1,8 +1,8 @@
 // $ANTLR 2.7.4: "oql.g" -> "OQLParser.java"$
 
-package com.gemstone.gemfire.cache.query.internal.parse;
+package org.apache.geode.cache.query.internal.parse;
 import java.util.*;
-import com.gemstone.gemfire.cache.query.internal.types.*;
+import org.apache.geode.cache.query.internal.types.*;
 
 public interface OQLLexerTokenTypes {
 	int EOF = 1;


[74/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/README
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/README b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/README
deleted file mode 100644
index 2d7cdcf..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/README
+++ /dev/null
@@ -1,68 +0,0 @@
-JSON in Java [package com.vmware.gemfire.tools.pulse.internal.json]
-
-Douglas Crockford
-douglas@crockford.com
-
-2011-02-02
-
-
-JSON is a light-weight, language independent, data interchange format.
-See http://www.JSON.org/
-
-The files in this package implement JSON encoders/decoders in Java. 
-It also includes the capability to convert between JSON and XML, HTTP 
-headers, Cookies, and CDL. 
-
-This is a reference implementation. There is a large number of JSON packages
-in Java. Perhaps someday the Java community will standardize on one. Until 
-then, choose carefully.
-
-The license includes this restriction: "The software shall be used for good, 
-not evil." If your conscience cannot live with that, then choose a different
-package.
-
-The package compiles on Java 1.2 thru Java 1.4.
-
-
-JSONObject.java: The JSONObject can parse text from a String or a JSONTokener
-to produce a map-like object. The object provides methods for manipulating its
-contents, and for producing a JSON compliant object serialization.
-
-JSONArray.java: The JSONObject can parse text from a String or a JSONTokener
-to produce a vector-like object. The object provides methods for manipulating 
-its contents, and for producing a JSON compliant array serialization.
-
-JSONTokener.java: The JSONTokener breaks a text into a sequence of individual
-tokens. It can be constructed from a String, Reader, or InputStream.
-
-JSONException.java: The JSONException is the standard exception type thrown
-by this package.
-
-
-JSONString.java: The JSONString interface requires a toJSONString method, 
-allowing an object to provide its own serialization.
-
-JSONStringer.java: The JSONStringer provides a convenient facility for 
-building JSON strings.
-
-JSONWriter.java: The JSONWriter provides a convenient facility for building 
-JSON text through a writer.
- 
-
-CDL.java: CDL provides support for converting between JSON and comma
-delimited lists.
-
-Cookie.java: Cookie provides support for converting between JSON and cookies.
-
-CookieList.java: CookieList provides support for converting between JSON and
-cookie lists.
-
-HTTP.java: HTTP provides support for converting between JSON and HTTP headers.
-
-HTTPTokener.java: HTTPTokener extends JSONTokener for parsing HTTP headers.
-
-XML.java: XML provides support for converting between JSON and XML.
-
-JSONML.java: JSONML provides support for converting between JSONML and XML.
-
-XMLTokener.java: XMLTokener extends JSONTokener for parsing XML text.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XML.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XML.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XML.java
deleted file mode 100644
index d43eb77..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XML.java
+++ /dev/null
@@ -1,503 +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 com.vmware.geode.tools.pulse.internal.json;
-
-import java.util.Iterator;
-
-
-/**
- * This provides static methods to convert an XML text into a JSONObject,
- * and to covert a JSONObject into an XML text.
- * @author JSON.org
- * @version 2011-02-11
- */
-public class XML {
-
-    /** The Character '&'. */
-    public static final Character AMP   = new Character('&');
-
-    /** The Character '''. */
-    public static final Character APOS  = new Character('\'');
-
-    /** The Character '!'. */
-    public static final Character BANG  = new Character('!');
-
-    /** The Character '='. */
-    public static final Character EQ    = new Character('=');
-
-    /** The Character '>'. */
-    public static final Character GT    = new Character('>');
-
-    /** The Character '<'. */
-    public static final Character LT    = new Character('<');
-
-    /** The Character '?'. */
-    public static final Character QUEST = new Character('?');
-
-    /** The Character '"'. */
-    public static final Character QUOT  = new Character('"');
-
-    /** The Character '/'. */
-    public static final Character SLASH = new Character('/');
-
-    /**
-     * Replace special characters with XML escapes:
-     * <pre>
-     * &amp; <small>(ampersand)</small> is replaced by &amp;amp;
-     * &lt; <small>(less than)</small> is replaced by &amp;lt;
-     * &gt; <small>(greater than)</small> is replaced by &amp;gt;
-     * &quot; <small>(double quote)</small> is replaced by &amp;quot;
-     * </pre>
-     * @param string The string to be escaped.
-     * @return The escaped string.
-     */
-    public static String escape(String string) {
-        StringBuffer sb = new StringBuffer();
-        for (int i = 0, length = string.length(); i < length; i++) {
-            char c = string.charAt(i);
-            switch (c) {
-            case '&':
-                sb.append("&amp;");
-                break;
-            case '<':
-                sb.append("&lt;");
-                break;
-            case '>':
-                sb.append("&gt;");
-                break;
-            case '"':
-                sb.append("&quot;");
-                break;
-            case '\'':
-                sb.append("&apos;");
-                break;
-            default:
-                sb.append(c);
-            }
-        }
-        return sb.toString();
-    }
-    
-    /**
-     * Throw an exception if the string contains whitespace. 
-     * Whitespace is not allowed in tagNames and attributes.
-     * @param string
-     * @throws JSONException
-     */
-    public static void noSpace(String string) throws JSONException {
-        int i, length = string.length();
-        if (length == 0) {
-            throw new JSONException("Empty string.");
-        }
-        for (i = 0; i < length; i += 1) {
-            if (Character.isWhitespace(string.charAt(i))) {
-                throw new JSONException("'" + string + 
-                        "' contains a space character.");
-            }
-        }
-    }
-
-    /**
-     * Scan the content following the named tag, attaching it to the context.
-     * @param x       The XMLTokener containing the source string.
-     * @param context The JSONObject that will include the new material.
-     * @param name    The tag name.
-     * @return true if the close tag is processed.
-     * @throws JSONException
-     */
-    private static boolean parse(XMLTokener x, JSONObject context,
-                                 String name) throws JSONException {
-        char       c;
-        int        i;
-        JSONObject jsonobject = null;
-        String     string;
-        String     tagName;
-        Object     token;
-
-// Test for and skip past these forms:
-//      <!-- ... -->
-//      <!   ...   >
-//      <![  ... ]]>
-//      <?   ...  ?>
-// Report errors for these forms:
-//      <>
-//      <=
-//      <<
-
-        token = x.nextToken();
-
-// <!
-
-        if (token == BANG) {
-            c = x.next();
-            if (c == '-') {
-                if (x.next() == '-') {
-                    x.skipPast("-->");
-                    return false;
-                }
-                x.back();
-            } else if (c == '[') {
-                token = x.nextToken();
-                if ("CDATA".equals(token)) {
-                    if (x.next() == '[') {
-                        string = x.nextCDATA();
-                        if (string.length() > 0) {
-                            context.accumulate("content", string);
-                        }
-                        return false;
-                    }
-                }
-                throw x.syntaxError("Expected 'CDATA['");
-            }
-            i = 1;
-            do {
-                token = x.nextMeta();
-                if (token == null) {
-                    throw x.syntaxError("Missing '>' after '<!'.");
-                } else if (token == LT) {
-                    i += 1;
-                } else if (token == GT) {
-                    i -= 1;
-                }
-            } while (i > 0);
-            return false;
-        } else if (token == QUEST) {
-
-// <?
-
-            x.skipPast("?>");
-            return false;
-        } else if (token == SLASH) {
-
-// Close tag </
-
-            token = x.nextToken();
-            if (name == null) {
-                throw x.syntaxError("Mismatched close tag " + token);
-            }            
-            if (!token.equals(name)) {
-                throw x.syntaxError("Mismatched " + name + " and " + token);
-            }
-            if (x.nextToken() != GT) {
-                throw x.syntaxError("Misshaped close tag");
-            }
-            return true;
-
-        } else if (token instanceof Character) {
-            throw x.syntaxError("Misshaped tag");
-
-// Open tag <
-
-        } else {
-            tagName = (String)token;
-            token = null;
-            jsonobject = new JSONObject();
-            for (;;) {
-                if (token == null) {
-                    token = x.nextToken();
-                }
-
-// attribute = value
-
-                if (token instanceof String) {
-                    string = (String)token;
-                    token = x.nextToken();
-                    if (token == EQ) {
-                        token = x.nextToken();
-                        if (!(token instanceof String)) {
-                            throw x.syntaxError("Missing value");
-                        }
-                        jsonobject.accumulate(string, 
-                                XML.stringToValue((String)token));
-                        token = null;
-                    } else {
-                        jsonobject.accumulate(string, "");
-                    }
-
-// Empty tag <.../>
-
-                } else if (token == SLASH) {
-                    if (x.nextToken() != GT) {
-                        throw x.syntaxError("Misshaped tag");
-                    }
-                    if (jsonobject.length() > 0) {
-                        context.accumulate(tagName, jsonobject);
-                    } else {
-                        context.accumulate(tagName, "");
-                    }
-                    return false;
-
-// Content, between <...> and </...>
-
-                } else if (token == GT) {
-                    for (;;) {
-                        token = x.nextContent();
-                        if (token == null) {
-                            if (tagName != null) {
-                                throw x.syntaxError("Unclosed tag " + tagName);
-                            }
-                            return false;
-                        } else if (token instanceof String) {
-                            string = (String)token;
-                            if (string.length() > 0) {
-                                jsonobject.accumulate("content", 
-                                        XML.stringToValue(string));
-                            }
-
-// Nested element
-
-                        } else if (token == LT) {
-                            if (parse(x, jsonobject, tagName)) {
-                                if (jsonobject.length() == 0) {
-                                    context.accumulate(tagName, "");
-                                } else if (jsonobject.length() == 1 &&
-                                       jsonobject.opt("content") != null) {
-                                    context.accumulate(tagName, 
-                                            jsonobject.opt("content"));
-                                } else {
-                                    context.accumulate(tagName, jsonobject);
-                                }
-                                return false;
-                            }
-                        }
-                    }
-                } else {
-                    throw x.syntaxError("Misshaped tag");
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Try to convert a string into a number, boolean, or null. If the string
-     * can't be converted, return the string. This is much less ambitious than
-     * JSONObject.stringToValue, especially because it does not attempt to
-     * convert plus forms, octal forms, hex forms, or E forms lacking decimal 
-     * points.
-     * @param string A String.
-     * @return A simple JSON value.
-     */
-    public static Object stringToValue(String string) {
-        if ("".equals(string)) {
-            return string;
-        }
-        if ("true".equalsIgnoreCase(string)) {
-            return Boolean.TRUE;
-        }
-        if ("false".equalsIgnoreCase(string)) {
-            return Boolean.FALSE;
-        }
-        if ("null".equalsIgnoreCase(string)) {
-            return JSONObject.NULL;
-        }
-        if ("0".equals(string)) {
-            return new Integer(0);
-        }
-
-// If it might be a number, try converting it. If that doesn't work, 
-// return the string.
-
-        try {
-            char initial = string.charAt(0);
-            boolean negative = false;
-            if (initial == '-') {
-                initial = string.charAt(1);
-                negative = true;
-            }
-            if (initial == '0' && string.charAt(negative ? 2 : 1) == '0') {
-                return string;
-            }
-            if ((initial >= '0' && initial <= '9')) {
-                if (string.indexOf('.') >= 0) {
-                    return Double.valueOf(string);
-                } else if (string.indexOf('e') < 0 && string.indexOf('E') < 0) {
-                    Long myLong = new Long(string);
-                    if (myLong.longValue() == myLong.intValue()) {
-                        return new Integer(myLong.intValue());
-                    } else {
-                        return myLong;
-                    }
-                }
-            }
-        }  catch (Exception ignore) {
-        }
-        return string;
-    }
-
-    
-    /**
-     * Convert a well-formed (but not necessarily valid) XML string into a
-     * JSONObject. Some information may be lost in this transformation
-     * because JSON is a data format and XML is a document format. XML uses
-     * elements, attributes, and content text, while JSON uses unordered
-     * collections of name/value pairs and arrays of values. JSON does not
-     * does not like to distinguish between elements and attributes.
-     * Sequences of similar elements are represented as JSONArrays. Content
-     * text may be placed in a "content" member. Comments, prologs, DTDs, and
-     * <code>&lt;[ [ ]]></code> are ignored.
-     * @param string The source string.
-     * @return A JSONObject containing the structured data from the XML string.
-     * @throws JSONException
-     */
-    public static JSONObject toJSONObject(String string) throws JSONException {
-        JSONObject jo = new JSONObject();
-        XMLTokener x = new XMLTokener(string);
-        while (x.more() && x.skipPast("<")) {
-            parse(x, jo, null);
-        }
-        return jo;
-    }
-
-
-    /**
-     * Convert a JSONObject into a well-formed, element-normal XML string.
-     * @param object A JSONObject.
-     * @return  A string.
-     * @throws  JSONException
-     */
-    public static String toString(Object object) throws JSONException {
-        return toString(object, null);
-    }
-
-
-    /**
-     * Convert a JSONObject into a well-formed, element-normal XML string.
-     * @param object A JSONObject.
-     * @param tagName The optional name of the enclosing tag.
-     * @return A string.
-     * @throws JSONException
-     */
-    public static String toString(Object object, String tagName)
-            throws JSONException {
-        StringBuffer sb = new StringBuffer();
-        int          i;
-        JSONArray    ja;
-        JSONObject   jo;
-        String       key;
-        Iterator     keys;
-        int          length;
-        String       string;
-        Object       value;
-        if (object instanceof JSONObject) {
-
-// Emit <tagName>
-
-            if (tagName != null) {
-                sb.append('<');
-                sb.append(tagName);
-                sb.append('>');
-            }
-
-// Loop thru the keys.
-
-            jo = (JSONObject)object;
-            keys = jo.keys();
-            while (keys.hasNext()) {
-                key = keys.next().toString();
-                value = jo.opt(key);
-                if (value == null) {
-                    value = "";
-                }
-                if (value instanceof String) {
-                    string = (String)value;
-                } else {
-                    string = null;
-                }
-
-// Emit content in body
-
-                if ("content".equals(key)) {
-                    if (value instanceof JSONArray) {
-                        ja = (JSONArray)value;
-                        length = ja.length();
-                        for (i = 0; i < length; i += 1) {
-                            if (i > 0) {
-                                sb.append('\n');
-                            }
-                            sb.append(escape(ja.get(i).toString()));
-                        }
-                    } else {
-                        sb.append(escape(value.toString()));
-                    }
-
-// Emit an array of similar keys
-
-                } else if (value instanceof JSONArray) {
-                    ja = (JSONArray)value;
-                    length = ja.length();
-                    for (i = 0; i < length; i += 1) {
-                        value = ja.get(i);
-                        if (value instanceof JSONArray) {
-                            sb.append('<');
-                            sb.append(key);
-                            sb.append('>');
-                            sb.append(toString(value));
-                            sb.append("</");
-                            sb.append(key);
-                            sb.append('>');
-                        } else {
-                            sb.append(toString(value, key));
-                        }
-                    }
-                } else if ("".equals(value)) {
-                    sb.append('<');
-                    sb.append(key);
-                    sb.append("/>");
-
-// Emit a new tag <k>
-
-                } else {
-                    sb.append(toString(value, key));
-                }
-            }
-            if (tagName != null) {
-
-// Emit the </tagname> close tag
-
-                sb.append("</");
-                sb.append(tagName);
-                sb.append('>');
-            }
-            return sb.toString();
-
-// XML does not have good support for arrays. If an array appears in a place
-// where XML is lacking, synthesize an <array> element.
-
-        } else {
-            if (object.getClass().isArray()) {
-                object = new JSONArray(object);
-            }
-            if (object instanceof JSONArray) {
-                ja = (JSONArray)object;
-                length = ja.length();
-                for (i = 0; i < length; i += 1) {
-                    sb.append(toString(ja.opt(i), tagName == null ? "array" : tagName));
-                }
-                return sb.toString();
-            } else {
-                string = (object == null) ? "null" : escape(object.toString());
-                return (tagName == null) ? "\"" + string + "\"" :
-                    (string.length() == 0) ? "<" + tagName + "/>" :
-                    "<" + tagName + ">" + string + "</" + tagName + ">";
-            }
-        }
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XMLTokener.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XMLTokener.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XMLTokener.java
deleted file mode 100644
index aa18c85..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/json/XMLTokener.java
+++ /dev/null
@@ -1,360 +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 com.vmware.geode.tools.pulse.internal.json;
-
-/**
- * The XMLTokener extends the JSONTokener to provide additional methods
- * for the parsing of XML texts.
- * @author JSON.org
- * @version 2010-12-24
- */
-public class XMLTokener extends JSONTokener {
-
-
-   /** The table of entity values. It initially contains Character values for
-    * amp, apos, gt, lt, quot.
-    */
-   public static final java.util.HashMap entity;
-
-   static {
-       entity = new java.util.HashMap(8);
-       entity.put("amp",  XML.AMP);
-       entity.put("apos", XML.APOS);
-       entity.put("gt",   XML.GT);
-       entity.put("lt",   XML.LT);
-       entity.put("quot", XML.QUOT);
-   }
-
-    /**
-     * Construct an XMLTokener from a string.
-     * @param s A source string.
-     */
-    public XMLTokener(String s) {
-        super(s);
-    }
-
-    /**
-     * Get the text in the CDATA block.
-     * @return The string up to the <code>]]&gt;</code>.
-     * @throws JSONException If the <code>]]&gt;</code> is not found.
-     */
-    public String nextCDATA() throws JSONException {
-        char         c;
-        int          i;
-        StringBuffer sb = new StringBuffer();
-        for (;;) {
-            c = next();
-            if (end()) {
-                throw syntaxError("Unclosed CDATA");
-            }
-            sb.append(c);
-            i = sb.length() - 3;
-            if (i >= 0 && sb.charAt(i) == ']' &&
-                          sb.charAt(i + 1) == ']' && sb.charAt(i + 2) == '>') {
-                sb.setLength(i);
-                return sb.toString();
-            }
-        }
-    }
-
-
-    /**
-     * Get the next XML outer token, trimming whitespace. There are two kinds
-     * of tokens: the '<' character which begins a markup tag, and the content
-     * text between markup tags.
-     *
-     * @return  A string, or a '<' Character, or null if there is no more
-     * source text.
-     * @throws JSONException
-     */
-    public Object nextContent() throws JSONException {
-        char         c;
-        StringBuffer sb;
-        do {
-            c = next();
-        } while (Character.isWhitespace(c));
-        if (c == 0) {
-            return null;
-        }
-        if (c == '<') {
-            return XML.LT;
-        }
-        sb = new StringBuffer();
-        for (;;) {
-            if (c == '<' || c == 0) {
-                back();
-                return sb.toString().trim();
-            }
-            if (c == '&') {
-                sb.append(nextEntity(c));
-            } else {
-                sb.append(c);
-            }
-            c = next();
-        }
-    }
-
-
-    /**
-     * Return the next entity. These entities are translated to Characters:
-     *     <code>&amp;  &apos;  &gt;  &lt;  &quot;</code>.
-     * @param ampersand An ampersand character.
-     * @return  A Character or an entity String if the entity is not recognized.
-     * @throws JSONException If missing ';' in XML entity.
-     */
-    public Object nextEntity(char ampersand) throws JSONException {
-        StringBuffer sb = new StringBuffer();
-        for (;;) {
-            char c = next();
-            if (Character.isLetterOrDigit(c) || c == '#') {
-                sb.append(Character.toLowerCase(c));
-            } else if (c == ';') {
-                break;
-            } else {
-                throw syntaxError("Missing ';' in XML entity: &" + sb);
-            }
-        }
-        String string = sb.toString();
-        Object object = entity.get(string);
-        return object != null ? object : ampersand + string + ";";
-    }
-
-
-    /**
-     * Returns the next XML meta token. This is used for skipping over <!...>
-     * and <?...?> structures.
-     * @return Syntax characters (<code>< > / = ! ?</code>) are returned as
-     *  Character, and strings and names are returned as Boolean. We don't care
-     *  what the values actually are.
-     * @throws JSONException If a string is not properly closed or if the XML
-     *  is badly structured.
-     */
-    public Object nextMeta() throws JSONException {
-        char c;
-        char q;
-        do {
-            c = next();
-        } while (Character.isWhitespace(c));
-        switch (c) {
-        case 0:
-            throw syntaxError("Misshaped meta tag");
-        case '<':
-            return XML.LT;
-        case '>':
-            return XML.GT;
-        case '/':
-            return XML.SLASH;
-        case '=':
-            return XML.EQ;
-        case '!':
-            return XML.BANG;
-        case '?':
-            return XML.QUEST;
-        case '"':
-        case '\'':
-            q = c;
-            for (;;) {
-                c = next();
-                if (c == 0) {
-                    throw syntaxError("Unterminated string");
-                }
-                if (c == q) {
-                    return Boolean.TRUE;
-                }
-            }
-        default:
-            for (;;) {
-                c = next();
-                if (Character.isWhitespace(c)) {
-                    return Boolean.TRUE;
-                }
-                switch (c) {
-                case 0:
-                case '<':
-                case '>':
-                case '/':
-                case '=':
-                case '!':
-                case '?':
-                case '"':
-                case '\'':
-                    back();
-                    return Boolean.TRUE;
-                }
-            }
-        }
-    }
-
-
-    /**
-     * Get the next XML Token. These tokens are found inside of angle
-     * brackets. It may be one of these characters: <code>/ > = ! ?</code> or it
-     * may be a string wrapped in single quotes or double quotes, or it may be a
-     * name.
-     * @return a String or a Character.
-     * @throws JSONException If the XML is not well formed.
-     */
-    public Object nextToken() throws JSONException {
-        char c;
-        char q;
-        StringBuffer sb;
-        do {
-            c = next();
-        } while (Character.isWhitespace(c));
-        switch (c) {
-        case 0:
-            throw syntaxError("Misshaped element");
-        case '<':
-            throw syntaxError("Misplaced '<'");
-        case '>':
-            return XML.GT;
-        case '/':
-            return XML.SLASH;
-        case '=':
-            return XML.EQ;
-        case '!':
-            return XML.BANG;
-        case '?':
-            return XML.QUEST;
-
-// Quoted string
-
-        case '"':
-        case '\'':
-            q = c;
-            sb = new StringBuffer();
-            for (;;) {
-                c = next();
-                if (c == 0) {
-                    throw syntaxError("Unterminated string");
-                }
-                if (c == q) {
-                    return sb.toString();
-                }
-                if (c == '&') {
-                    sb.append(nextEntity(c));
-                } else {
-                    sb.append(c);
-                }
-            }
-        default:
-
-// Name
-
-            sb = new StringBuffer();
-            for (;;) {
-                sb.append(c);
-                c = next();
-                if (Character.isWhitespace(c)) {
-                    return sb.toString();
-                }
-                switch (c) {
-                case 0:
-                    return sb.toString();
-                case '>':
-                case '/':
-                case '=':
-                case '!':
-                case '?':
-                case '[':
-                case ']':
-                    back();
-                    return sb.toString();
-                case '<':
-                case '"':
-                case '\'':
-                    throw syntaxError("Bad character in a name");
-                }
-            }
-        }
-    }
-    
-    
-    /**
-     * Skip characters until past the requested string.
-     * If it is not found, we are left at the end of the source with a result of false.
-     * @param to A string to skip past.
-     * @throws JSONException
-     */
-    public boolean skipPast(String to) throws JSONException {
-        boolean b;
-        char c;
-        int i;
-        int j;
-        int offset = 0;
-        int length = to.length();
-        char[] circle = new char[length];
-        
-        /*
-         * First fill the circle buffer with as many characters as are in the
-         * to string. If we reach an early end, bail.
-         */
-        
-        for (i = 0; i < length; i += 1) {
-            c = next();
-            if (c == 0) {
-                return false;
-            }
-            circle[i] = c;
-        }
-        /*
-         * We will loop, possibly for all of the remaining characters.
-         */
-        for (;;) {
-            j = offset;
-            b = true;
-            /*
-             * Compare the circle buffer with the to string. 
-             */
-            for (i = 0; i < length; i += 1) {
-                if (circle[j] != to.charAt(i)) {
-                    b = false;
-                    break;
-                }
-                j += 1;
-                if (j >= length) {
-                    j -= length;
-                }
-            }
-            /*
-             * If we exit the loop with b intact, then victory is ours.
-             */
-            if (b) {
-                return true;
-            }
-            /*
-             * Get the next character. If there isn't one, then defeat is ours.
-             */
-            c = next();
-            if (c == 0) {
-                return false;
-            }
-            /*
-             * Shove the character in the circle buffer and advance the 
-             * circle offset. The offset is mod n.
-             */
-            circle[offset] = c;
-            offset += 1;
-            if (offset >= length) {
-                offset -= length;
-            }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/LogWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/LogWriter.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/LogWriter.java
deleted file mode 100644
index 662c561..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/LogWriter.java
+++ /dev/null
@@ -1,265 +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 com.vmware.geode.tools.pulse.internal.log;
-
-/**
- * interface LogWriter
- * 
- * LogWriter interface for Pulse Logging.
- * 
- * @since GemFire 7.0.1
- * 
- */
-public interface LogWriter {
-  /**
-   * Returns true if "severe" log messages are enabled. Returns false if
-   * "severe" log messages are disabled.
-   */
-  public boolean severeEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "severe".
-   */
-  public void severe(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "severe".
-   */
-  public void severe(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "severe".
-   */
-  public void severe(Throwable ex);
-
-  /**
-   * Returns true if "error" log messages are enabled. Returns false if "error"
-   * log messages are disabled.
-   */
-  // public boolean errorEnabled();
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "error".
-   */
-  // public void error(String msg, Throwable ex);
-  /**
-   * Writes a message to this writer. The message level is "error".
-   */
-  // public void error(String msg);
-  /**
-   * Writes an exception to this writer. The exception level is "error".
-   */
-  // public void error(Throwable ex);
-  /**
-   * Returns true if "warning" log messages are enabled. Returns false if
-   * "warning" log messages are disabled.
-   */
-  public boolean warningEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "warning".
-   */
-  public void warning(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "warning".
-   */
-  public void warning(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "warning".
-   */
-  public void warning(Throwable ex);
-
-  /**
-   * Returns true if "info" log messages are enabled. Returns false if "info"
-   * log messages are disabled.
-   */
-  public boolean infoEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "information".
-   */
-  public void info(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "information".
-   */
-  public void info(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "information".
-   */
-  public void info(Throwable ex);
-
-  /**
-   * Returns true if "config" log messages are enabled. Returns false if
-   * "config" log messages are disabled.
-   */
-  public boolean configEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "config".
-   */
-  public void config(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "config".
-   */
-  public void config(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "config".
-   */
-  public void config(Throwable ex);
-
-  /**
-   * Returns true if "fine" log messages are enabled. Returns false if "fine"
-   * log messages are disabled.
-   */
-  public boolean fineEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "fine".
-   */
-  public void fine(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "fine".
-   */
-  public void fine(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "fine".
-   */
-  public void fine(Throwable ex);
-
-  /**
-   * Returns true if "finer" log messages are enabled. Returns false if "finer"
-   * log messages are disabled.
-   */
-  public boolean finerEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "finer".
-   */
-  public void finer(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "finer".
-   */
-  public void finer(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "finer".
-   */
-  public void finer(Throwable ex);
-
-  /**
-   * Log a method entry.
-   * <p>
-   * The logging is done using the <code>finer</code> level. The string message
-   * will start with <code>"ENTRY"</code> and include the class and method
-   * names.
-   * 
-   * @param sourceClass
-   *          Name of class that issued the logging request.
-   * @param sourceMethod
-   *          Name of the method that issued the logging request.
-   */
-  public void entering(String sourceClass, String sourceMethod);
-
-  /**
-   * Log a method return.
-   * <p>
-   * The logging is done using the <code>finer</code> level. The string message
-   * will start with <code>"RETURN"</code> and include the class and method
-   * names.
-   * 
-   * @param sourceClass
-   *          Name of class that issued the logging request.
-   * @param sourceMethod
-   *          Name of the method that issued the logging request.
-   */
-  public void exiting(String sourceClass, String sourceMethod);
-
-  /**
-   * Log throwing an exception.
-   * <p>
-   * Use to log that a method is terminating by throwing an exception. The
-   * logging is done using the <code>finer</code> level.
-   * <p>
-   * This is a convenience method that could be done instead by calling
-   * {@link #finer(String, Throwable)}. The string message will start with
-   * <code>"THROW"</code> and include the class and method names.
-   * 
-   * @param sourceClass
-   *          Name of class that issued the logging request.
-   * @param sourceMethod
-   *          Name of the method that issued the logging request.
-   * @param thrown
-   *          The Throwable that is being thrown.
-   */
-  public void throwing(String sourceClass, String sourceMethod, Throwable thrown);
-
-  /**
-   * Returns true if "finest" log messages are enabled. Returns false if
-   * "finest" log messages are disabled.
-   */
-  public boolean finestEnabled();
-
-  /**
-   * Writes both a message and exception to this writer. The message level is
-   * "finest".
-   */
-  public void finest(String msg, Throwable ex);
-
-  /**
-   * Writes a message to this writer. The message level is "finest".
-   */
-  public void finest(String msg);
-
-  /**
-   * Writes an exception to this writer. The exception level is "finest".
-   */
-  public void finest(Throwable ex);
-
-  /**
-   * Returns a 1.4 logging handler that can be used to direct application output
-   * to this GemFire logger using the standard JDK logger APIs. Each time this
-   * method is called it creates a new instance of a Handler so care should be
-   * taken to not call this method too often.
-   */
-  // public Handler getHandler();
-
-  /**
-   * A mechanism for accessing the abstraction layer used for
-   * internationalization.
-   * 
-   * @return LogWriterI18n
-   */
-  // public LogWriterI18n convertToLogWriterI18n();
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/MessageFormatter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/MessageFormatter.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/MessageFormatter.java
deleted file mode 100644
index 11fe290..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/MessageFormatter.java
+++ /dev/null
@@ -1,102 +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 com.vmware.geode.tools.pulse.internal.log;
-
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.text.DateFormat;
-import java.text.SimpleDateFormat;
-import java.util.Date;
-import java.util.logging.Formatter;
-import java.util.logging.Handler;
-import java.util.logging.LogRecord;
-
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-
-/**
- * Class MessageFormatter
- * 
- * MessageFormatter is the custom formatter class for formatting the log
- * messages.
- * 
- * @since GemFire version 7.0.1
- */
-public class MessageFormatter extends Formatter {
-
-  public MessageFormatter() {
-    super();
-  }
-
-  @Override
-  public String format(LogRecord record) {
-    DateFormat df = new SimpleDateFormat(Repository.get().getPulseConfig()
-        .getLogDatePattern());
-    StringWriter sw = new StringWriter();
-    PrintWriter pw = new PrintWriter(sw);
-
-    pw.println();
-    pw.print("[");
-    pw.print(record.getLevel().getName());
-    pw.print(" ");
-    pw.print(df.format(new Date(record.getMillis())));
-    String threadName = Thread.currentThread().getName();
-    if (threadName != null) {
-      pw.print(" ");
-      pw.print(threadName);
-    }
-    pw.print(" tid=0x");
-    pw.print(Long.toHexString(Thread.currentThread().getId()));
-    pw.print("] ");
-    pw.print("(msgTID=");
-    pw.print(record.getThreadID());
-
-    pw.print(" msgSN=");
-    pw.print(record.getSequenceNumber());
-
-    pw.print(") ");
-
-    pw.println("[" + PulseConstants.APP_NAME + "]");
-
-    pw.println("[" + record.getLoggerName() + "]");
-
-    pw.println(record.getMessage());
-
-    if (record.getThrown() != null) {
-      record.getThrown().printStackTrace(pw);
-    }
-    pw.close();
-    try {
-      sw.close();
-    } catch (IOException ignore) {
-    }
-    String result = sw.toString();
-    return result;
-  }
-
-  public String getHead(Handler h) {
-    return super.getHead(h);
-  }
-
-  public String getTail(Handler h) {
-    return super.getTail(h);
-  }
-} // End of Class MessageFormatter

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogWriter.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogWriter.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogWriter.java
deleted file mode 100644
index fe4e88b..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogWriter.java
+++ /dev/null
@@ -1,299 +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 com.vmware.geode.tools.pulse.internal.log;
-
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.util.logging.FileHandler;
-import java.util.logging.Level;
-import java.util.logging.Logger;
-
-import com.vmware.geode.tools.pulse.internal.data.PulseConfig;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-
-/**
- * Class PulseLogWriter
- * 
- * PulseLogWriter is the implementation of LogWriter.
- * 
- * @since GemFire 7.0.1
- * 
- */
-public class PulseLogWriter implements LogWriter {
-
-  // Log File handle Object
-  private FileHandler fileHandler;
-
-  // Message Formatter Object
-  private static MessageFormatter messageformatter;
-
-  // pulse log writer
-  private static PulseLogWriter pulseLogger = null;
-
-  // Logger Object
-  private Logger logger;
-
-  private PulseLogWriter() {
-    PulseConfig pulseConfig = Repository.get().getPulseConfig();
-    // Create Logger
-    logger = Logger.getLogger(this.getClass().getName());
-
-    // Set minimum log level to level passed
-    logger.setLevel(pulseConfig.getLogLevel());
-
-    try {
-      // Get file handler to log messages into log file.
-      if (fileHandler == null) {
-        fileHandler = new FileHandler(
-            pulseConfig.getLogFileFullName(),
-            pulseConfig.getLogFileSize(),
-            pulseConfig.getLogFileCount(),
-            pulseConfig.getLogAppend());
-
-        // Log Message Formatter
-        messageformatter = new MessageFormatter();
-        fileHandler.setFormatter(messageformatter);
-      }
-
-      // Add File Handler to logger object
-      logger.addHandler(fileHandler);
-    } catch (SecurityException e) {
-      logger.setUseParentHandlers(true);
-      e.printStackTrace();
-    } catch (IOException e) {
-      logger.setUseParentHandlers(true);
-      e.printStackTrace();
-    } catch (Exception e) {
-      e.printStackTrace();
-    }
-  }
-
-  /**
-   * @param jsonErr
-   * @param errorData
-   */
-  public void logJSONError(Exception jsonErr, Object errorData) {
-
-    // print details of thrown exception and data that couldn't be converted to
-    // json
-    if (this.fineEnabled()) {
-
-      // write errors
-      StringWriter swBuffer = new StringWriter();
-      PrintWriter prtWriter = new PrintWriter(swBuffer);
-      jsonErr.printStackTrace(prtWriter);
-      this.fine("JSON Error Details : " + swBuffer.toString() + "\n");
-
-      this.fine("Erroneous Data : "
-          + ((errorData != null) ? errorData.toString()
-              : "Not Available for output") + "\n");
-    }
-  }
-
-  public static synchronized PulseLogWriter getLogger() {
-    if (null == pulseLogger) {
-      pulseLogger = new PulseLogWriter();
-    }
-    return pulseLogger;
-  }
-
-  @Override
-  public boolean severeEnabled() {
-    return logger.isLoggable(Level.SEVERE);
-  }
-
-  @Override
-  public void severe(String msg, Throwable ex) {
-    logger.logp(Level.SEVERE, "", "", msg, ex);
-  }
-
-  @Override
-  public void severe(String msg) {
-    logger.severe(msg);
-  }
-
-  @Override
-  public void severe(Throwable ex) {
-    logger.logp(Level.SEVERE, "", "", "", ex);
-  }
-
-  /*
-  @Override
-  public boolean errorEnabled() {
-    // TODO Auto-generated method stub
-    return false;
-  }
-
-  @Override
-  public void error(String msg, Throwable ex) {
-    // TODO Auto-generated method stub
-
-  }
-
-  @Override
-  public void error(String msg) {
-    // TODO Auto-generated method stub
-
-  }
-
-  @Override
-  public void error(Throwable ex) {
-    // TODO Auto-generated method stub
-
-  }
-  */
-
-  @Override
-  public boolean warningEnabled() {
-    return logger.isLoggable(Level.WARNING);
-  }
-
-  @Override
-  public void warning(String msg, Throwable ex) {
-    logger.logp(Level.WARNING, "", "", msg, ex);
-  }
-
-  @Override
-  public void warning(String msg) {
-    logger.warning(msg);
-  }
-
-  @Override
-  public void warning(Throwable ex) {
-    logger.logp(Level.WARNING, "", "", "", ex);
-  }
-
-  @Override
-  public boolean infoEnabled() {
-    return logger.isLoggable(Level.INFO);
-  }
-
-  @Override
-  public void info(String msg, Throwable ex) {
-    logger.logp(Level.INFO, "", "", msg, ex);
-  }
-
-  @Override
-  public void info(String msg) {
-    logger.info(msg);
-  }
-
-  @Override
-  public void info(Throwable ex) {
-    logger.logp(Level.WARNING, "", "", "", ex);
-  }
-
-  @Override
-  public boolean configEnabled() {
-    return logger.isLoggable(Level.CONFIG);
-  }
-
-  @Override
-  public void config(String msg, Throwable ex) {
-    logger.logp(Level.CONFIG, "", "", msg, ex);
-  }
-
-  @Override
-  public void config(String msg) {
-    logger.config(msg);
-  }
-
-  @Override
-  public void config(Throwable ex) {
-    logger.logp(Level.CONFIG, "", "", "", ex);
-  }
-
-  @Override
-  public boolean fineEnabled() {
-    return logger.isLoggable(Level.FINE);
-  }
-
-  @Override
-  public void fine(String msg, Throwable ex) {
-    logger.logp(Level.FINE, "", "", msg, ex);
-  }
-
-  @Override
-  public void fine(String msg) {
-    logger.fine(msg);
-  }
-
-  @Override
-  public void fine(Throwable ex) {
-    logger.logp(Level.FINE, "", "", "", ex);
-  }
-
-  @Override
-  public boolean finerEnabled() {
-    return logger.isLoggable(Level.FINER);
-  }
-
-  @Override
-  public void finer(String msg, Throwable ex) {
-    logger.logp(Level.FINER, "", "", msg, ex);
-  }
-
-  @Override
-  public void finer(String msg) {
-    logger.finer(msg);
-  }
-
-  @Override
-  public void finer(Throwable ex) {
-    logger.logp(Level.FINER, "", "", "", ex);
-  }
-
-  @Override
-  public void entering(String sourceClass, String sourceMethod) {
-    logger.entering(sourceClass, sourceMethod);
-  }
-
-  @Override
-  public void exiting(String sourceClass, String sourceMethod) {
-    logger.exiting(sourceClass, sourceMethod);
-  }
-
-  @Override
-  public void throwing(String sourceClass, String sourceMethod, Throwable thrown) {
-    logger.throwing(sourceClass, sourceMethod, thrown);
-  }
-
-  @Override
-  public boolean finestEnabled() {
-    return logger.isLoggable(Level.FINEST);
-  }
-
-  @Override
-  public void finest(String msg, Throwable ex) {
-    logger.logp(Level.FINEST, "", "", msg, ex);
-  }
-
-  @Override
-  public void finest(String msg) {
-    logger.finest(msg);
-  }
-
-  @Override
-  public void finest(Throwable ex) {
-    logger.logp(Level.FINEST, "", "", "", ex);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogger.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogger.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogger.java
deleted file mode 100644
index 2de81bd..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/log/PulseLogger.java
+++ /dev/null
@@ -1,142 +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 com.vmware.geode.tools.pulse.internal.log;
-
-import java.io.IOException;
-import java.text.DateFormat;
-import java.text.SimpleDateFormat;
-import java.util.Date;
-import java.util.logging.FileHandler;
-import java.util.logging.Formatter;
-import java.util.logging.Handler;
-import java.util.logging.Level;
-import java.util.logging.LogRecord;
-import java.util.logging.Logger;
-
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-
-/**
- * Class PulseLogger
- * 
- * PulseLogger is the custom logger class for Pulse Web Application. It logs
- * messages to the file in custom format.
- * 
- * @since GemFire version 7.0.Beta
- */
-public class PulseLogger {
-
-  // Pulse Application Log File
-  private static final String LOG_FILE_NAME = PulseConstants.PULSE_LOG_FILE_LOCATION
-      + "/" + PulseConstants.PULSE_LOG_FILE;
-
-  // Date pattern to be used in log messages
-  public static final String LOG_MESSAGE_DATE_PATTERN = "dd/MM/yyyy hh:mm:ss.SSS";
-
-  // The log file size is set to 1MB.
-  public static final int FILE_SIZE = 1024 * 1024;
-
-  // The log file count set to 1 files.
-  public static final int FILE_COUNT = 5;
-
-  // Append logs is set to true.
-  public static final boolean FLAG_APPEND = true;
-
-  // Log File handle Object
-  private static FileHandler fileHandler;
-
-  // Message Formatter Object
-  private static MessageFormatter messageformatter;
-
-  // Logger Object
-  private static Logger logger;
-
-  public static Logger getLogger(String name) {
-    // Create Logger
-    logger = Logger.getLogger(name);
-
-    // Set minimum log level to inform
-    logger.setLevel(Level.INFO);
-
-    // Get file handler to log messages into log file.
-    try {
-      // fileHandler = new FileHandler(LOG_FILE_NAME, FILE_SIZE, FILE_COUNT,
-      // FLAG_APPEND);
-      fileHandler = new FileHandler(LOG_FILE_NAME, FLAG_APPEND);
-
-      // Log Message Formatter
-      messageformatter = new MessageFormatter();
-
-      fileHandler.setFormatter(messageformatter);
-
-      // Add File Handler to logger object
-      logger.addHandler(fileHandler);
-
-    } catch (SecurityException e) {
-      e.printStackTrace();
-    } catch (IOException e) {
-      e.printStackTrace();
-    } catch (Exception e) {
-      e.printStackTrace();
-    }
-
-    return logger;
-  }
-
-  /**
-   * Class MessageFormatter
-   * 
-   * MessageFormatter is the custom formatter class for formatting the log
-   * messages.
-   * 
-   * @since GemFire version 7.0.Beta 2012-09-23
-   */
-  private static class MessageFormatter extends Formatter {
-
-    public MessageFormatter() {
-      super();
-    }
-
-    @Override
-    public String format(LogRecord record) {
-      // Set DateFormat
-      DateFormat df = new SimpleDateFormat(PulseLogger.LOG_MESSAGE_DATE_PATTERN);
-      StringBuilder builder = new StringBuilder(1000);
-
-      // Format Log Message
-      builder.append(df.format(new Date(record.getMillis()))).append(" - ");
-      builder.append("[ " + PulseConstants.APP_NAME + " ] - ");
-      builder.append("[").append(record.getSourceClassName()).append(".");
-      builder.append(record.getSourceMethodName()).append("] - ");
-      builder.append("[").append(record.getLevel()).append("] - ");
-      builder.append(formatMessage(record));
-      builder.append(System.getProperty("line.separator"));
-
-      return builder.toString();
-    }
-
-    public String getHead(Handler h) {
-      return super.getHead(h);
-    }
-
-    public String getTail(Handler h) {
-      return super.getTail(h);
-    }
-  } // End of Class MessageFormatter
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthentication.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthentication.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthentication.java
deleted file mode 100644
index 6506667..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthentication.java
+++ /dev/null
@@ -1,91 +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 com.vmware.geode.tools.pulse.internal.security;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import javax.management.MBeanServerConnection;
-import javax.management.ObjectName;
-import javax.management.remote.JMXConnector;
-
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-
-import org.springframework.security.authentication.UsernamePasswordAuthenticationToken;
-import org.springframework.security.core.GrantedAuthority;
-import org.springframework.security.core.SpringSecurityCoreVersion;
-import org.springframework.security.core.authority.SimpleGrantedAuthority;
-
-/**
- * Spring security authentication object for GemFire
- * <p>
- * To use GemFire Integrated Security Model set Spring Application Profile to pulse.authentication.gemfire
- * <p>
- * 1. Authentication :
- * 1.a GemFire profile creates JMX connection with given credentials at the login time.
- * 1.b Successful connect is considered as Successful Authentication for Pulse WebApp
- * <p>
- * <p>
- * 2. Authorization :
- * 2.a Using newly created authenticated connection AccessControlMXBean is called to get authentication
- * levels. See @See {@link #populateAuthorities(JMXConnector)}. This sets Spring Security Authorities
- * 2.b DataBrowser end-points are required to be authorized against Spring Granted Authority
- * @since GemFire version 9.0
- */
-public class GemFireAuthentication extends UsernamePasswordAuthenticationToken {
-
-  private final static PulseLogWriter logger = PulseLogWriter.getLogger();
-
-  private JMXConnector jmxc = null;
-
-  public GemFireAuthentication(Object principal, Object credentials, Collection<GrantedAuthority> list, JMXConnector jmxc) {
-    super(principal, credentials, list);
-    this.jmxc = jmxc;
-  }
-
-  private static final long serialVersionUID = SpringSecurityCoreVersion.SERIAL_VERSION_UID;
-
-  public static ArrayList<GrantedAuthority> populateAuthorities(JMXConnector jmxc) {
-    ObjectName name;
-    ArrayList<GrantedAuthority> authorities = new ArrayList<>();
-    try {
-      name = new ObjectName(PulseConstants.OBJECT_NAME_ACCESSCONTROL_MBEAN);
-      MBeanServerConnection mbeanServer = jmxc.getMBeanServerConnection();
-
-      for (String role : PulseConstants.PULSE_ROLES) {
-        Object[] params = role.split(":");
-        String[] signature = new String[] { String.class.getCanonicalName(), String.class.getCanonicalName() };
-        boolean result = (Boolean) mbeanServer.invoke(name, "authorize", params, signature);
-        if (result) {
-          authorities.add(new SimpleGrantedAuthority(role));
-        }
-      }
-    }
-    catch (Exception e) {
-      throw new RuntimeException(e.getMessage(), e);
-    }
-
-    return authorities;
-
-  }
-
-  public JMXConnector getJmxc() {
-    return jmxc;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthenticationProvider.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthenticationProvider.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthenticationProvider.java
deleted file mode 100644
index cd37aea..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/GemFireAuthenticationProvider.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 com.vmware.geode.tools.pulse.internal.security;
-
-import java.util.Collection;
-import javax.management.remote.JMXConnector;
-
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-
-import org.springframework.security.authentication.AuthenticationProvider;
-import org.springframework.security.authentication.AuthenticationServiceException;
-import org.springframework.security.authentication.BadCredentialsException;
-import org.springframework.security.authentication.UsernamePasswordAuthenticationToken;
-import org.springframework.security.core.Authentication;
-import org.springframework.security.core.AuthenticationException;
-import org.springframework.security.core.GrantedAuthority;
-
-/**
- * Spring security AuthenticationProvider for GemFire. It connects to gemfire manager using given credentials.
- * Successful connect is treated as successful authentication and web user is authenticated
- * @since GemFire version 9.0
- */
-public class GemFireAuthenticationProvider implements AuthenticationProvider {
-
-  private final static PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-
-  public GemFireAuthenticationProvider() {
-    System.out.println("here");
-  }
-
-  @Override
-  public Authentication authenticate(Authentication authentication) throws AuthenticationException {
-
-    if (authentication instanceof GemFireAuthentication) {
-      GemFireAuthentication gemAuth = (GemFireAuthentication) authentication;
-      LOGGER.fine("GemAuthentication is connected? = " + gemAuth.getJmxc());
-      if (gemAuth.getJmxc() != null && gemAuth.isAuthenticated()) return gemAuth;
-    }
-
-    String name = authentication.getName();
-    String password = authentication.getCredentials().toString();
-
-    try {
-      LOGGER.fine("Connecting to GemFire with user=" + name);
-      JMXConnector jmxc = Repository.get().getCluster(name, password).connectToGemFire();
-      if (jmxc != null) {
-        Collection<GrantedAuthority> list = GemFireAuthentication.populateAuthorities(jmxc);
-        GemFireAuthentication auth = new GemFireAuthentication(authentication.getPrincipal(),
-            authentication.getCredentials(), list, jmxc);
-        LOGGER.fine("For user " + name + " authList=" + list);
-        return auth;
-      } else {
-        throw new AuthenticationServiceException("JMX Connection unavailable");
-      }
-    } catch (Exception e) {
-      throw new BadCredentialsException("Error connecting to GemFire JMX Server", e);
-    }
-  }
-
-  @Override
-  public boolean supports(Class<?> authentication) {
-    return authentication.equals(UsernamePasswordAuthenticationToken.class);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/LogoutHandler.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/LogoutHandler.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/LogoutHandler.java
deleted file mode 100644
index 5056ce2..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/security/LogoutHandler.java
+++ /dev/null
@@ -1,55 +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 com.vmware.geode.tools.pulse.internal.security;
-
-import java.io.IOException;
-import javax.servlet.ServletException;
-import javax.servlet.http.HttpServletRequest;
-import javax.servlet.http.HttpServletResponse;
-
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import com.vmware.geode.tools.pulse.internal.log.PulseLogWriter;
-
-import org.springframework.security.core.Authentication;
-import org.springframework.security.web.authentication.logout.LogoutSuccessHandler;
-import org.springframework.security.web.authentication.logout.SimpleUrlLogoutSuccessHandler;
-
-/**
- * Handler is used to close jmx connection maintained at user-level
- *
- */
-public class LogoutHandler extends SimpleUrlLogoutSuccessHandler implements LogoutSuccessHandler {
-
-  public LogoutHandler(String defaultTargetURL) {
-    this.setDefaultTargetUrl(defaultTargetURL);
-  }
-
-  public void onLogoutSuccess(HttpServletRequest request, HttpServletResponse response, Authentication authentication)
-      throws IOException, ServletException {
-    PulseLogWriter LOGGER = PulseLogWriter.getLogger();
-    LOGGER.fine("Invoked #LogoutHandler ...");
-    if (Repository.get().isUseGemFireCredentials()) {
-      GemFireAuthentication gemauthentication = (GemFireAuthentication) authentication;
-      if(gemauthentication!=null) {
-        gemauthentication.getJmxc().close();
-        LOGGER.info("#LogoutHandler : Closing GemFireAuthentication JMX Connection...");
-      }
-    }
-    super.onLogoutSuccess(request, response, authentication);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDetailsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDetailsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDetailsService.java
deleted file mode 100644
index 8b5e409..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDetailsService.java
+++ /dev/null
@@ -1,104 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.PulseConstants;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-import java.text.DecimalFormat;
-
-/**
- * Class ClusterDetailsService
- * 
- * This service class has implementation for providing cluster's basic
- * statistical data.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterDetails")
-@Scope("singleton")
-public class ClusterDetailsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    String userName = request.getUserPrincipal().getName();
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    Cluster.Alert[] alertsList = cluster.getAlertsList();
-    int severeAlertCount = 0;
-    int errorAlertCount = 0;
-    int warningAlertCount = 0;
-    int infoAlertCount = 0;
-
-    for (Cluster.Alert alertObj : alertsList) {
-      if (alertObj.getSeverity() == Cluster.Alert.SEVERE) {
-        severeAlertCount++;
-      } else if (alertObj.getSeverity() == Cluster.Alert.ERROR) {
-        errorAlertCount++;
-      } else if (alertObj.getSeverity() == Cluster.Alert.WARNING) {
-        warningAlertCount++;
-      } else {
-        infoAlertCount++;
-      }
-    }
-    // getting basic details of Cluster
-    responseJSON.put("clusterName", cluster.getServerName());
-    responseJSON.put("severeAlertCount", severeAlertCount);
-    responseJSON.put("errorAlertCount", errorAlertCount);
-    responseJSON.put("warningAlertCount", warningAlertCount);
-    responseJSON.put("infoAlertCount", infoAlertCount);
-
-    responseJSON.put("totalMembers", cluster.getMemberCount());
-    responseJSON.put("servers", cluster.getServerCount());
-    responseJSON.put("clients", cluster.getClientConnectionCount());
-    responseJSON.put("locators", cluster.getLocatorCount());
-    responseJSON.put("totalRegions", cluster.getTotalRegionCount());
-    Long heapSize = cluster.getTotalHeapSize();
-
-    DecimalFormat df2 = new DecimalFormat(
-        PulseConstants.DECIMAL_FORMAT_PATTERN);
-    Double heapS = heapSize.doubleValue() / 1024;
-    responseJSON.put("totalHeap", Double.valueOf(df2.format(heapS)));
-    responseJSON.put("functions", cluster.getRunningFunctionCount());
-    responseJSON.put("uniqueCQs", cluster.getRegisteredCQCount());
-    responseJSON.put("subscriptions", cluster.getSubscriptionCount());
-    responseJSON.put("txnCommitted", cluster.getTxnCommittedCount());
-    responseJSON.put("txnRollback", cluster.getTxnRollbackCount());
-    responseJSON.put("userName", userName);
-
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDiskThroughputService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDiskThroughputService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDiskThroughputService.java
deleted file mode 100644
index 11247bc..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterDiskThroughputService.java
+++ /dev/null
@@ -1,71 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class ClusterDiskThroughput This class contains implementations for getting
- * cluster's current disk throughput details and its trend over time
- * 
- * @since GemFire version 7.0.Beta
- */
-
-@Component
-@Service("ClusterDiskThroughput")
-@Scope("singleton")
-public class ClusterDiskThroughputService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    // cluster's Throughout Writes trend added to json response object
-    // CircularFifoBuffer throughoutWritesTrend =
-    // cluster.getThroughoutWritesTrend();
-    double currentThroughputWrites = cluster.getDiskWritesRate();
-    double currentThroughputReads = cluster.getDiskReadsRate();
-
-    responseJSON.put("currentThroughputReads", currentThroughputReads);
-    responseJSON.put("throughputReads",
-        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_THROUGHPUT_READS)));
-
-    responseJSON.put("currentThroughputWrites", currentThroughputWrites);
-    responseJSON.put("throughputWrites",
-        mapper.valueToTree( cluster.getStatisticTrend(Cluster.CLUSTER_STAT_THROUGHPUT_WRITES)));
-
-    // Send json response
-    return responseJSON;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterGCPausesService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterGCPausesService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterGCPausesService.java
deleted file mode 100644
index 52ba79c..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterGCPausesService.java
+++ /dev/null
@@ -1,69 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class ClusterGCPausesService
- * 
- * This class contains implementations of getting Cluster's GC Pauses (JVM
- * Pauses) Details and its trend over the time.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterJVMPauses")
-@Scope("singleton")
-public class ClusterGCPausesService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-    // cluster's GC Pauses trend added to json response object
-
-    ArrayNode pauses = mapper.createArrayNode();
-    for (Object obj : cluster.getStatisticTrend(Cluster.CLUSTER_STAT_GARBAGE_COLLECTION)) {
-      if (obj instanceof Number) {
-        pauses.add(((Number) obj).longValue());
-      }
-    }
-    responseJSON.put("currentGCPauses", cluster.getGarbageCollectionCount());
-    responseJSON.put("gCPausesTrend", pauses);
-    // Send json response
-    return responseJSON;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterKeyStatisticsService.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterKeyStatisticsService.java b/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterKeyStatisticsService.java
deleted file mode 100644
index 8c15ccc..0000000
--- a/geode-pulse/src/main/java/com/vmware/gemfire/tools/pulse/internal/service/ClusterKeyStatisticsService.java
+++ /dev/null
@@ -1,69 +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 com.vmware.geode.tools.pulse.internal.service;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ObjectNode;
-import com.vmware.geode.tools.pulse.internal.data.Cluster;
-import com.vmware.geode.tools.pulse.internal.data.Repository;
-import org.springframework.context.annotation.Scope;
-import org.springframework.stereotype.Component;
-import org.springframework.stereotype.Service;
-
-import javax.servlet.http.HttpServletRequest;
-
-/**
- * Class ClusterKeyStatisticsService
- * 
- * This class contains implementations of getting Cluster's current Reads,
- * Writes and queries details and their trends over the time.
- * 
- * @since GemFire version 7.5
- */
-
-@Component
-@Service("ClusterKeyStatistics")
-@Scope("singleton")
-public class ClusterKeyStatisticsService implements PulseService {
-
-  private final ObjectMapper mapper = new ObjectMapper();
-
-  public ObjectNode execute(final HttpServletRequest request) throws Exception {
-
-    // get cluster object
-    Cluster cluster = Repository.get().getCluster();
-
-    // json object to be sent as response
-    ObjectNode responseJSON = mapper.createObjectNode();
-
-    responseJSON.put("writePerSecTrend",
-        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_WRITES_PER_SECOND)));
-
-    responseJSON.put("readPerSecTrend",
-        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_READ_PER_SECOND)));
-
-    responseJSON.put("queriesPerSecTrend",
-        mapper.valueToTree(cluster.getStatisticTrend(Cluster.CLUSTER_STAT_QUERIES_PER_SECOND)));
-
-    // Send json response
-    return responseJSON;
-
-  }
-}


[54/83] [abbrv] incubator-geode git commit: GEODE-37 renamed pulse package

Posted by hi...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAbstractTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAbstractTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAbstractTest.java
new file mode 100644
index 0000000..21eddb6
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAbstractTest.java
@@ -0,0 +1,1047 @@
+/*
+ *
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import static org.junit.Assert.*;
+
+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;
+
+import com.jayway.awaitility.Awaitility;
+import org.junit.AfterClass;
+import org.junit.Before;
+import org.junit.Ignore;
+import org.junit.Test;
+import org.openqa.selenium.By;
+import org.openqa.selenium.JavascriptExecutor;
+import org.openqa.selenium.WebDriver;
+import org.openqa.selenium.WebElement;
+import org.openqa.selenium.firefox.FirefoxDriver;
+import org.openqa.selenium.interactions.Actions;
+import org.openqa.selenium.support.ui.ExpectedCondition;
+import org.openqa.selenium.support.ui.ExpectedConditions;
+import org.openqa.selenium.support.ui.WebDriverWait;
+
+import org.apache.geode.management.internal.JettyHelper;
+import org.apache.geode.tools.pulse.internal.data.PulseConstants;
+
+@SuppressWarnings("deprecated")
+public abstract class PulseAbstractTest extends PulseBaseTest {
+
+  private static String jmxPropertiesFile;
+  private static String path;
+
+  private static org.eclipse.jetty.server.Server jetty = null;
+  private static Server server = null;
+  private static String pulseURL = null;
+  public static WebDriver driver;
+
+  /* Constants for executing Data Browser queries */
+  public static final String QUERY_TYPE_ONE = "query1";
+  public static final String QUERY_TYPE_TWO = "query2";
+  public static final String QUERY_TYPE_THREE = "query3";
+  public static final String QUERY_TYPE_FOUR = "query4";
+  public static final String QUERY_TYPE_FIVE = "query5";
+  public static final String QUERY_TYPE_SIX = "query6";
+  public static final String QUERY_TYPE_SEVENE = "query7";
+
+  private static final String DATA_VIEW_LABEL = "Data View";
+  private static final String CLUSTER_VIEW_MEMBERS_ID = "clusterTotalMembersText";
+  private static final String CLUSTER_VIEW_SERVERS_ID = "clusterServersText";
+  private static final String CLUSTER_VIEW_LOCATORS_ID = "clusterLocatorsText";
+  private static final String CLUSTER_VIEW_REGIONS_ID = "clusterTotalRegionsText";
+  private static final String CLUSTER_CLIENTS_ID = "clusterClientsText";
+  private static final String CLUSTER_FUNCTIONS_ID = "clusterFunctions";
+  private static final String CLUSTER_UNIQUECQS_ID = "clusterUniqueCQs";
+  private static final String CLUSTER_SUBSCRIPTION_ID = "clusterSubscriptionsText";
+  private static final String CLUSTER_MEMORY_USAGE_ID = "currentMemoryUsage";
+  private static final String CLUSTER_THROUGHPUT_WRITES_ID = "currentThroughputWrites";
+  private static final String CLUSTER_GCPAUSES_ID = "currentGCPauses";
+  private static final String CLUSTER_WRITEPERSEC_ID = "writePerSec";
+  private static final String CLUSTER_READPERSEC_ID = "readPerSec";
+  private static final String CLUSTER_QUERIESPERSEC_ID = "queriesPerSec";
+  private static final String CLUSTER_PROCEDURE_ID = "clusterTxnCommittedText";
+  private static final String CLUSTER_TXNCOMMITTED_ID = "clusterTxnCommittedText";
+  private static final String CLUSTER_TXNROLLBACK_ID = "clusterTxnRollbackText";
+  private static final String MEMBER_VIEW_MEMBERNAME_ID = "memberName";
+  private static final String MEMBER_VIEW_REGION_ID = "memberRegionsCount";
+  private static final String MEMBER_VIEW_THREAD_ID = "threads";
+  private static final String MEMBER_VIEW_SOCKETS_ID = "sockets";
+  private static final String MEMBER_VIEW_LOADAVG_ID = "loadAverage";
+  private static final String MEMBER_VIEW_LISTENINGPORT_ID = "receiverListeningPort";
+  private static final String MEMBER_VIEW_LINKTHROUGHPUT_ID = "receiverLinkThroughput";
+  private static final String MEMBER_VIEW_AVGBATCHLATENCY_ID = "receiverAvgBatchLatency";
+  private static final String MEMBER_VIEW_HEAPUSAGE_ID = "memberHeapUsageAvg";
+  private static final String MEMBER_VIEW_JVMPAUSES_ID = "memberGcPausesAvg";
+  private static final String MEMBER_VIEW_CPUUSAGE_ID = "memberCPUUsageValue";
+  private static final String MEMBER_VIEW_READPERSEC_ID = "memberGetsPerSecValue";
+  private static final String MEMBER_VIEW_WRITEPERSEC_ID = "memberPutsPerSecValue";
+  private static final String MEMBER_VIEW_OFFHEAPFREESIZE_ID = "offHeapFreeSize";
+  private static final String MEMBER_VIEW_OFFHEAPUSEDSIZE_ID = "offHeapUsedSize";
+  private static final String MEMBER_VIEW_CLIENTS_ID = "clusterClientsText";
+
+  private static final String REGION_NAME_LABEL = "regionName";
+  private static final String REGION_PATH_LABEL = "regionPath";
+  private static final String REGION_TYPE_LABEL = "regionType";
+  private static final String DATA_VIEW_WRITEPERSEC = "regionWrites";
+  private static final String DATA_VIEW_READPERSEC = "regionReads";
+  private static final String DATA_VIEW_EMPTYNODES = "regionEmptyNodes";
+  private static final String DATA_VIEW_ENTRYCOUNT = "regionEntryCount";
+  private static final String REGION_PERSISTENCE_LABEL = "regionPersistence";
+  private static final String DATA_VIEW_USEDMEMORY = "memoryUsed";
+  private static final String DATA_VIEW_TOTALMEMORY = "totalMemory";
+
+  private static final String DATA_BROWSER_LABEL = "Data Browser";
+  private static final String DATA_BROWSER_REGIONName1 = "treeDemo_1_span";
+  private static final String DATA_BROWSER_REGIONName2 = "treeDemo_2_span";
+  private static final String DATA_BROWSER_REGIONName3 = "treeDemo_3_span";
+  private static final String DATA_BROWSER_REGION1_CHECKBOX = "treeDemo_1_check";
+  private static final String DATA_BROWSER_REGION2_CHECKBOX = "treeDemo_2_check";
+  private static final String DATA_BROWSER_REGION3_CHECKBOX = "treeDemo_3_check";
+  private static final String DATA_BROWSER_COLOCATED_REGION = "Colocated Regions";
+  private static final String DATA_BROWSER_COLOCATED_REGION_NAME1 = "treeDemo_1_span";
+  private static final String DATA_BROWSER_COLOCATED_REGION_NAME2 = "treeDemo_2_span";
+  private static final String DATA_BROWSER_COLOCATED_REGION_NAME3 = "treeDemo_3_span";
+
+  private static final String QUERY_STATISTICS_LABEL = "Query Statistics";
+  private static final String CLUSTER_VIEW_LABEL = "Cluster View";
+  private static final String CLUSTER_VIEW_GRID_ID = "default_treemap_button";
+  private static final String SERVER_GROUP_GRID_ID = "servergroups_treemap_button";
+  private static final String REDUNDANCY_GRID_ID = "redundancyzones_treemap_button";
+  private static final String MEMBER_DROPDOWN_ID = "Members";
+  private static final String DATA_DROPDOWN_ID = "Data";
+
+  private static final DecimalFormat df2 = new DecimalFormat(PulseConstants.DECIMAL_FORMAT_PATTERN);
+
+  public static void setUpServer(String username, String password, String jsonAuthFile) throws Exception {
+    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+
+    jmxPropertiesFile = classLoader.getResource("test.properties").getPath();
+    path = getPulseWarPath();
+    server = Server.createServer(9999, jmxPropertiesFile, jsonAuthFile);
+
+    String host = "localhost";
+    int port = 8080;
+    String context = "/pulse";
+
+    jetty = JettyHelper.initJetty(host, port, false, false, null, null, null);
+    JettyHelper.addWebApplication(jetty, context, getPulseWarPath());
+    jetty.start();
+
+    pulseURL = "http://" + host + ":" + port + context;
+
+    Awaitility.await().until(()->jetty.isStarted());
+
+    driver = new FirefoxDriver();
+    driver.manage().window().maximize();
+    driver.manage().timeouts().implicitlyWait(5, TimeUnit.SECONDS);
+    driver.get(pulseURL);
+    WebElement userNameElement = driver.findElement(By.id("user_name"));
+    WebElement passwordElement = driver.findElement(By.id("user_password"));
+    userNameElement.sendKeys(username);
+    passwordElement.sendKeys(password);
+    passwordElement.submit();
+
+    Thread.sleep(3000);
+    WebElement userNameOnPulsePage = (new WebDriverWait(driver, 10))
+      .until(new ExpectedCondition<WebElement>() {
+        @Override
+        public WebElement apply(WebDriver d) {
+          return d.findElement(By.id("userName"));
+        }
+      });
+    assertNotNull(userNameOnPulsePage);
+    driver.navigate().refresh();
+    Thread.sleep(7000);
+  }
+
+  @AfterClass
+  public static void tearDownAfterClass() throws Exception {
+    driver.close();
+    jetty.stop();
+  }
+
+  @Before
+  public void setup() throws Exception {
+    // Make sure we go to the home page first
+    searchByXPathAndClick(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+  }
+
+  public static String getPulseWarPath() throws Exception {
+    String warPath = null;
+    ClassLoader classLoader = Thread.currentThread().getContextClassLoader();
+    InputStream inputStream = classLoader.getResourceAsStream("GemFireVersion.properties");
+    Properties properties = new Properties();
+    properties.load(inputStream);
+    String version = properties.getProperty("Product-Version");
+    warPath = "geode-pulse-" + version + ".war";
+    String propFilePath = classLoader.getResource("GemFireVersion.properties").getPath();
+    warPath = propFilePath.substring(0, propFilePath.indexOf("generated-resources")) + "libs/" + warPath;
+    return warPath;
+  }
+
+  protected void searchByLinkAndClick(String linkText) {
+    WebElement element = By.linkText(linkText).findElement(driver);
+    assertNotNull(element);
+    element.click();
+  }
+
+  protected void searchByIdAndClick(String id) {
+    WebElement element = driver.findElement(By.id(id));
+    assertNotNull(element);
+    element.click();
+  }
+
+  protected void searchByClassAndClick(String Class) {
+    WebElement element = driver.findElement(By.className(Class));
+    assertNotNull(element);
+    element.click();
+  }
+
+  protected void searchByXPathAndClick(String xpath) {
+    WebElement element = driver.findElement(By.xpath(xpath));
+    assertNotNull(element);
+    element.click();
+  }
+
+  protected void waitForElementByClassName(final String className, int seconds) {
+    WebElement linkTextOnPulsePage1 = (new WebDriverWait(driver, seconds))
+      .until(new ExpectedCondition<WebElement>() {
+        @Override
+        public WebElement apply(WebDriver d) {
+          return d.findElement(By.className(className));
+        }
+      });
+    assertNotNull(linkTextOnPulsePage1);
+  }
+
+  protected void waitForElementById(final String id, int seconds) {
+    WebElement element = (new WebDriverWait(driver, 10))
+      .until(new ExpectedCondition<WebElement>() {
+        @Override
+        public WebElement apply(WebDriver d) {
+          return d.findElement(By.id(id));
+        }
+      });
+    assertNotNull(element);
+  }
+
+  protected void scrollbarVerticalDownScroll() {
+    JavascriptExecutor js = (JavascriptExecutor) driver;
+    js.executeScript("javascript:window.scrollBy(250,700)");
+    WebElement pickerScroll = driver.findElement(By.className("jspDrag"));
+    WebElement pickerScrollCorner = driver.findElement(By
+      .className("jspCorner"));
+    Actions builder = new Actions(driver);
+    Actions movePicker = builder.dragAndDrop(pickerScroll, pickerScrollCorner);
+    // pickerscroll is the web element
+    movePicker.perform();
+  }
+
+  protected void scrollbarHorizontalRightScroll() {
+    JavascriptExecutor js = (JavascriptExecutor) driver;
+    js.executeScript("javascript:window.scrollBy(250,700)");
+    WebElement pickerScroll = driver
+      .findElement(By
+        .xpath("//div[@id='gview_queryStatisticsList']/div[3]/div/div[3]/div[2]/div"));
+    WebElement pickerScrollCorner = driver.findElement(By
+      .className("jspCorner"));
+    Actions builder = new Actions(driver);
+    Actions movePicker = builder.dragAndDrop(pickerScroll, pickerScrollCorner);
+    // pickerscroll is the web element
+    movePicker.perform();
+  }
+
+
+  @Test
+  public void testClusterLocatorCount() throws IOException {
+    String clusterLocators = driver
+      .findElement(By.id(CLUSTER_VIEW_LOCATORS_ID)).getText();
+
+    String totallocators = JMXProperties.getInstance().getProperty("server.S1.locatorCount");
+    assertEquals(totallocators, clusterLocators);
+  }
+
+  @Test
+  public void testClusterRegionCount() {
+    String clusterRegions = driver.findElement(By.id(CLUSTER_VIEW_REGIONS_ID))
+      .getText();
+    String totalregions = JMXProperties.getInstance().getProperty(
+      "server.S1.totalRegionCount");
+    assertEquals(totalregions, clusterRegions);
+  }
+
+  @Test
+  public void testClusterMemberCount() {
+    String clusterMembers = driver.findElement(By.id(CLUSTER_VIEW_MEMBERS_ID)).getText();
+    String totalMembers = JMXProperties.getInstance().getProperty("server.S1.memberCount");
+    assertEquals(totalMembers, clusterMembers);
+  }
+
+  @Test
+  public void testClusterNumClient() {
+    String clusterClients = driver.findElement(By.id(CLUSTER_CLIENTS_ID))
+      .getText();
+    String totalclients = JMXProperties.getInstance().getProperty(
+      "server.S1.numClients");
+    assertEquals(totalclients, clusterClients);
+  }
+
+  @Test
+  public void testClusterNumRunningFunction() {
+    String clusterFunctions = driver.findElement(By.id(CLUSTER_FUNCTIONS_ID))
+      .getText();
+    String totalfunctions = JMXProperties.getInstance().getProperty(
+      "server.S1.numRunningFunctions");
+    assertEquals(totalfunctions, clusterFunctions);
+  }
+
+  @Test
+  public void testClusterRegisteredCQCount() {
+    String clusterUniqueCQs = driver.findElement(By.id(CLUSTER_UNIQUECQS_ID))
+      .getText();
+    String totaluniqueCQs = JMXProperties.getInstance().getProperty(
+      "server.S1.registeredCQCount");
+    assertEquals(totaluniqueCQs, clusterUniqueCQs);
+  }
+
+  @Test
+  public void testClusterNumSubscriptions() {
+    String clusterSubscriptions = driver.findElement(
+      By.id(CLUSTER_SUBSCRIPTION_ID)).getText();
+    String totalSubscriptions = JMXProperties.getInstance().getProperty(
+      "server.S1.numSubscriptions");
+    assertEquals(totalSubscriptions, clusterSubscriptions);
+  }
+
+  @Test
+  public void testClusterJVMPausesWidget() {
+    String clusterJVMPauses = driver.findElement(By.id(CLUSTER_GCPAUSES_ID))
+      .getText();
+    String totalgcpauses = JMXProperties.getInstance().getProperty(
+      "server.S1.jvmPauses");
+    assertEquals(totalgcpauses, clusterJVMPauses);
+  }
+
+  @Test
+  public void testClusterAverageWritesWidget() {
+    String clusterWritePerSec = driver.findElement(
+      By.id(CLUSTER_WRITEPERSEC_ID)).getText();
+    String totalwritepersec = JMXProperties.getInstance().getProperty(
+      "server.S1.averageWrites");
+    assertEquals(totalwritepersec, clusterWritePerSec);
+  }
+
+  @Test
+  public void testClusterAverageReadsWidget() {
+    String clusterReadPerSec = driver.findElement(By.id(CLUSTER_READPERSEC_ID))
+      .getText();
+    String totalreadpersec = JMXProperties.getInstance().getProperty(
+      "server.S1.averageReads");
+    assertEquals(totalreadpersec, clusterReadPerSec);
+  }
+
+  @Test
+  public void testClusterQuerRequestRateWidget() {
+    String clusterQueriesPerSec = driver.findElement(
+      By.id(CLUSTER_QUERIESPERSEC_ID)).getText();
+    String totalqueriespersec = JMXProperties.getInstance().getProperty(
+      "server.S1.queryRequestRate");
+    assertEquals(totalqueriespersec, clusterQueriesPerSec);
+  }
+
+  @Test
+  public void testClusterGridViewMemberID() throws InterruptedException {
+    searchByIdAndClick("default_grid_button");
+    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr")); //gives me 11 rows
+
+    for (int memberCount = 1; memberCount < elements.size(); memberCount++) {
+      String memberId = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberCount + 1) + "]/td")).getText();
+      String propertMemeberId = JMXProperties.getInstance().getProperty("member.M" + memberCount + ".id");
+      assertEquals(memberId, propertMemeberId);
+    }
+  }
+
+  @Test
+  public void testClusterGridViewMemberName() {
+    searchByIdAndClick("default_grid_button");
+    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
+    for (int memberNameCount = 1; memberNameCount < elements.size(); memberNameCount++) {
+      String gridMemberName = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberNameCount + 1) + "]/td[2]")).getText();
+      String memberName = JMXProperties.getInstance().getProperty("member.M" + memberNameCount + ".member");
+      assertEquals(gridMemberName, memberName);
+    }
+  }
+
+
+  @Test
+  public void testClusterGridViewMemberHost() {
+    searchByIdAndClick("default_grid_button");
+    List<WebElement> elements = driver.findElements(By.xpath("//table[@id='memberList']/tbody/tr"));
+    for (int memberHostCount = 1; memberHostCount < elements.size(); memberHostCount++) {
+      String MemberHost = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (memberHostCount + 1) + "]/td[3]")).getText();
+      String gridMemberHost = JMXProperties.getInstance().getProperty("member.M" + memberHostCount + ".host");
+      assertEquals(gridMemberHost, MemberHost);
+    }
+  }
+
+  @Test
+  public void testClusterGridViewHeapUsage() {
+    searchByIdAndClick("default_grid_button");
+    for (int i = 1; i <= 3; i++) {
+      Float HeapUsage = Float.parseFloat(driver
+        .findElement(
+          By.xpath("//table[@id='memberList']/tbody/tr[" + (i + 1) + "]/td[5]")).getText());
+      Float gridHeapUsagestring = Float.parseFloat(JMXProperties.getInstance()
+        .getProperty("member.M" + i + ".UsedMemory"));
+      assertEquals(gridHeapUsagestring, HeapUsage);
+    }
+  }
+
+  @Test
+  public void testClusterGridViewCPUUsage() throws Exception {
+    searchByIdAndClick("default_grid_button");
+    for (int i = 1; i <= 3; i++) {
+      String CPUUsage = driver.findElement(By.xpath("//table[@id='memberList']/tbody/tr[" + (i + 1) + "]/td[6]"))
+        .getText();
+      String gridCPUUsage = JMXProperties.getInstance().getProperty("member.M" + i + ".cpuUsage");
+      gridCPUUsage = gridCPUUsage.trim();
+      assertEquals(gridCPUUsage, CPUUsage);
+    }
+  }
+
+
+  public void testRgraphWidget() throws InterruptedException {
+    searchByIdAndClick("default_rgraph_button");
+    searchByIdAndClick("h1");
+    searchByIdAndClick("M1");
+  }
+
+  @Test  // region count in properties file is 2 and UI is 1
+  public void testMemberTotalRegionCount() throws InterruptedException {
+    testRgraphWidget();
+    String RegionCount = driver.findElement(By.id(MEMBER_VIEW_REGION_ID)).getText();
+    String memberRegionCount = JMXProperties.getInstance().getProperty("member.M1.totalRegionCount");
+    assertEquals(memberRegionCount, RegionCount);
+  }
+
+  @Test
+  public void testMemberNumThread() throws InterruptedException {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    String ThreadCount = driver.findElement(By.id(MEMBER_VIEW_THREAD_ID)).getText();
+    String memberThreadCount = JMXProperties.getInstance().getProperty("member.M1.numThreads");
+    assertEquals(memberThreadCount, ThreadCount);
+  }
+
+  @Test
+  public void testMemberTotalFileDescriptorOpen() throws InterruptedException {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    String SocketCount = driver.findElement(By.id(MEMBER_VIEW_SOCKETS_ID))
+      .getText();
+    String memberSocketCount = JMXProperties.getInstance().getProperty(
+      "member.M1.totalFileDescriptorOpen");
+    assertEquals(memberSocketCount, SocketCount);
+  }
+
+  @Test
+  public void testMemberLoadAverage() throws InterruptedException {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    String LoadAvg = driver.findElement(By.id(MEMBER_VIEW_LOADAVG_ID))
+      .getText();
+    String memberLoadAvg = JMXProperties.getInstance().getProperty(
+      "member.M1.loadAverage");
+    assertEquals(df2.format(Double.valueOf(memberLoadAvg)), LoadAvg);
+  }
+
+  @Ignore("WIP") // May be useful in near future
+  @Test
+  public void testOffHeapFreeSize() {
+
+    String OffHeapFreeSizeString = driver.findElement(
+      By.id(MEMBER_VIEW_OFFHEAPFREESIZE_ID)).getText();
+    String OffHeapFreeSizetemp = OffHeapFreeSizeString.replaceAll("[a-zA-Z]",
+      "");
+    float OffHeapFreeSize = Float.parseFloat(OffHeapFreeSizetemp);
+    float memberOffHeapFreeSize = Float.parseFloat(JMXProperties.getInstance()
+      .getProperty("member.M1.OffHeapFreeSize"));
+    if (memberOffHeapFreeSize < 1048576) {
+      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024;
+
+    }
+    else if (memberOffHeapFreeSize < 1073741824) {
+      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024 / 1024;
+    }
+    else {
+      memberOffHeapFreeSize = memberOffHeapFreeSize / 1024 / 1024 / 1024;
+    }
+    memberOffHeapFreeSize = Float.parseFloat(new DecimalFormat("##.##")
+      .format(memberOffHeapFreeSize));
+    assertEquals(memberOffHeapFreeSize, OffHeapFreeSize);
+
+  }
+
+  @Ignore("WIP") // May be useful in near future
+  @Test
+  public void testOffHeapUsedSize() throws InterruptedException {
+
+    String OffHeapUsedSizeString = driver.findElement(
+      By.id(MEMBER_VIEW_OFFHEAPUSEDSIZE_ID)).getText();
+    String OffHeapUsedSizetemp = OffHeapUsedSizeString.replaceAll("[a-zA-Z]",
+      "");
+    float OffHeapUsedSize = Float.parseFloat(OffHeapUsedSizetemp);
+    float memberOffHeapUsedSize = Float.parseFloat(JMXProperties.getInstance()
+      .getProperty("member.M1.OffHeapUsedSize"));
+    if (memberOffHeapUsedSize < 1048576) {
+      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024;
+
+    }
+    else if (memberOffHeapUsedSize < 1073741824) {
+      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024 / 1024;
+    }
+    else {
+      memberOffHeapUsedSize = memberOffHeapUsedSize / 1024 / 1024 / 1024;
+    }
+    memberOffHeapUsedSize = Float.parseFloat(new DecimalFormat("##.##")
+      .format(memberOffHeapUsedSize));
+    assertEquals(memberOffHeapUsedSize, OffHeapUsedSize);
+  }
+
+  @Test
+  public void testMemberJVMPauses() throws Exception {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    String JVMPauses = driver.findElement(By.id(MEMBER_VIEW_JVMPAUSES_ID))
+      .getText();
+    String memberGcPausesAvg = JMXProperties.getInstance().getProperty(
+      "member.M1.JVMPauses");
+    assertEquals(memberGcPausesAvg, JVMPauses);
+  }
+
+  @Test
+  public void testMemberCPUUsage() {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    String CPUUsagevalue = driver.findElement(By.id(MEMBER_VIEW_CPUUSAGE_ID))
+      .getText();
+    String memberCPUUsage = JMXProperties.getInstance().getProperty(
+      "member.M1.cpuUsage");
+    assertEquals(memberCPUUsage, CPUUsagevalue);
+  }
+
+  @Test  // difference between UI and properties file
+  public void testMemberAverageReads() {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    float ReadPerSec = Float.parseFloat(driver.findElement(By.id(MEMBER_VIEW_READPERSEC_ID)).getText());
+    float memberReadPerSec = Float.parseFloat(JMXProperties.getInstance().getProperty("member.M1.averageReads"));
+    memberReadPerSec = Float.parseFloat(new DecimalFormat("##.##")
+      .format(memberReadPerSec));
+    assertEquals(memberReadPerSec, ReadPerSec);
+  }
+
+  @Test
+  public void testMemberAverageWrites() throws InterruptedException {
+    testRgraphWidget();
+    String WritePerSec = driver.findElement(By.id(MEMBER_VIEW_WRITEPERSEC_ID))
+      .getText();
+    String memberWritePerSec = JMXProperties.getInstance().getProperty(
+      "member.M1.averageWrites");
+    assertEquals(memberWritePerSec, WritePerSec);
+  }
+
+
+  @Test
+  public void testMemberGridViewData() throws InterruptedException {
+    testRgraphWidget();
+    searchByXPathAndClick(PulseTestLocators.MemberDetailsView.gridButtonXpath);
+    // get the number of rows on the grid
+    List<WebElement> noOfRows = driver.findElements(By.xpath("//table[@id='memberRegionsList']/tbody/tr"));
+    String MemberRegionName = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[1]")).getText();
+    String memberRegionName = JMXProperties.getInstance().getProperty("region.R1.name");
+    assertEquals(memberRegionName, MemberRegionName);
+
+    String MemberRegionType = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[2]")).getText();
+    String memberRegionType = JMXProperties.getInstance().getProperty("region.R1.regionType");
+    assertEquals(memberRegionType, MemberRegionType);
+
+    String MemberRegionEntryCount = driver.findElement(By.xpath("//table[@id='memberRegionsList']/tbody/tr[2]/td[3]")).getText();
+    String memberRegionEntryCount = JMXProperties.getInstance().getProperty("regionOnMember./R1.M1.entryCount");
+    assertEquals(memberRegionEntryCount, MemberRegionEntryCount);
+  }
+
+  @Test
+  public void testDropDownList() throws InterruptedException {
+    searchByIdAndClick("default_grid_button");
+    searchByIdAndClick("M1&M1");
+    searchByIdAndClick("memberName");
+    searchByLinkAndClick("M3");
+    searchByIdAndClick("memberName");
+    searchByLinkAndClick("M2");
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewRegionName() throws InterruptedException {
+    searchByLinkAndClick(DATA_VIEW_LABEL);
+    Thread.sleep(7000);
+    searchByIdAndClick("default_grid_button");
+    String regionName = driver.findElement(By.id(REGION_NAME_LABEL)).getText();
+    String dataviewregionname = JMXProperties.getInstance().getProperty("region.R1.name");
+    assertEquals(dataviewregionname, regionName);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewRegionPath() {
+    String regionPath = driver.findElement(By.id(REGION_PATH_LABEL)).getText();
+    String dataviewregionpath = JMXProperties.getInstance().getProperty(
+      "region.R1.fullPath");
+    assertEquals(dataviewregionpath, regionPath);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewRegionType() {
+    String regionType = driver.findElement(By.id(REGION_TYPE_LABEL)).getText();
+    String dataviewregiontype = JMXProperties.getInstance().getProperty(
+      "region.R1.regionType");
+    assertEquals(dataviewregiontype, regionType);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewEmptyNodes() {
+    String regionEmptyNodes = driver.findElement(By.id(DATA_VIEW_EMPTYNODES))
+      .getText();
+    String dataviewEmptyNodes = JMXProperties.getInstance().getProperty(
+      "region.R1.emptyNodes");
+    assertEquals(dataviewEmptyNodes, regionEmptyNodes);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewSystemRegionEntryCount() {
+    String regionEntryCount = driver.findElement(By.id(DATA_VIEW_ENTRYCOUNT))
+      .getText();
+    String dataviewEntryCount = JMXProperties.getInstance().getProperty(
+      "region.R1.systemRegionEntryCount");
+    assertEquals(dataviewEntryCount, regionEntryCount);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewPersistentEnabled() {
+    String regionPersistence = driver.findElement(
+      By.id(REGION_PERSISTENCE_LABEL)).getText();
+    String dataviewregionpersistence = JMXProperties.getInstance().getProperty(
+      "region.R1.persistentEnabled");
+    assertEquals(dataviewregionpersistence, regionPersistence);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewDiskWritesRate() {
+    String regionWrites = driver.findElement(By.id(DATA_VIEW_WRITEPERSEC))
+      .getText();
+    String dataviewRegionWrites = JMXProperties.getInstance().getProperty(
+      "region.R1.diskWritesRate");
+    assertEquals(dataviewRegionWrites, regionWrites);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewDiskReadsRate() {
+    String regionReads = driver.findElement(By.id(DATA_VIEW_READPERSEC))
+      .getText();
+    String dataviewRegionReads = JMXProperties.getInstance().getProperty(
+      "region.R1.diskReadsRate");
+    assertEquals(dataviewRegionReads, regionReads);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewDiskUsage() {
+    String regionMemoryUsed = driver.findElement(By.id(DATA_VIEW_USEDMEMORY))
+      .getText();
+    String dataviewMemoryUsed = JMXProperties.getInstance().getProperty(
+      "region.R1.diskUsage");
+    assertEquals(dataviewMemoryUsed, regionMemoryUsed);
+    searchByLinkAndClick(QUERY_STATISTICS_LABEL);
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataViewGridValue() {
+    String DataViewRegionName = driver.findElement(
+      By.xpath("//*[id('6')/x:td[1]]")).getText();
+    String dataViewRegionName = JMXProperties.getInstance().getProperty(
+      "region.R1.name");
+    assertEquals(dataViewRegionName, DataViewRegionName);
+
+    String DataViewRegionType = driver.findElement(
+      By.xpath("//*[id('6')/x:td[2]")).getText();
+    String dataViewRegionType = JMXProperties.getInstance().getProperty(
+      "region.R2.regionType");
+    assertEquals(dataViewRegionType, DataViewRegionType);
+
+    String DataViewEntryCount = driver.findElement(
+      By.xpath("//*[id('6')/x:td[3]")).getText();
+    String dataViewEntryCount = JMXProperties.getInstance().getProperty(
+      "region.R2.systemRegionEntryCount");
+    assertEquals(dataViewEntryCount, DataViewEntryCount);
+
+    String DataViewEntrySize = driver.findElement(
+      By.xpath("//*[id('6')/x:td[4]")).getText();
+    String dataViewEntrySize = JMXProperties.getInstance().getProperty(
+      "region.R2.entrySize");
+    assertEquals(dataViewEntrySize, DataViewEntrySize);
+
+  }
+
+
+  public void loadDataBrowserpage() {
+    searchByLinkAndClick(DATA_BROWSER_LABEL);
+    //Thread.sleep(7000);
+  }
+
+  @Test
+  public void testDataBrowserRegionName() throws InterruptedException {
+    loadDataBrowserpage();
+    String DataBrowserRegionName1 = driver.findElement(By.id(DATA_BROWSER_REGIONName1))
+      .getText();
+    String databrowserRegionNametemp1 = JMXProperties.getInstance().getProperty(
+      "region.R1.name");
+    String databrowserRegionName1 = databrowserRegionNametemp1.replaceAll("[\\/]", "");
+    assertEquals(databrowserRegionName1, DataBrowserRegionName1);
+
+    String DataBrowserRegionName2 = driver.findElement(By.id(DATA_BROWSER_REGIONName2))
+      .getText();
+    String databrowserRegionNametemp2 = JMXProperties.getInstance().getProperty(
+      "region.R2.name");
+    String databrowserRegionName2 = databrowserRegionNametemp2.replaceAll("[\\/]", "");
+    assertEquals(databrowserRegionName2, DataBrowserRegionName2);
+
+    String DataBrowserRegionName3 = driver.findElement(By.id(DATA_BROWSER_REGIONName3))
+      .getText();
+    String databrowserRegionNametemp3 = JMXProperties.getInstance().getProperty(
+      "region.R3.name");
+    String databrowserRegionName3 = databrowserRegionNametemp3.replaceAll("[\\/]", "");
+    assertEquals(databrowserRegionName3, DataBrowserRegionName3);
+
+  }
+
+  @Test
+  public void testDataBrowserRegionMembersVerificaition() throws InterruptedException {
+    loadDataBrowserpage();
+    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
+    String DataBrowserMember1Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
+      .getText();
+    String DataBrowserMember1Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
+      .getText();
+    String DataBrowserMember1Name3 = driver.findElement(By.xpath("//label[@for='Member2']"))
+      .getText();
+    String databrowserMember1Names = JMXProperties.getInstance().getProperty(
+      "region.R1.members");
+
+    String databrowserMember1Names1 = databrowserMember1Names.substring(0, 2);
+    assertEquals(databrowserMember1Names1, DataBrowserMember1Name1);
+
+    String databrowserMember1Names2 = databrowserMember1Names.substring(3, 5);
+    assertEquals(databrowserMember1Names2, DataBrowserMember1Name2);
+
+    String databrowserMember1Names3 = databrowserMember1Names.substring(6, 8);
+    assertEquals(databrowserMember1Names3, DataBrowserMember1Name3);
+    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
+
+    searchByIdAndClick(DATA_BROWSER_REGION2_CHECKBOX);
+    String DataBrowserMember2Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
+      .getText();
+    String DataBrowserMember2Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
+      .getText();
+    String databrowserMember2Names = JMXProperties.getInstance().getProperty(
+      "region.R2.members");
+
+    String databrowserMember2Names1 = databrowserMember2Names.substring(0, 2);
+    assertEquals(databrowserMember2Names1, DataBrowserMember2Name1);
+
+    String databrowserMember2Names2 = databrowserMember2Names.substring(3, 5);
+    assertEquals(databrowserMember2Names2, DataBrowserMember2Name2);
+    searchByIdAndClick(DATA_BROWSER_REGION2_CHECKBOX);
+
+    searchByIdAndClick(DATA_BROWSER_REGION3_CHECKBOX);
+    String DataBrowserMember3Name1 = driver.findElement(By.xpath("//label[@for='Member0']"))
+      .getText();
+    String DataBrowserMember3Name2 = driver.findElement(By.xpath("//label[@for='Member1']"))
+      .getText();
+    String databrowserMember3Names = JMXProperties.getInstance().getProperty(
+      "region.R3.members");
+
+    String databrowserMember3Names1 = databrowserMember3Names.substring(0, 2);
+    assertEquals(databrowserMember3Names1, DataBrowserMember3Name1);
+
+    String databrowserMember3Names2 = databrowserMember3Names.substring(3, 5);
+    assertEquals(databrowserMember3Names2, DataBrowserMember3Name2);
+    searchByIdAndClick(DATA_BROWSER_REGION3_CHECKBOX);
+  }
+
+  @Test
+  public void testDataBrowserColocatedRegions() throws InterruptedException {
+    loadDataBrowserpage();
+    String databrowserMemberNames1 = JMXProperties.getInstance().getProperty(
+      "region.R1.members");
+    String databrowserMemberNames2 = JMXProperties.getInstance().getProperty(
+      "region.R2.members");
+    String databrowserMemberNames3 = JMXProperties.getInstance().getProperty(
+      "region.R3.members");
+
+    if ((databrowserMemberNames1.matches(databrowserMemberNames2 + "(.*)"))) {
+      if ((databrowserMemberNames1.matches(databrowserMemberNames3 + "(.*)"))) {
+        if ((databrowserMemberNames2.matches(databrowserMemberNames3 + "(.*)"))) {
+          System.out.println("R1, R2 and R3 are colocated regions");
+        }
+      }
+    }
+    searchByIdAndClick(DATA_BROWSER_REGION1_CHECKBOX);
+    searchByLinkAndClick(DATA_BROWSER_COLOCATED_REGION);
+    String DataBrowserColocatedRegion1 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME1))
+      .getText();
+    String DataBrowserColocatedRegion2 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME2))
+      .getText();
+    String DataBrowserColocatedRegion3 = driver.findElement(By.id(DATA_BROWSER_COLOCATED_REGION_NAME3))
+      .getText();
+
+    String databrowserColocatedRegiontemp1 = JMXProperties.getInstance().getProperty(
+      "region.R1.name");
+    String databrowserColocatedRegion1 = databrowserColocatedRegiontemp1.replaceAll("[\\/]", "");
+
+    String databrowserColocatedRegiontemp2 = JMXProperties.getInstance().getProperty(
+      "region.R2.name");
+    String databrowserColocatedRegion2 = databrowserColocatedRegiontemp2.replaceAll("[\\/]", "");
+
+    String databrowserColocatedRegiontemp3 = JMXProperties.getInstance().getProperty(
+      "region.R3.name");
+    String databrowserColocatedRegion3 = databrowserColocatedRegiontemp3.replaceAll("[\\/]", "");
+
+    assertEquals(databrowserColocatedRegion1, DataBrowserColocatedRegion1);
+    assertEquals(databrowserColocatedRegion2, DataBrowserColocatedRegion2);
+    assertEquals(databrowserColocatedRegion3, DataBrowserColocatedRegion3);
+
+  }
+
+  @Ignore("WIP") // clusterDetails element not found on Data Browser page. No assertions in test
+  @Test
+  public void testDataBrowserQueryValidation() throws IOException, InterruptedException {
+    loadDataBrowserpage();
+    WebElement textArea = driver.findElement(By.id("dataBrowserQueryText"));
+    textArea.sendKeys("query1");
+    WebElement executeButton = driver.findElement(By.id("btnExecuteQuery"));
+    executeButton.click();
+    String QueryResultHeader1 = driver.findElement(By.xpath("//div[@id='clusterDetails']/div/div/span[@class='n-title']")).getText();
+    double count = 0, countBuffer = 0, countLine = 0;
+    String lineNumber = "";
+    String filePath = "E:\\springsource\\springsourceWS\\Pulse-Cedar\\src\\main\\resources\\testQueryResultSmall.txt";
+    BufferedReader br;
+    String line = "";
+    br = new BufferedReader(new FileReader(filePath));
+    while ((line = br.readLine()) != null) {
+      countLine++;
+      String[] words = line.split(" ");
+
+      for (String word : words) {
+        if (word.equals(QueryResultHeader1)) {
+          count++;
+          countBuffer++;
+        }
+      }
+    }
+  }
+
+  public void testTreeMapPopUpData(String S1, String gridIcon) {
+    for (int i = 1; i <= 3; i++) {
+      searchByLinkAndClick(CLUSTER_VIEW_LABEL);
+      if (gridIcon.equals(SERVER_GROUP_GRID_ID)) {
+        WebElement ServerGroupRadio = driver.findElement(By.xpath("//label[@for='radio-servergroups']"));
+        ServerGroupRadio.click();
+      }
+      if (gridIcon.equals(REDUNDANCY_GRID_ID)) {
+        WebElement ServerGroupRadio = driver.findElement(By.xpath("//label[@for='radio-redundancyzones']"));
+        ServerGroupRadio.click();
+      }
+      searchByIdAndClick(gridIcon);
+      WebElement TreeMapMember = driver.findElement(By.xpath("//div[@id='" + S1 + "M" + (i) + "']/div"));
+      Actions builder = new Actions(driver);
+      builder.clickAndHold(TreeMapMember).perform();
+      int j = 1;
+      String CPUUsageM1temp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div/div[2]/div"))
+        .getText();
+      String CPUUsageM1 = CPUUsageM1temp.replaceAll("[\\%]", "");
+      String cpuUsageM1 = JMXProperties.getInstance().getProperty(
+        "member.M" + (i) + ".cpuUsage");
+      assertEquals(cpuUsageM1, CPUUsageM1);
+
+      String MemoryUsageM1temp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 1) + "]/div[2]/div"))
+        .getText();
+      String MemoryUsageM1 = MemoryUsageM1temp.replaceAll("MB", "");
+      String memoryUsageM1 = JMXProperties.getInstance().getProperty(
+        "member.M" + (i) + ".UsedMemory");
+      assertEquals(memoryUsageM1, MemoryUsageM1);
+
+      String LoadAvgM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 2) + "]/div[2]/div"))
+        .getText();
+      String loadAvgM1 = JMXProperties.getInstance().getProperty(
+        "member.M" + (i) + ".loadAverage");
+      assertEquals(df2.format(Double.valueOf(loadAvgM1)), LoadAvgM1);
+
+
+      String ThreadsM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 3) + "]/div[2]/div"))
+        .getText();
+      String threadsM1 = JMXProperties.getInstance().getProperty(
+        "member.M" + (i) + ".numThreads");
+      assertEquals(threadsM1, ThreadsM1);
+
+      String SocketsM1 = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[" + (j + 4) + "]/div[2]/div"))
+        .getText();
+      String socketsM1 = JMXProperties.getInstance().getProperty(
+        "member.M" + (i) + ".totalFileDescriptorOpen");
+      assertEquals(socketsM1, SocketsM1);
+      builder.moveToElement(TreeMapMember).release().perform();
+    }
+  }
+
+  @Test
+  public void testTopologyPopUpData() {
+    testTreeMapPopUpData("", CLUSTER_VIEW_GRID_ID);
+  }
+
+  @Test
+  public void testServerGroupTreeMapPopUpData() {
+    testTreeMapPopUpData("SG1(!)", SERVER_GROUP_GRID_ID);
+  }
+
+  @Test
+  public void testDataViewTreeMapPopUpData() {
+    searchByLinkAndClick(CLUSTER_VIEW_LABEL);
+    searchByLinkAndClick(DATA_DROPDOWN_ID);
+    WebElement TreeMapMember = driver.findElement(By.id("GraphTreeMapClusterData-canvas"));
+    Actions builder = new Actions(driver);
+    builder.clickAndHold(TreeMapMember).perform();
+    String RegionType = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div/div[2]/div"))
+      .getText();
+    String regionType = JMXProperties.getInstance().getProperty(
+      "region.R2.regionType");
+    assertEquals(regionType, RegionType);
+
+    String EntryCount = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[2]/div[2]/div"))
+      .getText();
+    String entryCount = JMXProperties.getInstance().getProperty(
+      "region.R2.systemRegionEntryCount");
+    assertEquals(entryCount, EntryCount);
+
+    String EntrySizetemp = driver.findElement(By.xpath("//div[@id='_tooltip']/div/div/div[2]/div[3]/div[2]/div"))
+      .getText();
+    float EntrySize = Float.parseFloat(EntrySizetemp);
+    float entrySize = Float.parseFloat(JMXProperties.getInstance().getProperty(
+      "region.R2.entrySize"));
+    entrySize = entrySize / 1024 / 1024;
+    entrySize = Float.parseFloat(new DecimalFormat("##.####")
+      .format(entrySize));
+    assertEquals(entrySize, EntrySize);
+    builder.moveToElement(TreeMapMember).release().perform();
+  }
+
+  @Test
+  public void testRegionViewTreeMapPopUpData() {
+    searchByLinkAndClick(CLUSTER_VIEW_LABEL);
+    searchByLinkAndClick(DATA_DROPDOWN_ID);
+    WebElement TreeMapMember = driver.findElement(By.id("GraphTreeMapClusterData-canvas"));
+    TreeMapMember.click();
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testNumberOfRegions() throws InterruptedException {
+
+    driver.findElement(By.xpath("//a[text()='Data Browser']")).click();
+
+    Thread.sleep(1000);
+    List<WebElement> regionList = driver.findElements(By.xpath("//ul[@id='treeDemo']/li"));
+    String regions = JMXProperties.getInstance().getProperty("regions");
+    String[] regionName = regions.split(" ");
+    for (String string : regionName) {
+    }
+    //JMXProperties.getInstance().getProperty("region.R1.regionType");
+    int i = 1;
+    for (WebElement webElement : regionList) {
+      //webElement.getAttribute(arg0)
+      i++;
+    }
+
+    driver.findElement(By.id("treeDemo_1_check")).click();
+
+    List<WebElement> memeberList = driver.findElements(By.xpath("//ul[@id='membersList']/li"));
+    int j = 0;
+    for (WebElement webElement : memeberList) {
+      j++;
+    }
+  }
+
+  @Ignore("WIP")
+  @Test
+  public void testDataBrowser() {
+
+    driver.findElement(By.linkText("Data Browser")).click();
+    // WebElement dataBrowserLabel = driver.findElement(By.xpath(""));
+    WebDriverWait wait = new WebDriverWait(driver, 20);
+    wait.until(ExpectedConditions.visibilityOf(driver.findElement(By.xpath("//label[text()='Data Browser']"))));
+
+
+    // Verify all elements must be displayed on data browser screen
+    assertTrue(driver.findElement(By.xpath("//a[text()='Data Regions']")).isDisplayed());
+    assertTrue(driver.findElement(By.id("linkColocatedRegions")).isDisplayed());
+    assertTrue(driver.findElement(By.linkText("All Regions")).isDisplayed());
+
+    assertTrue(driver.findElement(By.xpath("//a[text()='Region Members']")).isDisplayed());
+
+    assertTrue(driver.findElement(By.xpath("//a[text()='Queries']")).isDisplayed());
+    assertTrue(driver.findElement(By.xpath("//label[text()='Query Editor']")).isDisplayed());
+    assertTrue(driver.findElement(By.xpath("//label[text()='Result']")).isDisplayed());
+    assertTrue(driver.findElement(By.xpath("//input[@value='Export Result']")).isDisplayed());
+    assertTrue(driver.findElement(By.id("btnExecuteQuery")).isDisplayed());
+    assertTrue(driver.findElement(By.xpath("//input[@value='Clear']")).isDisplayed());
+    assertTrue(driver.findElement(By.id("dataBrowserQueryText")).isDisplayed());
+
+    assertTrue(driver.findElement(By.id("historyIcon")).isDisplayed());
+
+    //Actual query execution
+
+    driver.findElement(By.id("dataBrowserQueryText")).sendKeys("Query1");
+
+    // Assert data regions are displayed
+    assertTrue(driver.findElement(By.id("treeDemo_1")).isDisplayed());
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAuthTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAuthTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAuthTest.java
new file mode 100644
index 0000000..a77e0ca
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAuthTest.java
@@ -0,0 +1,33 @@
+/*
+ * 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 org.apache.geode.tools.pulse.tests;
+
+import org.apache.geode.test.junit.categories.UITest;
+import org.junit.BeforeClass;
+import org.junit.FixMethodOrder;
+import org.junit.experimental.categories.Category;
+import org.junit.runners.MethodSorters;
+
+@Category(UITest.class)
+@FixMethodOrder(MethodSorters.JVM)
+public class PulseAuthTest extends PulseAbstractTest {
+
+  @BeforeClass
+  public static void beforeClassSetup() throws Exception {
+    setUpServer("pulseUser", "12345", "/pulse-auth.json");
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/eff7f216/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAutomatedTest.java
----------------------------------------------------------------------
diff --git a/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAutomatedTest.java b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAutomatedTest.java
new file mode 100644
index 0000000..a4f14f8
--- /dev/null
+++ b/geode-pulse/src/test/java/org/apache/geode/tools/pulse/tests/PulseAutomatedTest.java
@@ -0,0 +1,784 @@
+/*
+ *
+ * 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.
+ *
+ */
+/**
+* This test class contains automated tests for Pulse application related to
+* 1. Different grid data validations for example - Topology, Server Group, Redundancy Zone
+* 2. Data Browser
+* 3. 
+* 
+*
+* @version 1.0
+* @since GemFire   2014-04-02
+*/
+package org.apache.geode.tools.pulse.tests;
+
+import static org.junit.Assert.*;
+
+import java.text.DateFormat;
+import java.text.SimpleDateFormat;
+import java.util.List;
+
+import org.junit.BeforeClass;
+import org.junit.Ignore;
+import org.junit.Test;
+import org.junit.experimental.categories.Category;
+import org.openqa.selenium.By;
+import org.openqa.selenium.WebElement;
+
+import org.apache.geode.test.junit.categories.UITest;
+
+@Category(UITest.class)
+public class PulseAutomatedTest extends PulseAbstractTest {
+
+	@BeforeClass
+	public static void beforeClassSetup() throws Exception {
+		setUpServer("pulseUser", "12345", "/pulse-auth.json");
+	}
+
+	@Test
+	public void serverGroupGridDataValidation() {
+		navigateToServerGroupGridView();
+		validateServerGroupGridData();
+	}
+
+	@Test
+	public void redundancyZonesGridDataValidation() {
+		navigateToRedundancyZonesGridView();
+		validateRedundancyZonesGridData();
+	}
+
+	@Test
+	public void topologyGridDataValidation() {
+		navigateToTopologyGridView();
+		validateTopologyGridData();
+	}
+
+	@Test
+	public void dataViewGridDataValidation() {
+		navigateToDataPrespectiveGridView();
+		validateDataPrespectiveGridData();
+	}
+
+	@Test
+	public void regionDetailsGridDataValidation() {
+		navigateToRegionDetailsGridView();
+		validateRegionDetailsGridData();
+
+	}
+
+	@Test
+	public void regionDetailsNavigationTest() {
+		navigateToRegionDetailsView();
+		assertEquals("/R2", getTextUsingId(PulseTestLocators.RegionDetailsView.regionNameDivId));
+	}
+
+	@Test
+	public void regionName() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.name"), getTextUsingId(PulseTestLocators.RegionDetailsView.regionNameDivId));
+	}
+
+	@Test
+	public void regionPath() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.fullPath"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionPathId));
+	}
+
+	@Test
+	public void regionType() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.regionType"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionTypeId));
+	}
+
+	@Test
+	public void regionMembers() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.memberCount"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionMembersTextId));
+	}
+
+	@Test
+	public void regionEmptyNodes() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.emptyNodes"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionEmptyNodesId));
+	}
+
+	@Test
+	public void regionEntryCount() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.systemRegionEntryCount"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionEntryCountTextId));
+	}
+
+	@Test
+	public void regionDiskUsage() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.diskUsage"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionDiskUsageId));
+	}
+
+	@Test
+	public void regionPersistence() {
+		navigateToRegionDetailsView();
+		assertEquals(getPersistanceEnabled(getPropertyValue("region.R2.persistentEnabled")),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.regionPersistenceId));
+	}
+
+	@Ignore("WIP")
+	@Test
+	public void regionMemoryUsage() {
+		navigateToRegionDetailsView();
+		// need to check the respective property values
+	}
+
+	@Test
+	public void regionInMemoryRead() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.getsRate"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.inMemoryReadsId));
+
+	}
+
+	@Test
+	public void regionInMemoryWrites() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.putsRate"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.inMemoryWritesId));
+	}
+
+	@Test
+	public void regionDiskRead() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.diskReadsRate"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.diskReadsId));
+	}
+
+	@Test
+	public void regionDiskWrites() {
+		navigateToRegionDetailsView();
+		assertEquals(getPropertyValue("region.R2.diskWritesRate"),
+				getTextUsingId(PulseTestLocators.RegionDetailsView.diskWritesId));
+	}
+
+	@Test
+	public void clickHostShowsMemberTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
+	}
+
+	@Test
+	@Ignore("Issue with highlighting")
+	public void verifyHostTooltipsOfTopologyGraphTest() {		
+		for (int i = 1; i <=3; i++) {
+			clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+			mouseClickAndHoldOverElementById("h" + i);
+			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostNameTTXpath, getPropertyValue("member.M" + i + ".host"));
+			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.cpuUsageTTXpath, "0%");
+			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memoryUsageTTXpath, getPropertyValue("member.M" + i
+					+ ".UsedMemory"));
+			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.loadAvgTTXpath, getPropertyValue("member.M" + i
+					+ ".loadAverage"));
+			verifyTextPresrntByXpath(PulseTestLocators.TopologyView.soketsTTXpath, getPropertyValue("member.M" + i
+					+ ".totalFileDescriptorOpen"));
+			mouseReleaseById("h" + i);
+			driver.navigate().refresh();
+		}
+	}
+
+	@Ignore("Issues with member tooltip xpath")
+	@Test
+	public void verifyMemberTooltipsOfTopologyGraphTest() {
+
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH1Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
+		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM1Id);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M1.member"));
+		//verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M1.cpuUsage") + "%");
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M1.JVMPauses"));
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M1.totalRegionCount"));
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH2Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
+		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM2Id);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M2.member"));
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M2.cpuUsage") + "%");
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M2.JVMPauses"));
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M2.totalRegionCount"));
+
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH3Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
+		mouseClickAndHoldOverElementById(PulseTestLocators.TopologyView.memberM3Id);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memNameTTXpath, getPropertyValue("member.M3.member"));
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.memCpuUsageTTXpath, getPropertyValue("member.M3.cpuUsage") + "%");
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.jvmPausesTTXpath, getPropertyValue("member.M3.JVMPauses"));
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.regionsTTXpath, getPropertyValue("member.M3.totalRegionCount"));
+
+	}
+
+	@Test
+	public void VerifyRGraphTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH1Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH2Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.nodeH3Id);
+	}
+
+	@Test
+	public void clickMembersOfTopologyGraphTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH1Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM1Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH2Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.nodeH3Id);
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM3Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+	@Test
+	public void clickTreeMapViewShowingTreeMapTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
+	}
+
+	@Test
+	public void verifyMembersPresentInTreeMapTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM1Id, "M1");
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM2Id, "M2");
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM3Id, "M3");
+	}
+
+	@Test
+	public void clickMemberNavigatingToCorrespondingRegionTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM1Id);
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM1Id, "M1");
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM1Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM2Id);
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM2Id, "M2");
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.memberM3Id);
+		verifyTextPresrntById(PulseTestLocators.TopologyView.memberM3Id, "M3");
+		clickElementUsingId(PulseTestLocators.TopologyView.memberM3Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+	@Test
+	public void clickGridButtonShowsGridTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM1Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM1Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH1Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.idM3Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM3Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH3Xpath);
+	}
+
+	@Test
+	public void verifyMembersPresentInGridTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM1Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM1Xpath, "M1");
+
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM2Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM2Xpath, "M2");
+
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.nameM3Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.nameM3Xpath, "M3");
+	}
+
+	@Test
+	public void verifyHostNamesInGridTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH1Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH1Xpath, "h1");
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH2Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH2Xpath, "h2");
+		verifyElementPresentByXpath(PulseTestLocators.TopologyView.hostH3Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.TopologyView.hostH3Xpath, "h3");
+	}
+
+	@Test
+	public void clickOnGridMemNameNavigatingToCorrespondingRegionTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM1Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM2Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.gridButtonId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.nameM3Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+	@Test
+	public void verifyMembersPresentInSvrGrpTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp1Id);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp2Id);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.serverGrp3Id);
+
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M1Id);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M2Id);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg1M3Id);
+
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg2M1Id);
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg2M2Id);
+
+		verifyElementPresentById(PulseTestLocators.ServerGroups.sg3M3Id);
+	}
+
+	@Test
+	public void expandAndCloseServerGroupsTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		//waitForElement(findElementByXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath));
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp1Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp1Id, "style", "width: 720px; height: 415px;");
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp1Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp1Id, "style", "width: 239.667px; height: 399px;");
+
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp2Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp2Id, "style", "width: 720px; height: 415px;");
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp2Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp2Id, "style", "width: 239.667px; height: 399px;");
+
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp3Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp3Id, "style", "width: 720px; height: 415px;");
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrp3Xpath);
+		verifyElementAttributeById(PulseTestLocators.ServerGroups.serverGrp3Id, "style", "width: 239.667px; height: 399px;");
+	}
+
+	@Test
+	public void verifyMembersInServGrpTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
+
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp1Id, "SG1");
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp2Id, "SG2");
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.serverGrp3Id, "SG3");
+
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M1Id, "M1");
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M2Id, "M2");
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg1M3Id, "M3");
+
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg2M1Id, "M1");
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg2M2Id, "M2");
+
+		verifyTextPresrntById(PulseTestLocators.ServerGroups.sg3M3Id, "M3");
+	}
+
+	@Test
+	public void memberNavigationFromServGrpTest() {
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.serverGrpsRadioXpath);
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M1Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg1M3Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg2M1Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg2M2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.sg3M3Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+	@Test
+	public void clickServGrpGridButtonShowsGridTest() {
+		navigateToServerGroupGridView();
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M3Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.idSG1M1Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM3Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.ServerGroups.nameM1Xpath);
+
+	}
+
+	@Test
+	public void memberNavigationFromServGrpGridTest() {
+		navigateToServerGroupGridView();
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M3Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+		navigateToServerGroupGridView();
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M1Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		navigateToServerGroupGridView();
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.idSG1M2Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+	}
+
+	@Test
+	public void verifyZonePresentTest() {
+		navigateToRedundancyZonesTreeView();
+		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
+		verifyElementPresentById(PulseTestLocators.RedundancyZone.zoneRZ2Id);
+	}
+
+	@Test
+	public void expandAndCloseRdncyZoneTest() {
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
+		verifyElementAttributeById(PulseTestLocators.RedundancyZone.zoneRZ1Id, "style", "width: 720px; height: 415px;");
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ1RZ2Xpath);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.zoneRZ2Xpath);
+		verifyElementAttributeById(PulseTestLocators.RedundancyZone.zoneRZ2Id, "style", "width: 720px; height: 415px;");
+
+	}
+
+	@Test
+	public void clickRZMembersNavigationTest() {
+		navigateToRedundancyZonesTreeView();		
+		clickElementUsingId(PulseTestLocators.RedundancyZone.m1RZ1RZ2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.m2RZ1Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.m3RZ2Id);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+	@Test
+	public void clickRZGridShowingGridTest() {
+		navigateToRedundancyZonesGridView();
+		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM2Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM1Xpath);
+		verifyElementPresentByXpath(PulseTestLocators.RedundancyZone.idM3Xpath);
+		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM2Xpath, "M2");
+		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM1Xpath, "M1");
+		verifyTextPresrntByXpath(PulseTestLocators.RedundancyZone.idM3Xpath, "M3");
+	}
+
+	@Test
+	public void clickRZGridMembersNavigationTest() {
+		navigateToRedundancyZonesGridView();
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM2Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M2");
+		navigateToRedundancyZonesGridView();
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM1Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M1");
+		navigateToRedundancyZonesGridView();
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.idM3Xpath);
+		verifyTextPresrntById(PulseTestLocators.RegionDetailsView.memberNameId, "M3");
+	}
+
+
+	@Test
+	public void verifySortingOptionsTest(){
+		clickElementUsingXpath(PulseTestLocators.TopNavigation.clusterViewLinkXpath);
+		clickElementUsingId(PulseTestLocators.TopologyView.treeMapButtonId);
+		verifyElementPresentById(PulseTestLocators.TopologyView.hotSpotId);
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);			
+		verifyElementPresentByLinkText("Heap Usage");
+		verifyElementPresentByLinkText("CPU Usage");		
+	}
+	
+	/* 
+	 * HotSpot test scripts - 
+	 */
+	//--- Topology view
+	
+	@Test
+	public void testHotSpotOptPrsntOnTopologyView(){
+		navigateToTopologyTreeView();
+	    assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));	
+	}
+	
+	@Test
+	public void testHotSpotOptionsTopologyView(){	
+		navigateToTopologyTreeView();
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
+		assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath));
+		assertEquals(PulseTestData.Topology.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath));
+	}
+	
+	@Test
+	public void testCpuUsageNavigationOnTopologyView(){
+		navigateToTopologyTreeView();
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath);
+		assertEquals(PulseTestData.Topology.hotSpotCPULbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));
+	}
+	
+	@Test
+	public void testHeapUsageNavigationOnTopologyView(){
+		navigateToTopologyTreeView();
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath);
+		assertEquals(PulseTestData.Topology.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.TopologyView.hotSpotId));
+	}
+
+	@Test
+	public void testSortingUsingCpuUsageOnTopologyView(){
+		navigateToTopologyTreeView();
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.cpuUsageXpath);
+		assertMemberSortingByCpuUsage();
+	}
+	
+	@Test
+	public void testSortingUsingHeapUsageOnTopologyView(){
+		navigateToTopologyTreeView();
+		clickElementUsingId(PulseTestLocators.TopologyView.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.TopologyView.heapUsageXpath);
+		assertMemberSortingByHeapUsage();
+	}
+	
+	//--- Server Group view
+	
+	@Test
+	public void testHotSpotOptPrsntOnServerGroupView(){
+		navigateToServerGroupTreeView();
+	    assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));	
+	}
+	
+	@Test
+	public void testHotSpotOptionsServerGroupView(){	
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
+		assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath));
+		assertEquals(PulseTestData.ServerGroups.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath));		
+	}
+	
+	@Test
+	public void testCpuUsageNavigationOnServerGroupView(){
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath);
+		assertEquals(PulseTestData.ServerGroups.hotSpotCPULbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));
+	}
+	
+	@Test
+	public void testHeapUsageNavigationOnServerGroupView(){
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath);
+		assertEquals(PulseTestData.ServerGroups.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.ServerGroups.hotSpotId));
+	}	
+
+	@Test
+	public void testSortingUsingHeapUsageOnServerGroupView(){
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.heapUsageXpath);
+		assertMemberSortingBySgHeapUsage();
+	}
+	
+	@Test
+	public void testSortingUsingCpuUsageOnServerGroupView(){
+		navigateToServerGroupTreeView();
+		clickElementUsingId(PulseTestLocators.ServerGroups.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.ServerGroups.cpuUsageXpath);
+		assertMemberSortingBySgCpuUsage();
+	}
+	
+	//--- Redundancy Zone view
+	
+	@Test
+	public void testHotSpotOptPrsntOnRedundancyZoneView(){
+		navigateToRedundancyZonesTreeView();
+	    assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));	
+	}
+	
+	
+	@Test
+	public void testHotSpotOptionsRedundancyZoneView(){	
+		// navigate to Redundancy Zones - Tree View
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
+		assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath));
+		assertEquals(PulseTestData.RedundancyZone.hotSpotCPULbl, getTextUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath));		
+	}
+	
+	@Test
+	public void testCpuUsageNavigationOnRedundancyZoneView(){
+		// navigate to Redundancy Zones - Tree View
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath);
+		assertEquals(PulseTestData.RedundancyZone.hotSpotCPULbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));
+	}
+	
+	@Test
+	public void testHeapUsageNavigationOnRedundancyZoneView(){
+		// navigate to Redundancy Zones - Tree View
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath);
+		assertEquals(PulseTestData.RedundancyZone.hotSpotHeapLbl, getTextUsingId(PulseTestLocators.RedundancyZone.hotSpotId));
+	}
+	
+	@Test
+	public void testSortingUsingHeapUsageOnRedundancyView(){
+		// navigate to Redundancy Zones - Tree View
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.heapUsageXpath);
+		assertMemberSortingByRzHeapUsage();
+	}
+	
+	@Test
+	public void testSortingUsingCpuUsageOnRedundancyView(){
+		// navigate to Redundancy Zones - Tree View
+		navigateToRedundancyZonesTreeView();
+		clickElementUsingId(PulseTestLocators.RedundancyZone.hotSpotId);
+		clickElementUsingXpath(PulseTestLocators.RedundancyZone.cpuUsageXpath);
+		assertMemeberSortingByRzCpuUsage();
+	}	
+	
+	@Test
+	public void testDataBrowserFilterFeature(){
+		// navigate to Data browser page
+		loadDataBrowserpage();		
+		List<WebElement> regionLst = getRegionsFromDataBrowser();		
+		String []regionNames = new String[regionLst.size()];		
+		for(int regionIndex = 0; regionIndex < regionLst.size(); regionIndex++){
+			regionNames[regionIndex] = findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + (regionIndex + 1 ) + PulseTestLocators.DataBrowser.rgnSpanSecondPart).getText();
+		}	
+		// type each region name in region filter and verify respective region(s) are displayed in region list
+		for (String region : regionNames) {
+				findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).clear();
+				findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).sendKeys(region);				
+				
+				List<WebElement> regionLst1 = getRegionsFromDataBrowser();									
+				
+				for(int regionIndex = 1; regionIndex <= regionLst1.size(); regionIndex++){
+					assertEquals(region,  findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + regionIndex + PulseTestLocators.DataBrowser.rgnSpanSecondPart).getText());
+				}
+		}
+	}
+	
+	@Test
+	public void testDataBrowserFilterPartialRegionName(){
+		// navigate to Data browser page
+		loadDataBrowserpage();		
+		findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).clear();
+		
+		// type partial region name in region filter and verify that all the regions that contains that  text displays
+		findElementById(PulseTestLocators.DataBrowser.rgnFilterTxtBoxId).sendKeys(PulseTestData.DataBrowser.partialRgnName);
+		List<WebElement> regionLst = getRegionsFromDataBrowser();		
+		
+		for(int regionIndex = 0; regionIndex < regionLst.size(); regionIndex++){			
+			assertTrue(findElementByXpath(PulseTestLocators.DataBrowser.rgnSpanFirstPart + 
+					(regionIndex + 1 ) + 
+					PulseTestLocators.DataBrowser.rgnSpanSecondPart).
+					getText().
+					contains(PulseTestData.DataBrowser.partialRgnName));
+		}	
+	}
+	
+	@Test
+	public void testDataBrowserClearButton(){
+		// navigate to Data browser page
+		loadDataBrowserpage();		
+		
+		sendKeysUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId, PulseTestData.DataBrowser.query1Text);		
+		String editorTextBeforeClear = getTextUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId);
+		clickElementUsingXpath(PulseTestLocators.DataBrowser.btnClearXpath);
+		String editorTextAfterClear = getTextUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId);
+		
+		assertFalse(PulseTestData.DataBrowser.query1Text.equals(editorTextAfterClear));
+	}
+	
+	@Ignore("WIP") // Data Browser's Query History not showing any data on button click, therefore this test is failing
+	@Test
+	public void testDataBrowserHistoryQueue(){
+		// navigate to Data browser page
+		loadDataBrowserpage();	
+						
+		List<WebElement> numOfReg = driver.findElements(By.xpath(PulseTestLocators.DataBrowser.divDataRegions));
+		   
+	    for(int i = 1;  i <= numOfReg.size(); i ++){
+	    	if(getTextUsingId("treeDemo_" + i + "_span").equals( PulseTestData.DataBrowser.regName)){	  	    		
+	    		searchByIdAndClick("treeDemo_" + i + "_check"); 	//driver.findElement(By.id("treeDemo_" + i + "_check")).click();
+	    	}
+	    }	
+		
+		sendKeysUsingId(PulseTestLocators.DataBrowser.queryEditorTxtBoxId, PulseAbstractTest.QUERY_TYPE_ONE);
+		clickElementUsingId(PulseTestLocators.DataBrowser.btnExecuteQueryId);
+			
+		//Get required datetime format and extract date and hours from date time.
+	    DateFormat dateFormat = new SimpleDateFormat(PulseTestData.DataBrowser.datePattern);
+	    String queryDateTime = dateFormat.format(System.currentTimeMillis());
+	    String queryTime[] = queryDateTime.split(":");
+		System.out.println("Query Time from System: " + queryTime[0]);
+
+	    
+	    clickElementUsingId(PulseTestLocators.DataBrowser.historyIcon);	    
+	    List<WebElement> historyLst = driver.findElements(By.xpath(PulseTestLocators.DataBrowser.historyLst));
+		String queryText       = findElementByXpath(PulseTestLocators.DataBrowser.historyLst)
+						.findElement(By.cssSelector(PulseTestLocators.DataBrowser.queryText)).getText();
+  	String historyDateTime = findElementByXpath(PulseTestLocators.DataBrowser.historyLst)
+						.findElement(By.cssSelector(PulseTestLocators.DataBrowser.historyDateTime)).getText();
+	  System.out.println("Query Text from History Table: " + queryText);
+		System.out.println("Query Time from History Table: " + historyDateTime);
+  	    //verify the query text, query datetime in history panel
+	    assertTrue(PulseAbstractTest.QUERY_TYPE_ONE.equals(queryText));
+	    assertTrue(historyDateTime.contains(queryTime[0]));
+	   
+	}	
+}