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

[22/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/UncreatedSystemException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/UncreatedSystemException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/UncreatedSystemException.java
deleted file mode 100644
index 4552b86..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/UncreatedSystemException.java
+++ /dev/null
@@ -1,48 +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;
-
-/**
- * An <code>UncreatedSystemException</code> is thrown when the specified
- * locator's directory or configuration file can not be found.
- * <p>
- * The most likely reasons for this are:
- * <ul>
- * <li> The wrong locator directory was given.
- * <li> The locator was deleted or never created.
- * </ul>
- * <p>As of GemFire 5.0 this exception should be named UncreatedLocatorException.
- */
-public class UncreatedSystemException extends NoSystemException {
-private static final long serialVersionUID = 5424354567878425435L;
-
-  //////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>UncreatedSystemException</code>.
-   */
-  public UncreatedSystemException(String message) {
-    super(message);
-  }
-  /**
-   * Creates a new <code>UncreatedSystemException</code> with the given message
-   * and cause.
-   */
-  public UncreatedSystemException(String message, Throwable cause) {
-      super(message, cause);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/UnmodifiableException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/UnmodifiableException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/UnmodifiableException.java
deleted file mode 100644
index 3a79c3c..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/UnmodifiableException.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.gemstone.gemfire;
-
-/**
- * A <code>UnmodifiableException</code> is thrown when a
- * an attempt is made to modify a GemFire member configuration attribute
- * that can not currently be modified. In most cases the reason it can
- * not be modified is that the member is active.
- */
-public class UnmodifiableException extends GemFireException {
-private static final long serialVersionUID = -1043243260052395455L;
-
-  //////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>UnmodifiableException</code>.
-   */
-  public UnmodifiableException(String message) {
-    super(message);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/UnstartedSystemException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/UnstartedSystemException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/UnstartedSystemException.java
deleted file mode 100644
index 6a10f08..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/UnstartedSystemException.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.gemstone.gemfire;
-
-/**
- * An <code>UnstartedSystemException</code> is thrown when the specified
- * locator exists but is not running or could not be connected to.
- * <p>
- * The most likely reasons for this are:
- * <ul>
- * <li> The locator has not completely started.
- * <li> The locator is stopping.
- * <li> The locator died or was killed.
- * </ul>
- * <p>As of GemFire 5.0 this exception should be named UnstartedLocatorException.
- */
-public class UnstartedSystemException extends NoSystemException {
-private static final long serialVersionUID = -4285897556527521788L;
-
-  //////////////////////  Constructors  //////////////////////
-
-  /**
-   * Creates a new <code>UnstartedSystemException</code>.
-   */
-  public UnstartedSystemException(String message) {
-    super(message);
-  }
-  /**
-   * Creates a new <code>UnstartedSystemException</code> with the given message
-   * and cause.
-   */
-  public UnstartedSystemException(String message, Throwable cause) {
-      super(message, cause);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminConfig.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminConfig.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminConfig.java
deleted file mode 100755
index f3405bd..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminConfig.java
+++ /dev/null
@@ -1,157 +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;
-
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import java.io.BufferedReader;
-import java.io.File;
-import java.io.FileOutputStream;
-import java.io.FileReader;
-import java.io.IOException;
-import java.io.PrintStream;
-import java.util.ArrayList;
-import java.util.Date;
-
-
-/**
- * AdminConfig loads/stores the member information list. The list contains
- * all of the members being monitored.
- *
- * Config must be of the format:
- * <p>
- * <li> Name=What you want displayed as a name for the instance
- * <li> Type=SERVER|CLIENT
- * <li> Host=A valid hostname or IP Address where the instance is
- * running
- * <li> Port=The port you are using to open the monitor port for
- * the instance
- * @author dpark
- * @deprecated as of 7.0 use the <code><a href="{@docRoot}/com/gemstone/gemfire/management/package-summary.html">management</a></code> package instead
- */
-public class AdminConfig
-{
-  // Name, Type, Host, Port
-  public static Entry[] loadConfig(File file) throws IOException
-  {
-
-    // Place all lines into stack
-    ArrayList entryList = new ArrayList();
-    FileReader reader = null;
-    BufferedReader fileReader = null;
-    try {
-      reader = new FileReader(file);
-      fileReader = new BufferedReader(reader);
-      // Read the first line.
-      String line = fileReader.readLine();
-
-      while (line != null) {
-        line = line.trim();
-
-        // Replace tabs with spaces
-        line = line.replace('\t', ' ');
-
-        // Skip all empty and comment lines
-          if (line.length() != 0 && line.startsWith("#") == false) {
-            try {
-              entryList.add(new Entry(line));
-            } catch (Exception ex) {
-          // ignore - drop any lines that are not valid
-        }
-          }
-          line = fileReader.readLine();
-      }
-    }
-    finally {
-      if (fileReader != null) {
-        fileReader.close();
-      }
-      if (reader != null) {
-        reader.close();
-      }
-    }
-
-    return (Entry[])entryList.toArray(new Entry[0]);
-  }
-
-  public static void storeConfig(File file, AdminConfig.Entry entries[]) throws IOException
-  {
-    FileOutputStream fos = null;
-    PrintStream ps = null;
-    try {
-      fos = new FileOutputStream(file);
-      ps = new PrintStream(fos);
-  
-      // Header
-      ps.print("#");
-      ps.println(LocalizedStrings.AdminConfig_THIS_FILE_IS_GENERATED_BY_ADMINCONSOLE_EDIT_AS_YOU_WISH_BUT_IT_WILL_BE_OVERWRITTEN_IF_IT_IS_MODIFIED_IN_ADMINCONSOLE.toLocalizedString());
-      ps.println("#");
-      ps.println(LocalizedStrings.AdminConfig_MODIFIED_0.toLocalizedString(new Date()));
-      ps.println("#");
-      ps.println("# Name, Type, Host, Port");
-      ps.println("#");
-      int len = entries.length;
-      for (int i = 0; i < len; i++) {
-        ps.println(entries[i].toString());
-      }
-      ps.flush();
-    }
-    finally {
-      if (ps != null) {
-        ps.close();
-      }
-      if (fos != null) {
-        fos.close();
-      }
-    }
-  }
-
-
-  public static class Entry
-  {
-    public String name;
-    public String type;
-    public String host;
-    public int port;
-
-    public Entry(String line)
-    {
-            // Split
-            String split[] = line.split(",");
-
-            // Convert line to parameters
-            name = split[0].trim();
-            type = split[1].trim();
-            host = split[2].trim();
-            port = Integer.parseInt(split[3]);
-    }
-
-    public Entry(String name, String type, String host, int port)
-    {
-      this.name = name;
-      this.type = type;
-      this.host = host;
-      this.port = port;
-    }
-
-    @Override // GemStoneAddition
-    public String toString()
-    {
-      return name + "," + type + "," + host + "," + port;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystem.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystem.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystem.java
deleted file mode 100755
index 7dd5220..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystem.java
+++ /dev/null
@@ -1,478 +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;
-
-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 java.io.File;
-import java.net.InetAddress;
-import java.util.Map;
-import java.util.Set;
-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
- * DistributedSystem} that represents a connection to a GemFire
- * distributed system.
- *
- * @see AdminDistributedSystemFactory
- *
- * @author    Kirk Lund
- * @since     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
- */
-public interface AdminDistributedSystem {
-	
-  /**
-   * Retrieves the unique id for this system.
-   */
-  public String getId();
-  
-  /**
-   * 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}.
-   */
-  public String getName();
-  
-  /**
-   * Retrieves the remote command and formatting this system should use to 
-   * access and/or manipulate resources on remote machines.
-   */
-  public String getRemoteCommand();
-
-  /**
-   * Sets the remote command and formatting this system should use to access 
-   * and/or manipulate resources on remote machines.
-   */
-  public void setRemoteCommand(String remoteCommand);
-
-  /**
-   * Sets the lowest level of alert that should be delivered to the
-   * {@link AlertListener}s registered on this
-   * <code>AdminDistributedSystem</code>.  The default level is {@link
-   * AlertLevel#WARNING}. 
-   */
-  public void setAlertLevel(AlertLevel level);
-
-  /**
-   * Returns the lowest level of alerts that should be delivered to
-   * the {@link AlertListener}s registered on this
-   * <code>AdminDistributedSystem</code>.
-   *
-   * @see #setAlertLevel
-   */
-  public AlertLevel getAlertLevel();
-  
-  /**
-   * Sets the lowest level of alert that should be delivered to the
-   * {@link AlertListener}s registered on this
-   * <code>AdminDistributedSystem</code>.  The default level is {@link
-   * AlertLevel#WARNING}. 
-   */
-  public void setAlertLevelAsString(String level);
-
-  /**
-   * Returns the lowest level of alerts that should be delivered to
-   * the {@link AlertListener}s registered on this
-   * <code>AdminDistributedSystem</code>.
-   *
-   * @see #setAlertLevelAsString
-   */
-  public String getAlertLevelAsString();
-
-  /**
-   * Registers an <code>AlertListener</code> that will receive all
-   * alerts that are at or above the {@linkplain #setAlertLevel alert
-   * level}. 
-   */
-  public void addAlertListener(AlertListener listener);
-
-  /**
-   * Unregisters an <code>AlertListener</code> 
-   */
-  public void removeAlertListener(AlertListener listener);
-
-  /**
-   * Retrieves the multicast address in use by this system.
-   */
-  public String getMcastAddress();
-
-  /**
-   * Retrieves the multicast port in use by this system.
-   */
-  public int getMcastPort();
-
-  /**
-   * Retrieves comma-delimited list locators to be used if multi-cast port is
-   * zero.  Format of each locators must be host[port].
-   */
-  public String getLocators();
-
-  /** 
-   * Returns true if this system has enabled the use of multicast for communications
-   */
-  public boolean isMcastEnabled();
-  
-  /**
-   * Returns true if any members of this system are currently running.
-   */
-  public boolean isRunning();
-
-  /** 
-   * Returns <code>true</code> if this is currently connected to the
-   * system.
-   */
-  public boolean isConnected();
-    
-  /**
-   * Starts all managed entities that are not currently running.
-   *
-   * @throws AdminException
-   *         If a problem is encountered while starting the managed
-   *         entities.
-   */
-  public void start() throws AdminException;
-
-  /**
-   * Stops all managed entities that are currently running.
-   *
-   * @throws AdminException
-   *         If a problem is encountered while starting the managed
-   *         entities.
-   */
-  public void stop() throws AdminException;
-
-  /**
-   * Merges and returns all system logs as a single formatted log.
-   */
-  public String displayMergedLogs();
-
-  /**
-   * Retrieves the license information for this installation of GemFire.
-   *
-   * @deprecated Removed licensing in 8.0.
-   */
-  public java.util.Properties getLicense();
-
-  /**
-   * Creates a new <code>DistributionLocator</code> that is ready to
-   * {@linkplain DistributionLocator#getConfig configure} and
-   * {@linkplain #start start}.
-   *
-   * <P>
-   *
-   * It is presumed that the newly-added locator is used to discover
-   * members of the distributed system.  That is, the host/port of the
-   * new locator is appended to the {@link #getLocators locators}
-   * attribute of this <code>AdminDistributedSystem</code>.
-   */
-  public DistributionLocator addDistributionLocator();
-  
-  /** 
-   * Returns array of <code>DistributionLocator</code>s administered
-   * by this <code>AdminDistributedSystem</code>.
-   */ 
-  public DistributionLocator[] getDistributionLocators();
-  
-  /**
-   * Retrieves SystemMember instances for every
-   * application that is running and currently connection to this
-   * system.  Note that this list does not include dedicated
-   * {@linkplain #getCacheVms cache server vms}.
-   */
-  public SystemMember[] getSystemMemberApplications() 
-  throws com.gemstone.gemfire.admin.AdminException;
-
-  /**
-   * Display in readable format the latest Alert in this distributed system.
-   */
-  public String getLatestAlert();
-  
-  /**
-   * Returns an object for monitoring the health of GemFire.
-   */
-  public GemFireHealth getGemFireHealth();
-
-  /**
-   * Connects to the distributed system.  This method will return
-   * immediately after spawning a background thread that connects to
-   * the distributed system.  As a result, a
-   * <code>AdminDistributedSystem</code> can be "connected" to before
-   * any members of the system have been started or have been seen.
-   * The {@link #waitToBeConnected} method will wait for the
-   * connection to be made.
-   *
-   * @see #isConnected
-   * @see #isRunning
-   * @see #waitToBeConnected
-   */
-  public void connect();
-
-  /**
-   * Wait for up to a given number of milliseconds for the connection
-   * to the distributed system to be made.
-   *
-   * @param timeout
-   *        The number of milliseconds to wait for the connection to
-   *        to be made.
-   *
-   * @return Whether or not the connection was made.
-   *         <code>false</code>, if the method times out
-   *
-   * @throws InterruptedException
-   *         If the thread invoking this method is interrupted while
-   *         waiting. 
-   * @throws IllegalStateException
-   *         If {@link #connect} has not yet been called.
-   */
-  public boolean waitToBeConnected(long timeout)
-    throws InterruptedException;
-
-  /**
-   * Disconnects from the distributed system.
-   */
-  public void disconnect();
-
-  /** Returns this system's configuration .*/  
-  public DistributedSystemConfig getConfig();
-  
-  /**
-   * Registers a listener that receives callbacks when a member joins
-   * or leaves the distributed system.
-   */
-  public void addMembershipListener(SystemMembershipListener listener);
-
-  /**
-   * Unregisters a membership listener
-   *
-   * @see #addMembershipListener
-   */
-  public void removeMembershipListener(SystemMembershipListener listener);
-
-  /**
-   * Registers a cache event listener.
-   * Does nothing if the listener is already registered. The listeners are called
-   * in the order they are registered.
-   * @param listener the listener to register.
-    * @since 5.0
-   */
-   public void addCacheListener(SystemMemberCacheListener listener);
-
-   /**
-    * Unregisters a cache listener. Does nothing if the listener is
-    * not registered.
-    * @param listener the listener to unregister.
-    * @since 5.0
-    */
-   public void removeCacheListener(SystemMemberCacheListener listener);
-
-  /**
-   * Creates a new cache server that is ready to {@linkplain
-   * CacheServerConfig configure} and {@linkplain #start
-   * start}.
-   *
-   * @since 4.0
-   * @deprecated as of 5.7 use {@link #addCacheVm} instead.
-   */
-  @Deprecated
-  public CacheServer addCacheServer() throws AdminException;
-
-  /**
-   * Returns all of the dedicated cache server members of the
-   * distributed system.  Because they are not managed entities,
-   * application VMs that host a server cache are not included in the
-   * array.
-   *
-   * @since 4.0
-   * @deprecated as of 5.7 use {@link #getCacheVms} instead.
-   */
-  @Deprecated
-  public CacheServer[] getCacheServers() throws AdminException;
-
-  /**
-   * Returns all the cache server members of the distributed system which are
-   * hosting a client queue for the particular durable-client having the given
-   * durableClientId
-   * 
-   * @param durableClientId -
-   *                durable-id of the client
-   * @return array of CacheServer(s) having the queue for the durable client
-   * @throws AdminException
-   *
-   * @since 5.6
-   */
-  public CacheServer[] getCacheServers(String durableClientId)
-      throws AdminException;
-
-  /**
-   * Creates a new cache vm that is ready to {@linkplain
-   * CacheVmConfig configure} and {@linkplain #start
-   * start}.
-   *
-   * @since 5.7
-   */
-  public CacheVm addCacheVm() throws AdminException;
-
-  /**
-   * Returns all of the dedicated cache server vm members of the
-   * distributed system.  Because they are not managed entities,
-   * application VMs that host a server cache are not included in the
-   * array.
-   *
-   * @since 5.7
-   */
-  public CacheVm[] getCacheVms() throws AdminException;
-
-  /**
-   * Returns the administrative SystemMember specified by the {@link
-   * com.gemstone.gemfire.distributed.DistributedMember}.
-   *
-   * @param distributedMember the distributed member to lookup
-   * @return administrative SystemMember for that distributed member
-   * @since 5.0
-   */
-  public SystemMember lookupSystemMember(DistributedMember distributedMember) 
-  throws AdminException;
-
-  /**
-   * Indicate to the distributed system that persistent files have been lost.
-   * When a member recovers from a set of persistent files, it will wait for
-   * other members that were also persisting the same region to start up. If the
-   * persistent files for those other members were lost, this method can be used
-   * to tell the remaining members to stop waiting for the lost data.
-   * 
-   * @param host
-   *          The host of the member whose files were lost.
-   * @param directory
-   *          The directory where those files resided.
-   * @since 6.5
-   * @deprecated use {@link #revokePersistentMember(UUID)} instead
-   */
-  public void revokePersistentMember(InetAddress host, String directory) throws AdminException;
-  
-  /**
-   * Indicate to the distributed system that persistent files have been lost.
-   * When a member recovers from a set of persistent files, it will wait for
-   * other members that were also persisting the same region to start up. If the
-   * persistent files for those other members were lost, this method can be used
-   * to tell the remaining members to stop waiting for the lost data.
-   * 
-   * @param diskStoreID
-   *          The unique id of the disk store which you are revoking. The unique
-   *          id can be discovered from {@link #getMissingPersistentMembers()}
-   * 
-   * @since 7.0
-   */
-  public void revokePersistentMember(UUID diskStoreID) throws AdminException;
-  
-  /**
-   * Retrieve the set of persistent files that the existing members are waiting
-   * for. See {@link AdminDistributedSystem#revokePersistentMember(InetAddress, String)}
-   * @return The persistent members that were known to the existing persistent members,
-   * when the existing members were last online.
-   * @throws AdminException
-   * @since 6.5
-   * 
-   */
-  public Set<PersistentID> getMissingPersistentMembers() throws AdminException;
-
-  /**
-   * Shuts down all the members of the distributed system with a cache that the admin 
-   * member is connected to, excluding the stand-alone locators. Calling this method
-   * will ensure that regions with the {@link DataPolicy#PERSISTENT_PARTITION} to
-   * be shutdown in a way which allows for a faster recovery when the members are 
-   * restarted.
-   * 
-   * Killing individual members can lead to inconsistencies in the members persistent
-   * data, which gemfire repairs on startup. Calling shutDownAllMembers makes sure
-   * that the persistent files are consistent on shutdown, which makes recovery faster.
-   *  
-   * This is equivalent to calling shutDownAllMembers(0);
-   * @return The set of members that were shutdown
-   * @since 6.5
-   */
-  public Set<DistributedMember> shutDownAllMembers() throws AdminException;
-  
-  /**
-   * Shuts down all the members of the distributed system with a cache that the
-   * admin member is connected to, excluding the stand-alone locators. Calling
-   * this method will ensure that regions with the
-   * {@link DataPolicy#PERSISTENT_PARTITION} to be shutdown in a way which
-   * allows for a faster recovery when the members are restarted.
-   * 
-   * Killing individual members can lead to inconsistencies in the members
-   * persistent data, which gemfire repairs on startup. Calling
-   * shutDownAllMembers makes sure that the persistent files are consistent on
-   * shutdown, which makes recovery faster.
-   * 
-   * @param timeout The amount of time to wait (in milliseconds) for the shutdown all to
-   *          complete. 
-   * @return The set of members that were shutdown, or null if the timeout is exceeded.
-   * 
-   * @since 6.5
-   */
-  public Set<DistributedMember> shutDownAllMembers(long timeout) throws AdminException;
-
-  /**
-   * Backup the persistent files for all of the members of the distributed
-   * system that the admin member is connected to. 
-   * 
-   * @param targetDir The directory where each member's backup should be placed.
-   * 
-   * @return The status of the backup, which includes the set of members
-   * that were backed up and the set of members that were known to be
-   * offline at the time of backup.
-   * @since 6.5
-   */
-  public BackupStatus backupAllMembers(File targetDir) throws AdminException;
-  
-  /**
-   * Incrementally backup the persistent files for all of the members of the distributed
-   * system that the admin member is connected to. Only new operation log files since the previous backup will be copied during this backup.
-   * The generated restore script will reference and copy operation log files from the previous backup.
-   * 
-   * @param targetDir The directory where each member's backup should be placed.
-   * @param baselineDir The directory of a previous backup.
-   * If this parameter is null or the directory does not exist (on a member by member basis)
-   * a full backup will be performed for the member. 
-   * 
-   * @return The status of the backup, which includes the set of members
-   * that were backed up and the set of members that were known to be
-   * offline at the time of backup.
-   * @since 6.5
-   */
-  public BackupStatus backupAllMembers(File targetDir,File baselineDir) throws AdminException;
-  
-  /**
-   * Compact the persistent files for all of the members of the distributed
-   * system that the admin member connected to. 
-   * 
-   * This is equivalent to calling {DiskStore#forceCompaction} on all members.
-   * 
-   * @return The set of members that compacted their disk stores.
-   * @since 6.5
-   */
-  public Map<DistributedMember, Set<PersistentID>> compactAllDiskStores() throws AdminException;
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystemFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystemFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystemFactory.java
deleted file mode 100755
index 8c48e29..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminDistributedSystemFactory.java
+++ /dev/null
@@ -1,163 +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;
-
-import com.gemstone.gemfire.admin.internal.DistributedSystemConfigImpl;
-import com.gemstone.gemfire.admin.internal.AdminDistributedSystemImpl;
-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.InternalLogWriter;
-import com.gemstone.gemfire.internal.logging.LocalLogWriter;
-
-import java.util.Properties;
-
-/**
- * Factory for creating GemFire administration entities. 
- *
- * @author    Kirk Lund
- * @since     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
- */
-public class AdminDistributedSystemFactory {
-  
-  /**
-   * Sets the address this VM should bind to when connecting to the distributed
-   * system.  This involves a system property, so using this option will limit
-   * all connections to distributed systems to this one network interface.
-   * <p>
-   * Using a null or empty bindAddress will clear the usage of this option and
-   * connections to distributed systems will return to using all available
-   * network interfaces.
-   * <p>
-   * This method always throws UnsupportedOperationException because it is
-   * now deprecated and is unsafe to use. Please use {@link 
-   * DistributedSystemConfig#setBindAddress} instead.
-   *
-   * @param bindAddress machine name or IP address to bind to
-   * @throws UnsupportedOperationException because of deprecation
-   * @deprecated Use {@link DistributedSystemConfig#setBindAddress} instead.
-   */
-  @Deprecated
-  public static void bindToAddress(String bindAddress) {
-    throw new UnsupportedOperationException(LocalizedStrings.AdminDistributedSystemFactory_PLEASE_USE_DISTRIBUTEDSYSTEMCONFIGSETBINDADDRESS_INSTEAD.toLocalizedString());
-  }
-  
-  /**
-   * Defines a "default" distributed system configuration based on VM
-   * system properties and the content of
-   * <code>gemfire.properties</code>.  The {@linkplain
-   * DistributedSystemConfig#DEFAULT_REMOTE_COMMAND} default remote
-   * command is used.
-   *
-   * @see DistributedSystem#connect
-   */
-  public static DistributedSystemConfig defineDistributedSystem() {
-    DistributionConfig dc = new DistributionConfigImpl(new Properties());
-
-    String remoteCommand =
-      DistributedSystemConfig.DEFAULT_REMOTE_COMMAND;
-    return new DistributedSystemConfigImpl(dc, remoteCommand);
-  }
-
-  /**
-   * Call this method with a value of <code>true</code>
-   * to dedicate the VM to GemFire administration only.
-   * Default is <code>false</code>.
-   * <p>This method <em>must</em> be called before calling
-   * {@link AdminDistributedSystem#connect}. It <em>must</em> also be called
-   * 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}.
-   * @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}
-   * or {@link AdminDistributedSystem} connection already exists.
-   * 
-   * @since 5.7
-   */
-  public static void setEnableAdministrationOnly(boolean adminOnly) {
-    InternalDistributedSystem.setEnableAdministrationOnly(adminOnly);
-  }
-  
-  /**
-   * Defines a distributed system configuration for administering the
-   * distributed system to which this VM is currently connected.  The
-   * <code>DistributedSystem</code> is used to configure the discovery
-   * mechanism (multicast or locators), bind address, SSL attributes,
-   * as well as the logger of the
-   * <code>DistributedSystemConfig</code>.  Note that the distributed
-   * system will not be able to be administered until the {@link
-   * AdminDistributedSystem#connect connect} method is invoked.
-   *
-   * @param system
-   *        A connection to the distributed system
-   * @param remoteCommand
-   *        The shell command that is used to launch processes that
-   *        run on remote machines.  If <code>null</code>, then the
-   *        {@linkplain DistributedSystemConfig#DEFAULT_REMOTE_COMMAND
-   *        default} will be used.
-   *
-   * @since 4.0
-   */
-  public static DistributedSystemConfig
-    defineDistributedSystem(DistributedSystem system,
-                            String remoteCommand)
-    throws AdminException {
-
-    InternalDistributedSystem internal =
-      (InternalDistributedSystem) system;
-    if (remoteCommand == null) {
-      remoteCommand = DistributedSystemConfig.DEFAULT_REMOTE_COMMAND;
-    }
-    
-    DistributedSystemConfigImpl impl =
-      new DistributedSystemConfigImpl(internal.getConfig(),
-                                      remoteCommand);
-    return impl;
-  }
-
-  /**
-   * Returns the distributed system for administrative monitoring and
-   * managing.  You must then call {@link
-   * AdminDistributedSystem#connect} before interacting with the
-   * actual system.
-   *
-   * @param config configuration definition of the system to administer
-   * @return administrative interface for a distributed system
-   */
-  public static AdminDistributedSystem getDistributedSystem(DistributedSystemConfig config) {
-    return new AdminDistributedSystemImpl((DistributedSystemConfigImpl)config);
-  }
-  
-  /**
-   * Returns a default GemFire LogWriterI18n for logging.  This LogWriterI18n will
-   * log to standard out.
-   *
-   * @return a GemFire LogWriterI18n for logging
-   */
-  public static LogWriterI18n getLogWriter() {
-    return new LocalLogWriter(DistributionConfig.DEFAULT_LOG_LEVEL);
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminException.java
deleted file mode 100755
index 5dbe593..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminException.java
+++ /dev/null
@@ -1,90 +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;
-
-import com.gemstone.gemfire.GemFireCheckedException;
-
-/**
- * An <code>AdminException</code> is thrown when administration or monitoring
- * of GemFire fails. 
- *
- * @author    Kirk Lund
- * @since     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
- */
-public class AdminException extends GemFireCheckedException {
-private static final long serialVersionUID = 879398950879472021L;
-
-  /**
-   * Constructs a new exception with <code>null</code> as its detail message.
-   * The cause is not initialized, and may subsequently be initialized by a
-   * call to {@link Throwable#initCause}.
-   */
-  public AdminException() {
-    super();
-  }
-
-  /**
-   * Constructs a new exception with the specified detail message.  The
-   * cause is not initialized, and may subsequently be initialized by
-   * a call to {@link Throwable#initCause}.
-   *
-   * @param   message   the detail message. The detail message is saved for 
-   *          later retrieval by the {@link #getMessage()} method.
-   */
-  public AdminException(String message) {
-    super(message);
-  }
-
-  /**
-   * Constructs a new exception with the specified detail message and
-   * cause.  <p>Note that the detail message associated with
-   * <code>cause</code> is <i>not</i> automatically incorporated in
-   * this exception's detail message.
-   *
-   * @param  message the detail message (which is saved for later retrieval
-   *         by the {@link #getMessage()} method).
-   * @param  cause the cause (which is saved for later retrieval by the
-   *         {@link #getCause()} method).  (A <tt>null</tt> value is
-   *         permitted, and indicates that the cause is nonexistent or
-   *         unknown.)
-   */
-  public AdminException(String message, Throwable cause) {
-    super(message, cause);
-  }
-
-  /**
-   * Constructs a new exception with the specified cause.
-   * The detail
-   * message will be <tt>(cause==null ? null : cause.toString())</tt> (which
-   * typically contains the class and detail message of <tt>cause</tt>).
-   * This constructor is useful for exceptions that are little more than
-   * wrappers for other throwables (for example, {@link
-   * java.security.PrivilegedActionException}).
-   *
-   * @param  cause the cause (which is saved for later retrieval by the
-   *         {@link #getCause()} method).  (A <tt>null</tt> value is
-   *         permitted, and indicates that the cause is nonexistent or
-   *         unknown.)
-   */
-  public AdminException(Throwable cause) {
-    super(cause);
-  }
-    
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminXmlException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminXmlException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminXmlException.java
deleted file mode 100644
index 112f126..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AdminXmlException.java
+++ /dev/null
@@ -1,48 +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;
-
-/**
- * Thrown when a problem is encountered while working with
- * admin-related XML data.
- *
- * @see DistributedSystemConfig#getEntityConfigXMLFile
- *
- * @author David Whitlock
- * @since 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
- */
-public class AdminXmlException extends RuntimeAdminException {
-  private static final long serialVersionUID = -6848726449157550169L;
-
-  /**
-   * Creates a new <code>AdminXmlException</code> with the given
-   * descriptive message.
-   */
-  public AdminXmlException(String s) {
-    super(s);
-  }
-
-  /**
-   * Creates a new <code>AdminXmlException</code> with the given
-   * descriptive message and cause.
-   */
-  public AdminXmlException(String s, Throwable cause) {
-    super(s, cause);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/Alert.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/Alert.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/Alert.java
deleted file mode 100755
index 7c34bf9..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/Alert.java
+++ /dev/null
@@ -1,56 +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;
-
-/**
- * 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}.
- *
- * @author    Kirk Lund
- * @see       AlertListener
- * @since     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
- */
-public interface Alert {
-  
-  /** The level at which this alert is issued */
-  public AlertLevel getLevel();
-
-  /**
-   * The member of the distributed system that issued the alert, or
-   * null if the issuer is no longer a member of the distributed system.
-   */
-  public SystemMember getSystemMember();
-
-  /** 
-   * The name of the {@linkplain
-   * com.gemstone.gemfire.distributed.DistributedSystem#getName
-   * distributed system}) through which the alert was issued.
-   */
-  public String getConnectionName();
-
-  /** The id of the source of the alert (such as a thread in a VM) */
-  public String getSourceId();
-
-  /** The alert's message */
-  public String getMessage();
-
-  /** The time at which the alert was issued */
-  public java.util.Date getDate();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertLevel.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertLevel.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertLevel.java
deleted file mode 100755
index e3633a1..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertLevel.java
+++ /dev/null
@@ -1,174 +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;
-
-import com.gemstone.gemfire.internal.admin.Alert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-/**
- * Type-safe enumeration for {@link com.gemstone.gemfire.admin.Alert
- * Alert} level.
- *
- * @author    Kirk Lund
- * @since     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
- */
-public class AlertLevel implements java.io.Serializable {
-  private static final long serialVersionUID = -4752438966587392126L;
-    
-  public static final AlertLevel WARNING =
-    new AlertLevel(Alert.WARNING, "WARNING");
-  public static final AlertLevel ERROR = 
-    new AlertLevel(Alert.ERROR, "ERROR");
-  public static final AlertLevel SEVERE =
-    new AlertLevel(Alert.SEVERE, "SEVERE");
-  
-  public static final AlertLevel OFF =
-    new AlertLevel(Alert.OFF, "OFF");
-
-  /** The severity level of this AlertLevel. Greater is more severe. */
-  private final transient int severity;
-  
-  /** The name of this AlertLevel. */
-  private final transient String name;
-  
-  // The 4 declarations below are necessary for serialization
-  /** int used as ordinal to represent this AlertLevel */
-  public final int ordinal = nextOrdinal++;
-
-  private static int nextOrdinal = 0;
-  
-  private static final AlertLevel[] VALUES =
-    { WARNING, ERROR, SEVERE, OFF };
-
-  private Object readResolve() throws java.io.ObjectStreamException {
-    return VALUES[ordinal];  // Canonicalize
-  }
-  
-  /** Creates a new instance of AlertLevel. */
-  private AlertLevel(int severity, String name) {
-    this.severity = severity;
-    this.name = name;
-  }
-    
-  /** Return the AlertLevel represented by specified ordinal */
-  public static AlertLevel fromOrdinal(int ordinal) {
-    return VALUES[ordinal];
-  }
-
-  /**
-   * Returns the <code>AlertLevel</code> for the given severity
-   *
-   * @throws IllegalArgumentException
-   *         If there is no alert level with the given
-   *         <code>severity</code> 
-   */
-  public static AlertLevel forSeverity(int severity) {
-    switch (severity) {
-    case Alert.WARNING:
-      return AlertLevel.WARNING;
-    case Alert.ERROR:
-      return AlertLevel.ERROR;
-    case Alert.SEVERE:
-      return AlertLevel.SEVERE;
-    case Alert.OFF:
-      return AlertLevel.OFF;
-    default:
-      throw new IllegalArgumentException(LocalizedStrings.AlertLevel_UNKNOWN_ALERT_SEVERITY_0.toLocalizedString(Integer.valueOf(severity)));
-    }
-  }
-
-  /**
-   * Returns the <code>AlertLevel</code> with the given name
-   *
-   * @throws IllegalArgumentException
-   *         If there is no alert level named <code>name</code>
-   */
-  public static AlertLevel forName(String name) {
-    for (int i = 0; i < VALUES.length; i++) {
-      AlertLevel level = VALUES[i];
-      if (level.getName().equalsIgnoreCase(name)) {
-        return level;
-      }
-    }
-
-    throw new IllegalArgumentException(LocalizedStrings.AlertLevel_THERE_IS_NO_ALERT_LEVEL_0.toLocalizedString(name));
-  }
-
-  public int getSeverity() {
-    return this.severity;
-  }
-  
-  public String getName() {
-    return this.name;
-  }
-
-  public static AlertLevel[] values() {
-    return VALUES;
-  }
-  
-  /** 
-   * Returns a string representation for this alert level.
-   *
-   * @return the name of this alert level
-   */
-  @Override
-  public String toString() {
-    return this.name /* + "=" + this.severity */;
-  }
-
-	/**
-	 * Indicates whether some other object is "equal to" this one.
-	 *
-	 * @param  other  the reference object with which to compare.
-	 * @return true if this object is the same as the obj argument;
-	 *         false otherwise.
-	 */
-  @Override
-	public boolean equals(Object other) {
-		if (other == this) return true;
-		if (other == null) return false;
-		if (!(other instanceof AlertLevel)) return  false;
-		final AlertLevel that = (AlertLevel) other;
-
-		if (this.severity != that.severity) return false;
-		if (this.name != that.name &&
-	  		!(this.name != null &&
-	  		this.name.equals(that.name))) return false;
-
-		return true;
-	}
-
-	/**
-	 * Returns a hash code for the object. This method is supported for the
-	 * benefit of hashtables such as those provided by java.util.Hashtable.
-	 *
-	 * @return the integer 0 if description is null; otherwise a unique integer.
-	 */
-  @Override
-	public int hashCode() {
-		int result = 17;
-		final int mult = 37;
-
-		result = mult * result + this.severity;
-		result = mult * result + 
-			(this.name == null ? 0 : this.name.hashCode());
-
-		return result;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertListener.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertListener.java
deleted file mode 100755
index a19f93d..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/AlertListener.java
+++ /dev/null
@@ -1,30 +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;
-
-/**
- * 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
- */
-public interface AlertListener extends java.util.EventListener {
-
-  /**
-   * Invoked when an <code>Alert</code> is received.
-   */
-  public void alert(Alert alert);
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/BackupStatus.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/BackupStatus.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/BackupStatus.java
deleted file mode 100644
index 547a759..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/BackupStatus.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.gemstone.gemfire.admin;
-
-import java.util.Map;
-import java.util.Set;
-
-import com.gemstone.gemfire.cache.persistence.PersistentID;
-import com.gemstone.gemfire.distributed.DistributedMember;
-
-/**
- * The status of a backup operation, returned by
- * {@link AdminDistributedSystem#backupAllMembers(java.io.File,java.io.File)}.
- * 
- * @author dsmith
- * @since 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
- */
-public interface BackupStatus {
-  
-  /**
-   * Returns a map of disk stores that were successfully backed up.
-   * The key is an online distributed member. The value is the set of disk 
-   * stores on that distributed member. 
-   */
-  Map<DistributedMember, Set<PersistentID>> getBackedUpDiskStores();
-  
-  /**
-   * Returns the set of disk stores that were known to be offline at the 
-   * time of the backup. These members were not backed up. If this set
-   * is not empty the backup may not contain a complete snapshot of 
-   * any partitioned regions in the distributed system.
-   */
-  Set<PersistentID> getOfflineDiskStores();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheDoesNotExistException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheDoesNotExistException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheDoesNotExistException.java
deleted file mode 100644
index f5216da..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheDoesNotExistException.java
+++ /dev/null
@@ -1,87 +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;
-
-/**
- * An <code>CacheDoesNotExistException</code> is thrown when an attempt
- * is made to get a cache and one does not exist.
- *
- * @author    Darrel Schneider
- * @since     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
- */
-public class CacheDoesNotExistException extends AdminException {
-private static final long serialVersionUID = -1639933911265729978L;
-
-  /**
-   * Constructs a new exception with <code>null</code> as its detail message.
-   * The cause is not initialized, and may subsequently be initialized by a
-   * call to {@link Throwable#initCause}.
-   */
-  public CacheDoesNotExistException() {
-    super();
-  }
-
-  /**
-   * Constructs a new exception with the specified detail message.  The
-   * cause is not initialized, and may subsequently be initialized by
-   * a call to {@link Throwable#initCause}.
-   *
-   * @param   message   the detail message. The detail message is saved for 
-   *          later retrieval by the {@link #getMessage()} method.
-   */
-  public CacheDoesNotExistException(String message) {
-    super(message);
-  }
-
-  /**
-   * Constructs a new exception with the specified detail message and
-   * cause.  <p>Note that the detail message associated with
-   * <code>cause</code> is <i>not</i> automatically incorporated in
-   * this exception's detail message.
-   *
-   * @param  message the detail message (which is saved for later retrieval
-   *         by the {@link #getMessage()} method).
-   * @param  cause the cause (which is saved for later retrieval by the
-   *         {@link #getCause()} method).  (A <tt>null</tt> value is
-   *         permitted, and indicates that the cause is nonexistent or
-   *         unknown.)
-   */
-  public CacheDoesNotExistException(String message, Throwable cause) {
-    super(message, cause);
-  }
-
-  /**
-   * Constructs a new exception with the specified cause and a detail
-   * message of <tt>(cause==null ? null : cause.toString())</tt> (which
-   * typically contains the class and detail message of <tt>cause</tt>).
-   * This constructor is useful for exceptions that are little more than
-   * wrappers for other throwables (for example, {@link
-   * java.security.PrivilegedActionException}).
-   *
-   * @param  cause the cause (which is saved for later retrieval by the
-   *         {@link #getCause()} method).  (A <tt>null</tt> value is
-   *         permitted, and indicates that the cause is nonexistent or
-   *         unknown.)
-   */
-  public CacheDoesNotExistException(Throwable cause) {
-    super(cause);
-  }
-    
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheHealthConfig.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheHealthConfig.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheHealthConfig.java
deleted file mode 100644
index 3636209..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheHealthConfig.java
+++ /dev/null
@@ -1,157 +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;
-
-/**
- * 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}.
- *
- * <P>
- *
- * If any of the following criteria is true, then a cache member is
- * considered to be in {@link GemFireHealth#OKAY_HEALTH OKAY_HEALTH}.
- *
- * <UL>
- *
- * <LI><code>netSearch</code> operations take {@linkplain
- * #getMaxNetSearchTime too long} to complete.</LI>
- *
- * <LI>Cache <code>load</code> operations take {@linkplain
- * #getMaxLoadTime too long} to complete.</LI>
- *
- * <LI>The overall cache {@link #getMinHitRatio hitRatio} is too
- * small</LI> 
- *
- * <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}
- * on role loss.</LI>
- *
- * </UL>
- *
- * If any of the following criteria is true, then a cache member is
- * considered to be in {@link GemFireHealth#POOR_HEALTH POOR_HEALTH}.
- * 
- * <UL>
- * 
- * <LI>If one of the regions is configured with {@link com.gemstone.gemfire.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}
- * on role loss.</LI> 
- * 
- * </UL>
- * 
- * <UL>
- *
- * </UL>
- *
- * @author David Whitlock
- *
- * @since 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
- * */
-public interface CacheHealthConfig {
-
-  /** The default maximum number of milliseconds a
-   * <code>netSearch</code> operation can take before the cache member
-   * is considered to be unhealthy. */
-  public static final long DEFAULT_MAX_NET_SEARCH_TIME = 60 * 1000;
-
-  /** The default maximum mumber of milliseconds a cache
-   * <code>load</code> operation can take before the cache member is
-   * considered to be unhealthy. */
-  public static final long DEFAULT_MAX_LOAD_TIME = 60 * 1000;
-
-  /** The default minimum hit ratio of a healthy cache member. */
-  public static final double DEFAULT_MIN_HIT_RATIO = 0.0;
-
-  /** The default maximum number of entries in the event delivery queue
-   * of a healthy cache member. */
-  public static final long DEFAULT_MAX_EVENT_QUEUE_SIZE = 1000;
-
-  ///////////////////////  Instance Methods  ///////////////////////
-  
-  /**
-   * Returns the maximum number of milliseconds a
-   * <code>netSearch</code> operation can take before the cache member
-   * is considered to be unhealthy.
-   *
-   * @see #DEFAULT_MAX_NET_SEARCH_TIME
-   */
-  public long getMaxNetSearchTime();
-
-  /**
-   * Sets the maximum number of milliseconds a
-   * <code>netSearch</code> operation can take before the cache member
-   * is considered to be unhealthy.
-   *
-   * @see #getMaxNetSearchTime
-   */
-  public void setMaxNetSearchTime(long maxNetSearchTime);
-
-  /**
-   * Returns the maximum mumber of milliseconds a cache
-   * <code>load</code> operation can take before the cache member is
-   * considered to be unhealthy.
-   *
-   * @see #DEFAULT_MAX_LOAD_TIME
-   */
-  public long getMaxLoadTime();
-
-  /**
-   * Sets the maximum mumber of milliseconds a cache
-   * <code>load</code> operation can take before the cache member is
-   * considered to be unhealthy.
-   *
-   * @see #getMaxLoadTime
-   */
-  public void setMaxLoadTime(long maxLoadTime);
-
-  /**
-   * Returns the minimum hit ratio of a healthy cache member.
-   *
-   * @see #DEFAULT_MIN_HIT_RATIO
-   */
-  public double getMinHitRatio();
-
-  /**
-   * Sets the minimum hit ratio of a healthy cache member.
-   *
-   * @see #getMinHitRatio
-   */
-  public void setMinHitRatio(double minHitRatio);
-
-  /**
-   * Returns the maximum number of entries in the event delivery queue
-   * of a healthy cache member.
-   *
-   * @see #DEFAULT_MAX_EVENT_QUEUE_SIZE
-   */
-  public long getMaxEventQueueSize();
-
-  /**
-   * Sets the maximum number of entries in the event delivery queue
-   * of a healthy cache member.
-   *
-   * @see #getMaxEventQueueSize
-   */
-  public void setMaxEventQueueSize(long maxEventQueueSize);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServer.java
deleted file mode 100644
index 7cee2fa..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServer.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.gemstone.gemfire.admin;
-
-/**
- * A dedicated cache server VM that is managed by the administration
- * API.
- *
- * @author David Whitlock
- * @since 4.0
- * @deprecated as of 5.7 use {@link CacheVm} instead.
- */
-@Deprecated
-public interface CacheServer extends SystemMember, ManagedEntity {
-  /**
-   * Returns the configuration of this cache vm
-   * @deprecated as of 5.7 use {@link CacheVm#getVmConfig} instead.
-   */
-  @Deprecated
-  public CacheServerConfig getConfig();
-  /**
-   * 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);
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServerConfig.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServerConfig.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServerConfig.java
deleted file mode 100644
index 87f2fee..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheServerConfig.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.gemstone.gemfire.admin;
-
-/**
- * Configuration for a GemFire cache server that is managed by the
- * administration API.  The cache server may or may not be running.
- *
- * @see AdminDistributedSystem#addCacheServer()
- *
- * @author David Whitlock
- * @since 4.0
- * @deprecated as of 5.7 use {@link CacheVmConfig} instead.
- */
-@Deprecated
-public interface CacheServerConfig extends CacheVmConfig {
-  /**
-   * Returns the <code>cache.xml</code> declarative caching
-   * initialization file used to configure this cache server VM.  By
-   * default, a cache server VM is started without an XML file.
-   */
-  public String getCacheXMLFile();
-
-  /**
-   * Sets the <code>cache.xml</code> declarative caching
-   * initialization file used to configure this cache server VM.
-   */
-  public void setCacheXMLFile(String cacheXml);
-
-  /**
-   * Returns the location(s) of user classes (such as cache loaders)
-   * required by the cache server VM.
-   */
-  public String getClassPath();
-
-  /**
-   * Sets the location(s) of user classes (such as cache loaders)
-   * required by the cache server VM.
-   */
-  public void setClassPath(String classpath);
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVm.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVm.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVm.java
deleted file mode 100755
index 87a15a6..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVm.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.gemstone.gemfire.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
- * 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}
- * but is an instance of this interface.
- *
- * @author darrel
- * @since 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
- */
-public interface CacheVm extends SystemMember, ManagedEntity {
-  /**
-   * Returns the configuration of this cache vm
-   */
-  public CacheVmConfig getVmConfig();
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVmConfig.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVmConfig.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVmConfig.java
deleted file mode 100755
index 4193ec5..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/CacheVmConfig.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.gemstone.gemfire.admin;
-
-/**
- * Configuration for a GemFire cache server VM that is managed by the
- * administration API.  The VM may or may not be running.
- *
- * @see AdminDistributedSystem#addCacheVm()
- *
- * @author darrel
- * @since 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
- */
-public interface CacheVmConfig extends ManagedEntityConfig {
-  /**
-   * Returns the <code>cache.xml</code> declarative caching
-   * initialization file used to configure this cache server VM.  By
-   * default, a cache server VM is started without an XML file.
-   */
-  public String getCacheXMLFile();
-
-  /**
-   * Sets the <code>cache.xml</code> declarative caching
-   * initialization file used to configure this cache server VM.
-   */
-  public void setCacheXMLFile(String cacheXml);
-
-  /**
-   * Returns the location(s) of user classes (such as cache loaders)
-   * required by the cache server VM.
-   */
-  public String getClassPath();
-
-  /**
-   * Sets the location(s) of user classes (such as cache loaders)
-   * required by the cache server VM.
-   */
-  public void setClassPath(String classpath);
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/f6c4c2f9/gemfire-core/src/main/java/com/gemstone/gemfire/admin/ConfigurationParameter.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/ConfigurationParameter.java b/gemfire-core/src/main/java/com/gemstone/gemfire/admin/ConfigurationParameter.java
deleted file mode 100755
index ee42305..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/admin/ConfigurationParameter.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.gemstone.gemfire.admin;
-
-/**
-* A single configuration parameter of a {@link SystemMember}.
- *
- * @author    Kirk Lund
- * @since     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
- */
-public interface ConfigurationParameter {
-  
-  /** Gets the identifying name of this configuration parameter. */
-  public String getName();
-  
-  /** Gets the full description of this configuration parameter */
-  public String getDescription();
-  
-  /** Gets the current value */
-  public Object getValue();
-  
-  /** Gets the current value as a string */
-  public String getValueAsString();
-  
-  /** Gets the class type of the value */
-  public Class getValueType();
-  
-  /** True if this is modifiable; false if read-only */
-  public boolean isModifiable();
-  
-  /** Returns true if this config parameter uses a string array for value. */
-  public boolean isArray();
-  
-  /** Returns true if this config parameter represents an InetAddress value. */
-  public boolean isInetAddress();
-  
-  /** Returns true if this config parameter represents a File value. */
-  public boolean isFile();
-  
-  /** Returns true if this config parameter represents an octal value. */
-  public boolean isOctal();
-    
-  /** Returns true if this config parameter represents a string value. */
-  public boolean isString();
-  
-  /**
-   * Sets a new value for this configuration parameter.
-   *
-   * @param value   the new value which must be of type {@link #getValueType}
-   * @throws IllegalArgumentException
-   *         if value type does not match {@link #getValueType}
-   * @throws UnmodifiableConfigurationException
-   *         if attempting to set value when isModifiable is false
-   */
-  public void setValue(Object value) throws UnmodifiableConfigurationException;
-}
-