You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ab...@apache.org on 2016/02/17 19:23:21 UTC

[17/51] [partial] incubator-geode git commit: GEODE-917: rename gemfire subprojects to geode

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreHelper.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreHelper.java
deleted file mode 100644
index 58a66bc..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreHelper.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.gemstone.gemfire.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;
-
-public class BackupDataStoreHelper {
-
-  public static String LOCK_SERVICE_NAME = BackupDataStoreHelper.class.getSimpleName();
-
-  private static String LOCK_NAME = LOCK_SERVICE_NAME + "_token";
-  
-  private static Object LOCK_SYNC = new Object();
-
-  @SuppressWarnings("rawtypes")
-  public static BackupDataStoreResult backupAllMembers(
-      DM dm, Set recipients, File targetDir, File baselineDir) {
-    FlushToDiskRequest.send(dm, recipients);
-
-    boolean abort= true;
-    Map<DistributedMember, Set<PersistentID>> successfulMembers;
-    Map<DistributedMember, Set<PersistentID>> existingDataStores;
-    try {
-      existingDataStores = PrepareBackupRequest.send(dm, recipients);
-      abort = false;
-    } finally {
-      successfulMembers = FinishBackupRequest.send(dm, recipients, targetDir, baselineDir, abort);
-    }
-    return new BackupDataStoreResult(existingDataStores, successfulMembers);
-  }
-  
-  private static DistributedLockService getLockService(DM dm) {
-    DistributedLockService dls = DistributedLockService.getServiceNamed(LOCK_SERVICE_NAME);
-    if (dls == null) {
-      synchronized (LOCK_SYNC) {
-        dls = DistributedLockService.getServiceNamed(LOCK_SERVICE_NAME);
-        if (dls == null) {
-          // Create the DistributedLockService
-          dls = DistributedLockService.create(LOCK_SERVICE_NAME, dm.getSystem());
-        }
-      }
-    }
-    Assert.assertTrue(dls != null);
-    return dls;
-  }
-  
-  public static boolean obtainLock(DM dm) {
-    return getLockService(dm).lock(LOCK_NAME, 0, -1);
-  }
-  
-  public static void releaseLock(DM dm) {
-    getLockService(dm).unlock(LOCK_NAME);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreResult.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreResult.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreResult.java
deleted file mode 100644
index b939f75..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupDataStoreResult.java
+++ /dev/null
@@ -1,57 +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.gemstone.gemfire.admin.internal;
-
-import java.util.Map;
-import java.util.Set;
-
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-
-public class BackupDataStoreResult {
-  
-  private Map<DistributedMember, Set<PersistentID>> existingDataStores;
-
-  private Map<DistributedMember, Set<PersistentID>> successfulMembers;
-
-  public BackupDataStoreResult(
-      Map<DistributedMember, Set<PersistentID>> existingDataStores,
-      Map<DistributedMember, Set<PersistentID>> successfulMembers) {
-    this.existingDataStores = existingDataStores;
-    this.successfulMembers = successfulMembers;
-  }
-
-  public Map<DistributedMember, Set<PersistentID>> getExistingDataStores() {
-    return this.existingDataStores;
-  }
-
-  public Map<DistributedMember, Set<PersistentID>> getSuccessfulMembers() {
-    return this.successfulMembers;
-  }
-  
-  public String toString() {
-    return new StringBuilder()
-      .append(getClass().getSimpleName())
-      .append("[")
-      .append("existingDataStores=")
-      .append(this.existingDataStores)
-      .append("; successfulMembers=")
-      .append(this.successfulMembers)
-      .append("]")
-      .toString();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupStatusImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupStatusImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupStatusImpl.java
deleted file mode 100644
index aee056e..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/BackupStatusImpl.java
+++ /dev/null
@@ -1,62 +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.gemstone.gemfire.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;
-
-/**
- * Holds the result of a backup operation.
- * 
- * @author dsmith
- *
- */
-public class BackupStatusImpl implements BackupStatus, Serializable {
-  private static final long serialVersionUID = 3704162840296921840L;
-  
-  private Map<DistributedMember, Set<PersistentID>> backedUpDiskStores;
-  private Set<PersistentID> offlineDiskStores;
-  
-  public BackupStatusImpl(
-      Map<DistributedMember, Set<PersistentID>> backedUpDiskStores,
-      Set<PersistentID> offlineDiskStores) {
-    super();
-    this.backedUpDiskStores = backedUpDiskStores;
-    this.offlineDiskStores = offlineDiskStores;
-  }
-
-  public Map<DistributedMember, Set<PersistentID>> getBackedUpDiskStores() {
-    return backedUpDiskStores;
-  }
-
-  public Set<PersistentID> getOfflineDiskStores() {
-    return offlineDiskStores;
-  }
-
-  @Override
-  public String toString() {
-    return "BackupStatus[backedUpDiskStores=" + backedUpDiskStores + ", offlineDiskStores=" + offlineDiskStores + "]"; 
-  }
-  
-  
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthConfigImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthConfigImpl.java
deleted file mode 100644
index 127fe21..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthConfigImpl.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.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.*;
-
-/**
- * The implementation of <code>CacheHealthConfig</code>
- *
- * @author David Whitlock
- *
- * @since 3.5
- */
-public abstract class CacheHealthConfigImpl
-  extends MemberHealthConfigImpl implements CacheHealthConfig {
-
-  /** The maximum number of milliseconds a
-   * <code>netSearch</code> operation can take before the cache member
-   * is considered to be unhealthy. */
-  private long maxNetSearchTime = DEFAULT_MAX_NET_SEARCH_TIME;
-
-  /** The maximum mumber of milliseconds a cache
-   * <code>load</code> operation can take before the cache member is
-   * considered to be unhealthy. */
-  private long maxLoadTime = DEFAULT_MAX_LOAD_TIME;
-
-  /** The minimum hit ratio of a healthy cache member. */
-  private double minHitRatio = DEFAULT_MIN_HIT_RATIO;
-
-  /** The maximum number of entries in the event delivery queue
-   * of a healthy cache member. */
-  private long maxEventQueueSize = DEFAULT_MAX_EVENT_QUEUE_SIZE;
-
-  ///////////////////////  Constructors  ///////////////////////
-
-  /**
-   * Creates a new <code>CacheHealthConfigImpl</code> with the default
-   * configuration.
-   */
-  CacheHealthConfigImpl() {
-
-  }
-
-  //////////////////////  Instance Methods  /////////////////////
-
-  public long getMaxNetSearchTime() {
-    return this.maxNetSearchTime;
-  }
-
-  public void setMaxNetSearchTime(long maxNetSearchTime) {
-    this.maxNetSearchTime = maxNetSearchTime;
-  }
-
-  public long getMaxLoadTime() {
-    return this.maxLoadTime;
-  }
-
-  public void setMaxLoadTime(long maxLoadTime) {
-    this.maxLoadTime = maxLoadTime;
-  }
-
-  public double getMinHitRatio() {
-    return this.minHitRatio;
-  }
-
-  public void setMinHitRatio(double minHitRatio) {
-    this.minHitRatio = minHitRatio;
-  }
-
-  public long getMaxEventQueueSize() {
-    return this.maxEventQueueSize;
-  }
-
-  public void setMaxEventQueueSize(long maxEventQueueSize) {
-    this.maxEventQueueSize = maxEventQueueSize;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthEvaluator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthEvaluator.java
deleted file mode 100644
index 7df4b85..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheHealthEvaluator.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.gemstone.gemfire.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;
-
-/**
- * Contains the logic for evaluating the health of a GemFire
- * <code>Cache</code> instance according to the thresholds provided in
- * a {@link CacheHealthConfig}.
- *
- * @author David Whitlock
- *
- * @since 3.5
- */
-class CacheHealthEvaluator extends AbstractHealthEvaluator 
-  implements CacheLifecycleListener {
-
-  private static final Logger logger = LogService.getLogger();
-  
-  /** The config from which we get the evaulation criteria */
-  private CacheHealthConfig config;
-
-  /** The description of the cache being evaluated */
-  private String description;
-
-  /** Statistics about the <code>Cache</code> instance.  If no cache
-   * has been created in this VM, this field will be <code>null</code>
-   */
-  private CachePerfStats cacheStats;
-
-  /** The previous value of the netsearchTime stat (in nanoseconds) */
-  private long prevNetsearchTime;
-
-  /** The previous value of the netsearchedCompleted stat */
-  private long prevNetsearchesCompleted;
-
-  /** The previous value of the loadTime stat (in nanoseconds) */
-  private long prevLoadTime;
-
-  /** The previous value of the loadedCompleted stat */
-  private long prevLoadsCompleted;
-
-  /** The previous value of the gets stat */
-  private long prevGets;
-
-  //////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>CacheHealthEvaluator</code>
-   */
-  CacheHealthEvaluator(GemFireHealthConfig config,
-                       DM dm) {
-    super(config, dm);
-
-    this.config = config;
-    InternalDistributedSystem system = dm.getSystem();
-    GemFireCacheImpl cache;
-    try {
-      cache = (GemFireCacheImpl) CacheFactory.getInstance(system);
-
-    } catch (CancelException ex) {
-      // No cache in this VM
-      cache = null;
-    }
-
-    initialize(cache, dm);
-    GemFireCacheImpl.addCacheLifecycleListener(this);
-  }
-
-  ////////////////////  Instance Methods  ////////////////////
-
-  @Override
-  protected String getDescription() {
-    return this.description;
-  }
-
-  /**
-   * Initializes the state of this evaluator based on the given cache
-   * instance. 
-   */
-  private void initialize(GemFireCacheImpl cache, DM dm) {
-    StringBuffer sb = new StringBuffer();
-    if (cache != null) {
-      this.cacheStats = cache.getCachePerfStats();
-
-      sb.append("Cache \"");
-      sb.append(cache.getName());
-      sb.append("\"");
-
-    } else {
-      sb.append("No Cache");
-    }
-
-    sb.append(" in member ");
-    sb.append(dm.getId());
-    int pid = OSProcess.getId();
-    if (pid != 0) {
-      sb.append(" with pid ");
-      sb.append(pid);
-    }
-    this.description = sb.toString();
-  }
-
-  public void cacheCreated(GemFireCacheImpl cache) {
-    InternalDistributedSystem system =
-      (InternalDistributedSystem) cache.getDistributedSystem();
-    DM dm = system.getDistributionManager();
-    initialize(cache, dm);
-  }
-
-  /**
-   * Checks to make sure that the average <code>netSearch</code> time
-   * during the previous health check interval is less than the
-   * {@linkplain CacheHealthConfig#getMaxNetSearchTime threshold}.  If
-   * not, the status is "okay" health.
-   *
-   * @see CachePerfStats#getNetsearchTime
-   * @see CachePerfStats#getNetsearchesCompleted
-   */
-  void checkNetSearchTime(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
-      return;
-    }
-
-    long deltaNetsearchTime =
-      this.cacheStats.getNetsearchTime() - this.prevNetsearchTime;
-    long deltaNetsearchesCompleted =
-      this.cacheStats.getNetsearchesCompleted() -
-      this.prevNetsearchesCompleted;
-
-    if (deltaNetsearchesCompleted != 0) {
-      long ratio = deltaNetsearchTime / deltaNetsearchesCompleted;
-      ratio /= 1000000;
-      long threshold = this.config.getMaxNetSearchTime();
-        
-      if (ratio > threshold) {
-        String s = LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_NETSEARCH_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { ratio, threshold });
-        status.add(okayHealth(s));
-      }
-    }
-  }
-
-  /**
-   * Checks to make sure that the average <code>load</code> time
-   * during the previous health check interval is less than the
-   * {@linkplain CacheHealthConfig#getMaxLoadTime threshold}.  If
-   * not, the status is "okay" health.
-   *
-   * @see CachePerfStats#getLoadTime
-   * @see CachePerfStats#getLoadsCompleted
-   */
-  void checkLoadTime(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
-      return;
-    }
-
-    if (!isFirstEvaluation()) {
-      long deltaLoadTime =
-        this.cacheStats.getLoadTime() - this.prevLoadTime;
-      long deltaLoadsCompleted =
-        this.cacheStats.getLoadsCompleted() -
-        this.prevLoadsCompleted;
-
-      if (logger.isDebugEnabled()) {
-        logger.debug("Completed {} loads in {} ms", deltaLoadsCompleted, (deltaLoadTime / 1000000));
-      }
-
-      if (deltaLoadsCompleted != 0) {
-        long ratio = deltaLoadTime / deltaLoadsCompleted;
-        ratio /= 1000000;
-        long threshold = this.config.getMaxLoadTime();
-        
-        if (ratio > threshold) {
-          String s = LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_LOAD_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { ratio, threshold });
-          if (logger.isDebugEnabled()) {
-            logger.debug(s);
-          }
-          status.add(okayHealth(s));
-        }
-      }
-    }
-  }
-
-  /**
-   * Checks to make sure that the cache hit ratio during the previous
-   * health check interval is less than the {@linkplain
-   * CacheHealthConfig#getMinHitRatio threshold}.  If not, the status
-   * is "okay" health.
-   *
-   * <P>
-   *
-   * The following formula is used to compute the hit ratio:
-   *
-   * <PRE>
-   * hitRatio = (gets - (loadsCompleted + netsearchesCompleted)) / (gets)
-   * </PRE>
-   *
-   *
-   * @see CachePerfStats#getGets
-   * @see CachePerfStats#getLoadsCompleted
-   * @see CachePerfStats#getNetsearchesCompleted
-   */
-  void checkHitRatio(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
-      return;
-    }
-
-    long deltaGets = this.cacheStats.getGets() - this.prevGets;
-    if (deltaGets != 0) {
-      long deltaLoadsCompleted =
-        this.cacheStats.getLoadsCompleted() - this.prevLoadsCompleted;
-      long deltaNetsearchesCompleted =
-        this.cacheStats.getNetsearchesCompleted() -
-        this.prevNetsearchesCompleted;
-
-      double hits =
-        (deltaGets -
-                (deltaLoadsCompleted + deltaNetsearchesCompleted));
-      double hitRatio = hits / deltaGets;
-      double threshold = this.config.getMinHitRatio();
-      if (hitRatio < threshold) {
-        String s = "The hit ratio of this Cache (" + hitRatio +
-          ") is below the threshold (" + threshold + ")";
-        status.add(okayHealth(s));
-      }
-    }
-  }
-
-  /**
-   * Checks to make sure that the {@linkplain
-   * CachePerfStats#getEventQueueSize cache event queue size} does
-   * not exceed the {@linkplain CacheHealthConfig#getMaxEventQueueSize
-   * threshold}.  If it does, the status is "okay" health.
-   */
-  void checkEventQueueSize(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
-      return;
-    }
-
-    long eventQueueSize = this.cacheStats.getEventQueueSize();
-    long threshold = this.config.getMaxEventQueueSize();
-    if (eventQueueSize > threshold) {
-      String s = LocalizedStrings.CacheHealthEvaluator_THE_SIZE_OF_THE_CACHE_EVENT_QUEUE_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { Long.valueOf(eventQueueSize), Long.valueOf(threshold) });
-      status.add(okayHealth(s));
-    }
-  }
-
-
-  /**
-   * Updates the previous values of statistics
-   */
-  private void updatePrevious() {
-    if (this.cacheStats != null && !this.cacheStats.isClosed()) {
-      this.prevLoadTime = this.cacheStats.getLoadTime();
-      this.prevLoadsCompleted = this.cacheStats.getLoadsCompleted();
-      this.prevNetsearchTime = this.cacheStats.getNetsearchTime();
-      this.prevNetsearchesCompleted =
-        this.cacheStats.getNetsearchesCompleted();
-      this.prevGets = this.cacheStats.getGets();
-
-    } else {
-      this.prevLoadTime = 0L;
-      this.prevLoadsCompleted = 0L;
-      this.prevNetsearchTime = 0L;
-      this.prevNetsearchesCompleted = 0L;
-      this.prevGets = 0L;
-    }
-  }
-
-  @Override
-  protected void check(List status) {
-
-    checkNetSearchTime(status);
-    checkLoadTime(status);
-    checkHitRatio(status);
-    checkEventQueueSize(status);
-
-    updatePrevious();
-  }
-
-  @Override
-  public void close() {
-    GemFireCacheImpl.removeCacheLifecycleListener(this);
-  }
-
-  @Override
-  public void cacheClosed(GemFireCacheImpl cache) {
-    // do nothing
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerConfigImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerConfigImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerConfigImpl.java
deleted file mode 100644
index 1518f8b..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerConfigImpl.java
+++ /dev/null
@@ -1,136 +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.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.CacheServerConfig;
-import com.gemstone.gemfire.admin.CacheVmConfig;
-import com.gemstone.gemfire.distributed.internal.DistributionConfig;
-import com.gemstone.gemfire.internal.admin.GemFireVM;
-
-/**
- * An implementation of <code>CacheVmConfig</code>
- *
- * @author David Whitlock
- * @since 4.0
- */
-public class CacheServerConfigImpl extends ManagedEntityConfigImpl 
-  implements CacheVmConfig, CacheServerConfig {
-
-  /** Declarative caching XML file that is used to initialize the
-   * Cache in the cache server. */
-  private String cacheXMLFile;
-
-  /** Extra classpath for the cache server */
-  private String classpath;
-
-  ///////////////////////  Constructors  ///////////////////////
-
-  /**
-   * Creates a new <code>CacheServerConfigImpl</code> with the default
-   * configuration settings.
-   */
-  public CacheServerConfigImpl() {
-    this.cacheXMLFile = null;
-    this.classpath = null;
-  }
-
-  /**
-   * Creates a new <code>CacheServerConfigImpl</code> for a running
-   * cache server.
-   */
-  public CacheServerConfigImpl(GemFireVM vm) {
-    super(vm);
-
-    String name = DistributionConfig.CACHE_XML_FILE_NAME;
-    this.cacheXMLFile = vm.getConfig().getAttribute(name);
-    this.classpath = null;
-  }
-
-  /**
-   * Copy constructor
-   */
-  public CacheServerConfigImpl(CacheServerConfig other) {
-    super(other);
-    this.cacheXMLFile = other.getCacheXMLFile();
-    this.classpath = other.getClassPath();
-  }
-
-  /**
-   * Copy constructor
-   */
-  public CacheServerConfigImpl(CacheVmConfig other) {
-    super(other);
-    this.cacheXMLFile = other.getCacheXMLFile();
-    this.classpath = other.getClassPath();
-  }
-
-  //////////////////////  Instance Methods  //////////////////////
-
-  public String getCacheXMLFile() {
-    return this.cacheXMLFile;
-  }
-
-  public void setCacheXMLFile(String cacheXMLFile) {
-    checkReadOnly();
-    this.cacheXMLFile = cacheXMLFile;
-    configChanged();
-  }
-
-  public String getClassPath() {
-    return this.classpath;
-  }
-
-  public void setClassPath(String classpath) {
-    checkReadOnly();
-    this.classpath = classpath;
-    configChanged();
-  }
-
-  @Override
-  public void validate() {
-    super.validate();
-
-    // Nothing to validate really.  Cache.xml file could live on
-    // different file system.
-  }
-
-  /**
-   * Currently, listeners are not supported on the locator config.
-   */
-  @Override
-  protected void configChanged() {
-
-  }
-
-  @Override
-  public Object clone() throws CloneNotSupportedException {
-    return new CacheServerConfigImpl((CacheVmConfig)this);
-  }
-
-  @Override
-  public String toString() {
-    StringBuffer sb = new StringBuffer();
-    sb.append(super.toString());
-    sb.append(" cacheXMLFile=");
-    sb.append(this.getCacheXMLFile());
-    sb.append(" classPath=");
-    sb.append(this.getClassPath());
-
-    return sb.toString();    
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerImpl.java
deleted file mode 100644
index fd5fef3..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/CacheServerImpl.java
+++ /dev/null
@@ -1,199 +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.gemstone.gemfire.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 com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-/**
- * Implements the administrative interface to a cache server.
- *
- * @author David Whitlock
- * @since 3.5
- */
-public class CacheServerImpl extends ManagedSystemMemberImpl
-  implements CacheVm, CacheServer {
-
-  /** How many new <code>CacheServer</code>s have been created? */
-  private static int newCacheServers = 0;
-
-  ///////////////////////  Instance Fields  ///////////////////////
-
-  /** The configuration object for this cache server */
-  private final CacheServerConfigImpl config;
-
-  /////////////////////////  Constructors  ////////////////////////
-
-  /**
-   * Creates a new <code>CacheServerImpl</code> that represents a
-   * non-existsing (unstarted) cache server in a given distributed
-   * system.
-   */
-  public CacheServerImpl(AdminDistributedSystemImpl system,
-                         CacheVmConfig config) 
-    throws AdminException {
-
-    super(system, config);
-
-    this.config = (CacheServerConfigImpl) config;
-    this.config.setManagedEntity(this);
-  }
-
-  /**
-   * Creates a new <code>CacheServerImpl</code> that represents an
-   * existing dedicated cache server in a given distributed system.
-   */
-  public CacheServerImpl(AdminDistributedSystemImpl system,
-                         GemFireVM vm) 
-    throws AdminException {
-
-    super(system, vm);
-    this.config = new CacheServerConfigImpl(vm);
-  }
-
-  //////////////////////  Instance Methods  //////////////////////
-
-  @Override
-  public SystemMemberType getType() {
-    return SystemMemberType.CACHE_VM;
-  }
-
-  public String getNewId() {
-    synchronized (CacheServerImpl.class) {
-      return "CacheVm" + (++newCacheServers);
-    }
-  }
-
-  public void start() throws AdminException {
-    if (!needToStart()) {
-      return;
-    }
-
-    this.config.validate();
-    this.controller.start(this);
-    this.config.setManagedEntity(this);
-  }
-
-  public void stop() {
-    if (!needToStop()) {
-      return;
-    }
-
-    this.controller.stop(this);
-    // NOTE: DistributedSystem nodeLeft will then set this.manager to null
-    this.config.setManagedEntity(null);
-  }
-  
-  public boolean isRunning() {
-    DM dm = ((AdminDistributedSystemImpl)getDistributedSystem()).getDistributionManager();
-    if(dm == null) {
-      try {
-        return this.controller.isRunning(this);
-      }
-      catch (IllegalStateException e) {
-        return false;
-      }
-    }
-    return ((DistributionManager)dm).getDistributionManagerIdsIncludingAdmin().contains(getDistributedMember());
-  }
-
-  public CacheServerConfig getConfig() {
-    return this.config;
-  }
-
-  public CacheVmConfig getVmConfig() {
-    return this.config;
-  }
-
-  ////////////////////////  Command execution  ////////////////////////
-
-  public ManagedEntityConfig getEntityConfig() {
-    return this.getConfig();
-  }
-
-  public String getEntityType() {
-    // Fix bug 32564
-    return "Cache Vm";
-  }
-
-  public String getStartCommand() {
-    StringBuffer sb = new StringBuffer();
-    sb.append(this.controller.getProductExecutable(this, "cacheserver"));
-    sb.append(" start -dir=");
-    sb.append(this.getConfig().getWorkingDirectory());
-
-    String file = this.getConfig().getCacheXMLFile();
-    if (file != null && file.length() > 0) {
-      sb.append(" ");
-      sb.append(com.gemstone.gemfire.distributed.internal.DistributionConfig.CACHE_XML_FILE_NAME);
-      sb.append("=");
-      sb.append(file);
-    }
-
-    String classpath = this.getConfig().getClassPath();
-    if (classpath != null && classpath.length() > 0) {
-      sb.append(" -classpath=");
-      sb.append(classpath);
-    }
-
-    appendConfiguration(sb);
-
-    return sb.toString().trim();
-  }
-
-  public String getStopCommand() {
-    StringBuffer sb = new StringBuffer();
-    sb.append(this.controller.getProductExecutable(this, "cacheserver"));
-    sb.append(" stop -dir=");
-    sb.append(this.getConfig().getWorkingDirectory());
-
-    return sb.toString().trim();
-  }
-
-  public String getIsRunningCommand() {
-    StringBuffer sb = new StringBuffer();
-    sb.append(this.controller.getProductExecutable(this, "cacheserver"));
-    sb.append(" status -dir=");
-    sb.append(this.getConfig().getWorkingDirectory());
-
-    return sb.toString().trim();
-  }
-
-  /**
-   * Find whether this server is primary for given client (durableClientId)
-   * 
-   * @param durableClientId -
-   *                durable-id of the client
-   * @return true if the server is primary for given client
-   * 
-   * @since 5.6
-   */
-  public boolean isPrimaryForDurableClient(String durableClientId)
-  {
-    RemoteApplicationVM vm = (RemoteApplicationVM)this.getGemFireVM();
-    boolean isPrimary = false;
-    if (vm != null) {
-      isPrimary = vm.isPrimaryForDurableClient(durableClientId);
-}
-    return isPrimary;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterImpl.java
deleted file mode 100755
index 909214c..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterImpl.java
+++ /dev/null
@@ -1,281 +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.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-import com.gemstone.gemfire.admin.UnmodifiableConfigurationException;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import java.io.File;
-//import java.net.InetAddress;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.List;
-
-/**
- * A single configuration parameter of a system member.
- *
- * @author    Kirk Lund
- * @since     3.5
- *
- */
-public class ConfigurationParameterImpl
-implements com.gemstone.gemfire.admin.ConfigurationParameter {
-  
-  /** Identifying name of this configuration parameter */
-  protected String name;
-  /** Full description of this configuration parameter */
-  protected String description;
-  /** The current value */
-  protected Object value;
-  /** Class type of the value */
-  protected Class type;
-  /** True if this is modifiable; false if read-only */
-  protected boolean userModifiable;
-  /** List of listeners to notify when value changes */
-  private final List listeners = new ArrayList();
-  
-  // -------------------------------------------------------------------------
-  //   Constructor(s)
-  // -------------------------------------------------------------------------
-  
-  /** 
-   * Constructs new <code>ConfigurationParameterImpl</code>.
-   *
-   * @param name            the name of this parameter which cannot change
-   * @param description     full description to use
-   * @param value           the value of this parameter
-   * @param type            the class type of the value
-   * @param userModifiable  true if this is modifiable; false if read-only
-   */
-  protected ConfigurationParameterImpl(String name,
-                                       String description,
-                                       Object value,
-                                       Class type,
-                                       boolean userModifiable) {
-    if (name == null || name.length() == 0) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_CONFIGURATIONPARAMETER_NAME_MUST_BE_SPECIFIED.toLocalizedString());
-    }
-    
-    this.name = name;
-    setInternalState(description, value, type, userModifiable);
-  }
-  
-  /** 
-   * Constructs new <code>ConfigurationParameterImpl</code>.
-   *
-   * @param name            the name of this parameter which cannot change
-   * @param value           the value of this parameter
-   */
-  protected ConfigurationParameterImpl(String name,
-                                       Object value) {
-    if (name == null || name.length() == 0) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_CONFIGURATIONPARAMETER_NAME_MUST_BE_SPECIFIED.toLocalizedString());
-    }
-    
-    this.name = name;
-    setInternalState(name, value, value.getClass(), true);
-  }
-  
-  /** Constructor to allow serialization by subclass */
-  protected ConfigurationParameterImpl() {}
-  
-  // -------------------------------------------------------------------------
-  //   Attribute accessors and mutators
-  // -------------------------------------------------------------------------
-
-  public String getName() {
-    return this.name;
-  }
-  
-  public String getDescription() {
-    return this.description;
-  }
-  
-  public Object getValue() {
-    return this.value;
-  }
-  
-  public String getValueAsString() {
-    if (isString()) {
-      return (String) this.value;
-    }
-    else if (isInetAddress()) {
-      return InetAddressUtil.toString(this.value);
-    }
-    else if (isFile()) {
-      return this.value.toString();
-    }
-    else if (isOctal()) {
-      String strVal = Integer.toOctalString(((Integer) this.value).intValue());
-      if (!strVal.startsWith("0")) {
-        strVal = "0" + strVal;
-      }
-      return strVal;
-    }
-    else if (isArray()) {
-      List list = Arrays.asList((Object[]) this.value);
-      return list.toString();
-    }
-    else {
-      return this.value.toString();
-    }
-  }
-  
-  public Class getValueType() {
-    return this.type;
-  }
-  
-  public boolean isModifiable() {
-    return this.userModifiable;
-  }
-  
-  public boolean isArray() {
-    return "manager-parameters".equals(this.name) || 
-           "manager-classpaths".equals(this.name);
-  }
-  public boolean isInetAddress() {
-    return java.net.InetAddress.class.isAssignableFrom(this.type);
-  }
-  public boolean isFile() {
-    return java.io.File.class.equals(this.type);
-  }
-  public boolean isOctal() {
-    return "shared-memory-permissions".equals(this.name);
-  }
-  public boolean isString() {
-    return java.lang.String.class.equals(this.type);
-  }
-  
-  public void setValue(Object value) throws UnmodifiableConfigurationException {
-    if (!isModifiable()) {
-      throw new UnmodifiableConfigurationException(LocalizedStrings.ConfigurationParameterImpl_0_IS_NOT_A_MODIFIABLE_CONFIGURATION_PARAMETER.toLocalizedString(getName()));
-    }
-    if (value == null) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_UNABLE_TO_SET_0_TO_NULL_VALUE.toLocalizedString(getName()));
-    }
-    if (!getValueType().equals(value.getClass())) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_UNABLE_TO_SET_TYPE_0_WITH_TYPE_1.toLocalizedString(new Object[] {getValueType().getName(), value.getClass().getName()}));
-    }
-    
-    if (value instanceof String && !isString()) {
-      // we need to check what the type should be and convert to it...
-      setValueFromString((String) value);
-    }
-    else {
-      this.value = value;
-    }
-    fireConfigurationParameterValueChanged(this);
-  }
-  
-  // -------------------------------------------------------------------------
-  //   Operations for handling the registration of listeners
-  //     Note: this is only for use within impl pkg and subclass pkgs
-  // -------------------------------------------------------------------------
-  
-  /** Adds the listener for any changes to this configuration parameter. */
-  public void addConfigurationParameterListener(ConfigurationParameterListener listener) {
-    if (!this.listeners.contains(listener)) {
-      this.listeners.add(listener);
-    }
-  }
-  
-  /** Removes the listener if it's currently registered. */
-  public void removeConfigurationParameterListener(ConfigurationParameterListener listener) {
-    if (this.listeners.contains(listener)) {
-      this.listeners.remove(listener);
-    }
-  }
-
-  // -------------------------------------------------------------------------
-  //   Implementation methods
-  // -------------------------------------------------------------------------
-
-  protected void setValueFromString(String newValue) {
-    if (newValue == null) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_UNABLE_TO_SET_0_TO_NULL_VALUE.toLocalizedString(getName()));
-    }
-
-    if (isInetAddress()) {
-      this.value = InetAddressUtil.toInetAddress(newValue);
-    }
-    else if (isFile()) {
-      this.value = new File(newValue);
-    }
-    else if (isOctal()) {
-      if (!newValue.startsWith("0")) {
-        newValue = "0" + newValue;
-      }
-      this.value = Integer.valueOf(Integer.parseInt(newValue, 8));
-    }
-    else if (isArray()) {
-      // parse it TODO
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_SETTING_ARRAY_VALUE_FROM_DELIMITED_STRING_IS_NOT_SUPPORTED.toLocalizedString());
-    }
-    else {
-      this.value = newValue;
-    }
-  }
-  
-  /**
-   * Fires changed configuration parameter to registered listeners.
-   *
-   * @param parm  the configuration parameter the changed 
-   */
-  protected void fireConfigurationParameterValueChanged(ConfigurationParameter parm)  {
-    ConfigurationParameterListener[] listeners = 
-        (ConfigurationParameterListener[]) this.listeners.toArray(
-            new ConfigurationParameterListener[0]);
-    for (int i = 0; i < listeners.length; i++) {
-      listeners[i].configurationParameterValueChanged(parm);
-    }
-  }  
-  
-  /**
-   * Sets the internal state of this configuration parameter.  
-   *
-   * @param description     full description to use
-   * @param value           the value of this parameter
-   * @param type            the class type of the value
-   * @param userModifiable  true if this is modifiable; false if read-only
-   */
-  protected void setInternalState(String description,
-                                  Object value,
-                                  Class type,
-                                  boolean userModifiable) {
-    if (description == null || description.length() == 0) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_CONFIGURATIONPARAMETER_DESCRIPTION_MUST_BE_SPECIFIED.toLocalizedString());
-    }
-    this.description = description;
-    this.type = type;
-    this.userModifiable = userModifiable;
-
-    if (value == null) {
-      throw new IllegalArgumentException(LocalizedStrings.ConfigurationParameterImpl_UNABLE_TO_SET_0_TO_NULL_VALUE.toLocalizedString(getName()));
-    }
-
-    this.value = value;
-  }
-  
-  @Override
-  public String toString() {
-    return this.name;
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterListener.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterListener.java
deleted file mode 100755
index 82e0d3c..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/ConfigurationParameterListener.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.gemstone.gemfire.admin.internal;
-
-import com.gemstone.gemfire.admin.ConfigurationParameter;
-
-/**
- * Listens to value changes of a 
- * {@link com.gemstone.gemfire.admin.ConfigurationParameter}.  This is for 
- * internal use only to allow a {@link SystemMemberImpl} to keep track of 
- * configuration changes made through 
- * {@link ConfigurationParameterImpl#setValue}.
- *
- * @author    Kirk Lund
- * @since     3.5
- *
- */
-public interface ConfigurationParameterListener {
-  public void configurationParameterValueChanged(ConfigurationParameter parm);
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/DisabledManagedEntityController.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/DisabledManagedEntityController.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/DisabledManagedEntityController.java
deleted file mode 100755
index b922078..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/internal/DisabledManagedEntityController.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.gemstone.gemfire.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;
-
-/**
- * This is a disabled implementation of ManagedEntityController for bug #47909.
- *
- * The old ManagedEntityController was a concrete class which has been renamed
- * to ManagedEntityControllerImpl. The build.xml now skips building
- * ManagedEntityControllerImpl. If ManagedEntityControllerImpl is not found
- * in the classpath then the code uses DisabledManagedEntityController as a
- * place holder.
- *
- * @author Kirk Lund
- */
-class DisabledManagedEntityController implements ManagedEntityController {
-
-  private static final Logger logger = LogService.getLogger();
-
-  private static final String EXCEPTION_MESSAGE = "Local and remote OS command invocations are disabled for the Admin API.";
-  
-  DisabledManagedEntityController() {
-  }
-  
-  @Override
-  public void start(InternalManagedEntity entity) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#start {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-
-  @Override
-  public void stop(InternalManagedEntity entity) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#stop {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-
-  @Override
-  public boolean isRunning(InternalManagedEntity entity) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#isRunning {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-
-  @Override
-  public String getLog(DistributionLocatorImpl locator) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#getLog {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-
-  @Override
-  public String buildSSLArguments(DistributedSystemConfig config) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#buildSSLArguments {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-
-  @Override
-  public String getProductExecutable(InternalManagedEntity entity, String executable) {
-    if (logger.isTraceEnabled(LogMarker.MANAGED_ENTITY)){
-      logger.warn(LogMarker.MANAGED_ENTITY, "DisabledManagedEntityController#getProductExecutable {}", EXCEPTION_MESSAGE);
-    }
-    throw new UnsupportedOperationException(EXCEPTION_MESSAGE);
-  }
-}