You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by vf...@apache.org on 2015/11/25 20:07:56 UTC

[43/50] [abbrv] incubator-geode git commit: GEODE-243: remove deprecated Bridge feature

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriter.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriter.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriter.java
deleted file mode 100755
index 1f8a09a..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriter.java
+++ /dev/null
@@ -1,795 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-import java.util.Properties;
-import java.util.concurrent.atomic.AtomicInteger;
-
-import com.gemstone.gemfire.LicenseException;
-import com.gemstone.gemfire.SystemFailure;
-import com.gemstone.gemfire.cache.AttributesFactory;
-import com.gemstone.gemfire.cache.AttributesMutator;
-import com.gemstone.gemfire.cache.CacheWriter;
-import com.gemstone.gemfire.cache.CacheWriterException;
-import com.gemstone.gemfire.cache.Declarable;
-import com.gemstone.gemfire.cache.EntryEvent;
-import com.gemstone.gemfire.cache.Region;
-import com.gemstone.gemfire.cache.RegionEvent;
-import com.gemstone.gemfire.cache.client.internal.BridgePoolImpl;
-import com.gemstone.gemfire.internal.cache.tier.ConnectionProxy;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-/**
- * A <code>CacheWriter</code> that writes data to one or more remote
- * <code>CacheServer</code> processes. This allows for a hierarchical caching
- * scheme in which one cache ('client' cache) delegates a request to another
- * cache ('server' cache).
- * 
- * 
- * When using the <code>BridgeWriter</code>, at least two GemFire Caches must
- * exist in a client/server mode (they should not be part of the same
- * distributed system).
- * 
- * The 'server' cache must be running a gemfire <code>CacheServer</code>
- * process, while the 'client' cache must have a <code>BridgeWriter</code>
- * installed in one or more of its <code>Regions</code>. If a
- * <code>BridgeWriter</code> is defined in a client <code>Region</code>,
- * there must also be a <code>Region</code> defined in the 'server' cache with
- * the same exact name.
- * 
- * <p>
- * 
- * The <code>BridgeWriter</code> performs <code>put()</code> operations on
- * the remote server cache, and does not provide the distribution behavior that
- * can be enabled by using a <code>DISTRIBUTED</code> or
- * <code>DISTRIBUTED_NO_ACK</code> <code>Region</code>. This mechanism is
- * designed as a more targeted alternative to netSearch, in which the 'client'
- * cache completely delegates the loading of the data to the 'server' cache if
- * it is not yet cached in the client. This directed behavior enables a remote
- * network <code>put()</code> operation to be performed much more efficiently
- * in a scenario where there is a hierarchical cache topology. Updates and
- * invalidation remain local, in fact the <code>Regions</code> that are used
- * for this loosely coupled cache may even be <code>LOCAL</code> in scope.
- * 
- * The <code>BridgeWriter</code> may be used to configure caches with
- * multi-layer hierarchies.
- * 
- * 
- * <p>
- * <b>Load Balancing: </b>
- * <p>
- * The <code>BridgeWriter</code> supports these load balancing mechanisms
- * (specified by the <code>LBPolicy</code> config attribute):
- * <p>
- * <ul>
- * <li><b>Sticky </b> <br>
- * In this mode, the client writer picks the first server from the list of
- * servers and establishes a connection to it. Once this connection has been
- * established, every request from that particular 'client' cache is sent on
- * that connection. If requests time out or produce exceptions, the
- * <code>BridgeWriter</code> picks another server and then sends further
- * requests to that server. This achieves a level of load balancing by
- * redirecting requests away from servers that produce timeouts.</li>
- * 
- * <li><b>RandomSticky </b> <br>
- * The behavior is the same as Sticky, however the initial assignment of the
- * connection is randomly selected from the list of servers.</li>
- * 
- * <li><b>RoundRobin </b> <br>
- * In this mode, the client establishes connections to all the servers in the
- * server list and then randomly picks a server for each given request. For the
- * next request, it picks the next server in the list.</li>
- * 
- * <li><b>Random </b>: <br>
- * In this mode, the edge establishes connections to all the servers in the
- * server list and then randomly picks a server for every request.</li>
- * </ul>
- * 
- * <p>
- * <b>Failover: </b>
- * <p>
- * 
- * If a remote server cache throws an exception or times out, the client will
- * retry based on the configured <code>retryCount</code> parameter. If the
- * <code>retryCount</code> is exceeded, the server in question will be added
- * to a failed server list, and the client will select another server to connect
- * to. The servers in the failed server list will be periodically pinged with an
- * intelligent ping that ensures cache health. If a server is determined to be
- * healthy again, it will be promoted back to the healthy server list. The time
- * period between failed server pings is configurable via the
- * <code>retryInterval</code> parameter.
- * 
- * <p>
- * <b>Configuration: </b>
- * <p>
- * The <code>BridgeWriter</code> is configurable declaratively or
- * programmatically. Declarative configuration is achieved through defining the
- * configuration parameters in a <code>cache.xml</code> file. Programmatic
- * configuration may be achieved by first instantiating a
- * <code>BridgeWriter</code> object and subsequently calling
- * {@link #init(Properties)}with a <code>Properties</code> object containing
- * each desired parameter and value.
- * <p>
- * <b>The supported parameters are: </b>
- * <p>
- * <ul>
- * <li><b>endpoints </b> (required) <br>
- * A comma delimited list of logical names, hostnames, and ports of 'server'
- * caches to connect to <br>
- * The endpoints parameter follows this syntax:
- * logicalName=host:port,logicalName2=host2:port2,.... <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;endpoints&quot;&gt;
- *   &lt;string&gt;MyPrimaryServer=hostsrv:40404,MySecondary=hostsrv2:40404&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>readTimeout </b> (optional: default 10000) <br>
- * A millisecond value representing the amount of time to wait for a response
- * from a cache server. <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;readTimeout&quot;&gt;
- *   &lt;string&gt;5000&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * 
- * <li><b>retryAttempts </b> (optional: default 5)<br>
- * The number of times to retry a request after timeout/exception. <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;retryAttempts&quot;&gt;
- *   &lt;string&gt;5&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>retryInterval </b> (optional: default 10000) <br>
- * A millisecond value representing the amount of time to wait between attempts
- * by the <code>ServerMonitor</code> to ping living servers to verify that
- * they are still alive and dead servers to verify that they are still dead.
- * <br>
- * Example:</li>
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;retryInterval&quot;&gt;
- *   &lt;string&gt;10000&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>LBPolicy </b> (optional: default "Sticky") <br>
- * A String value representing the load balancing policy to use. See above for
- * more details. <br>
- * Options are:
- * <ul>
- * <li>"Sticky"</li>
- * <li>"RandomSticky"</li>
- * <li>"RoundRobin"</li>
- * <li>"Random"</li>
- * </ul>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;LBPolicy&quot;&gt;
- *   &lt;string&gt;Sticky&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>connectionsPerServer </b> (optional: default 1)<br>
- * The number of initial connections created to each time it is determined to be
- * alive. The minimum of <code>0</code> causes no initial connections to be
- * created (they are only created on demand). <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;connectionsPerServer&quot;&gt;
- *   &lt;string&gt;10&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>establishCallbackConnection </b> (optional: default false) <br>
- * Instruct the server to make a connection back to this edge client through
- * which the client receives cache updates. <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;establishCallbackConnection&quot;&gt;
- *   &lt;string&gt;true&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * 
- * <li><b>redundancyLevel </b> (optional: default 0) <br>
- * The number of secondary servers set for backup to the primary server for the
- * high availability of client queue. <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;redundancyLevel&quot;&gt;
- *   &lt;string&gt;1&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * 
- * <li><b>socketBufferSize </b> (optional: default 32768) <br>
- * The size of the socket buffers in bytes. <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;socketBufferSize&quot;&gt;
- *   &lt;string&gt;32768&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * 
- * <li><b>messageTrackingTimeout </b> (optional: default 300000 milliseconds)
- * <br>
- * messageTrackingTimeout property specifies the time-to-live period, in
- * milliseconds, for entries in the client's message tracking list, to minimize
- * duplicate events. Entries that have not been modified for this amount of time
- * are expired from the list <br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;messageTrackingTimeout&quot;&gt;
- *   &lt;string&gt;300000&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * <li><b>clientAckInterval</b> (optional: default 500 milliseconds) <br>
- * Bridge client sends an acknowledgement to its primary server for the events
- * it has got after every ClientAckInterval time.Client will send an ack to the
- * primary server only when redundancy level is greater than 0 or -1.<br>
- * Example:
- * 
- * <pre>
- *<code>
- * &lt;parameter name=&quot;clientAckInterval&quot;&gt;
- *   &lt;string&gt;5000&lt;/string&gt;
- * &lt;/parameter&gt;
- * </code>
- *</pre>
- * 
- * </li>
- * </ul>
- * 
- * <p>
- * 
- * If you are using a <code>cache.xml</code> file to create a
- * <code>Region</code> declaratively, you can include the following to
- * associate a <code>BridgeWriter</code> with a <code>Region</code> (default
- * values shown for optional parameters):
- * 
- * <pre>
- * 
- * &lt;cache-writer&gt;
- *   &lt;classname&gt;com.gemstone.gemfire.cache.util.BridgeWriter&lt;/classname&gt;
- *   &lt;parameter name=&quot;endpoints&quot;&gt;
- *     &lt;string&gt;MyHost=ninja.gemstone.com:40404&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;readTimeout&quot;&gt;
- *     &lt;string&gt;10000&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;retryAttempts&quot;&gt;
- *     &lt;string&gt;5&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;retryInterval&quot;&gt;
- *     &lt;string&gt;10000&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;LBPolicy&quot;&gt;
- *     &lt;string&gt;Sticky&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;establishCallbackConnection&quot;&gt;
- *     &lt;string&gt;false&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;socketBufferSize&quot;&gt;
- *     &lt;string&gt;32768&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;messageTrackingTimeout&quot;&gt;
- *     &lt;string&gt;300000&lt;/string&gt;
- *   &lt;/parameter&gt;
- *   &lt;/parameter&gt;
- *   &lt;/parameter&gt;
- *   &lt;parameter name=&quot;clientAckInterval&quot;&gt;
- *      &lt;string&gt;5000&lt;/string&gt;
- *    &lt;/parameter&gt;
- * &lt;/cache-writer&gt;
- * </pre>
- * 
- * @since 3.5
- * @author Barry Oglesby
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-
-@Deprecated
-public class BridgeWriter implements CacheWriter, Declarable
-{
-  protected ConnectionProxy proxy = null; // package access for
-                                    // tests/com/gemstone/gemfire/cache/util/BridgeHelper
-
-  private Properties properties;
-
-  private volatile boolean isClosed = false;
-
-  private final AtomicInteger refCount = new AtomicInteger();
-
-  // all writers logic was moved to ConnectionProxyImpl
-  
-  /**
-   * Initializes the writer with supplied config parameters. If instantiating
-   * the writer programmatically, this method must be called with a
-   * <code>Properties</code> object that at a minimum contains the 'endpoints'
-   * parameter before the writer can be used. If init fails with a
-   * LicenseException, the resulting BridgeWriter will throw
-   * IllegalStateException until it is properly initialized.
-   * 
-   * @param p configuration data such as 'endpoint' definitions
-   * @throws IllegalStateException if the writer is already initialized
-   */
-  public void init(Properties p)
-  {
-    if (this.proxy != null) throw new IllegalStateException(LocalizedStrings.BridgeWriter_ALREADY_INITIALIZED.toLocalizedString());
-    this.properties = p;
-    if (Boolean.getBoolean("skipConnection")) {
-      // used by hydra when generating XML via RegionAttributesCreation
-      return;
-    }
-    this.proxy = BridgePoolImpl.create(properties, true/*useByBridgeWriter*/);
-  }
-
-  /**
-   * Initializes this writer from an existing <code>BridgeWriter</code>. This
-   * method reuses the existing <code>BridgeWriter</code>'s proxy.
-   * 
-   * @param bridgeWriter
-   *          The existing <code>BridgeWriter</code>
-   * @throws IllegalStateException if the writer is already initialized
-   * 
-   * @since 4.2
-   */
-  public void init(BridgeWriter bridgeWriter)
-  {
-    if (this.proxy != null) throw new IllegalStateException(LocalizedStrings.BridgeWriter_ALREADY_INITIALIZED.toLocalizedString());
-    ConnectionProxy p = bridgeWriter.proxy;
-    p.reuse();
-    this.proxy = p;
-  }
-
-  /**
-   * Ensure that the BridgeClient and BridgePoolImpl classes
-   * get loaded.
-   * 
-   * @see SystemFailure#loadEmergencyClasses()
-   */
-  public static void loadEmergencyClasses() {
-    BridgeClient.loadEmergencyClasses(); // make sure subclass is taken care of
-    BridgePoolImpl.loadEmergencyClasses();
-  }
-
-  // emergency logic was moved to ConnectionProxyImpl
-  
-  /**
-   * Called when a region using this <code>BridgeWriter</code> is destroyed,
-   * when the cache is closed, or when a callback is removed from a region using
-   * an {@link AttributesMutator}.
-   * 
-   * Closes connections to {@link BridgeServer BridgeServers}when all
-   * {@link Region Regions}are finished using this BridgeWriter,
-   * 
-   * 
-   * @see #attach(Region)
-   * @see #detach(Region)
-   */
-  public void close()
-  {
-    if (this.refCount.get() <= 0) {
-      this.isClosed = true;
-      this.proxy.close();
-    }
-  }
-
-  // handleMarker moved to ConnectionProxyImpl
-
-  /**
-   * Returns true if this <code>BridgeWriter</code> has been closed.
-   */
-  public boolean isClosed() {
-    return this.isClosed;
-  }
-
-  private void checkClosed() {
-    String reason = this.proxy.getCancelCriterion().cancelInProgress();
-    if(reason != null) {
-      throw new BridgeWriterException("The BridgeWriter has been closed: " + reason);
-    }
-    
-    if (this.isClosed) {
-      throw new BridgeWriterException(LocalizedStrings.BridgeWriter_THE_BRIDGEWRITER_HAS_BEEN_CLOSED.toLocalizedString());
-    }
-    if (this.proxy != null && !this.proxy.isOpen()) {
-      throw new BridgeWriterException(LocalizedStrings.BridgeWriter_THE_BRIDGEWRITER_HAS_BEEN_CLOSED.toLocalizedString());
-    }
-  }
-  
-  /**
-   * Notify the BridgeWriter that the given region is no longer relevant. This
-   * method is used internally during Region
-   * {@link Region#destroyRegion() destruction}and
-   * {@link Region#close() closure}. This method effects the behavor of
-   * {@link #close()}.
-   * 
-   * @see #attach(Region)
-   * @see #close()
-   * @param r
-   *          the Region which will no longer use this BridgeWriter
-   * @since 4.3
-   */
-  public void detach(Region r)
-  {
-    this.refCount.decrementAndGet();
-    if (r != null) {
-      this.proxy.detachRegion(r);
-    }
-//    close(); // only closes if refCount is zero
-  }
-
-  /**
-   * Returns the number of attaches that have not yet called detach.
-   * @since 5.7
-   */
-  public int getAttachCount() {
-    return this.refCount.get();
-  }
-  
-  /**
-   * For speed optimizations, a connection to a server may be assigned to the
-   * calling thread when the BridgeWriter is used to do an operation.
-   * When the application thread is done doing its work it can invoke
-   * the BridgeWriter release method to make the connection available
-   * to other application threads.
-   */
-  public void release()
-  {
-    proxy.release();
-  }
-
-  /**
-   * This method should be invoked when the BridgeWriter mechanism is to be shut
-   * down explicitly , outside of closing the cache.
-   */
-  public void terminate()
-  {
-    this.isClosed = true;
-    proxy.terminate();
-  }
-
-  // removed checkForTransaction
-
-  /**
-   * Called before an entry is updated. The entry update is initiated by a
-   * <code>put</code> or a <code>get</code> that causes the writer to update
-   * an existing entry. The entry previously existed in the cache where the
-   * operation was initiated, although the old value may have been null. The
-   * entry being updated may or may not exist in the local cache where the
-   * CacheWriter is installed.
-   * 
-   * @param event
-   *          an EntryEvent that provides information about the operation in
-   *          progress
-   * @throws CacheWriterException
-   *           if thrown will abort the operation in progress, and the exception
-   *           will be propagated back to caller that initiated the operation
-   * @see Region#put(Object, Object)
-   * @see Region#get(Object)
-   */
-  public void beforeUpdate(EntryEvent event) throws CacheWriterException
-  {
-    throw new IllegalStateException("this method should not be called"); 
-  }
-
-  /**
-   * Called before an entry is created. Entry creation is initiated by a
-   * <code>create</code>, a <code>put</code>, or a <code>get</code>.
-   * The <code>CacheWriter</code> can determine whether this value comes from
-   * a <code>get</code> or not from {@link EntryEvent#isLoad}. The entry
-   * being created may already exist in the local cache where this
-   * <code>CacheWriter</code> is installed, but it does not yet exist in the
-   * cache where the operation was initiated.
-   * 
-   * @param event
-   *          an EntryEvent that provides information about the operation in
-   *          progress
-   * @throws CacheWriterException
-   *           if thrown will abort the operation in progress, and the exception
-   *           will be propagated back to caller that initiated the operation
-   * @see Region#create(Object, Object)
-   * @see Region#put(Object, Object)
-   * @see Region#get(Object)
-   */
-  public void beforeCreate(EntryEvent event) throws CacheWriterException
-  {
-    throw new IllegalStateException("this method should not be called"); 
-  }
-
-  /**
-   * Called before an entry is destroyed. The entry being destroyed may or may
-   * not exist in the local cache where the CacheWriter is installed. This
-   * method is <em>not</em> called as a result of expiration or
-   * {@link Region#localDestroy(Object)}.
-   * 
-   * @param event
-   *          an EntryEvent that provides information about the operation in
-   *          progress
-   * @throws CacheWriterException
-   *           if thrown will abort the operation in progress, and the exception
-   *           will be propagated back to caller that initiated the operation
-   * 
-   * @see Region#destroy(Object)
-   */
-  public void beforeDestroy(EntryEvent event) throws CacheWriterException
-  {
-    throw new IllegalStateException("this method should not be called"); 
-  }
-
-  /**
-   * Called before a region is destroyed. The <code>CacheWriter</code> will
-   * not additionally be called for each entry that is destroyed in the region
-   * as a result of a region destroy. If the region's subregions have
-   * <code>CacheWriter</code> s installed, then they will be called for the
-   * cascading subregion destroys. This method is <em>not</em> called as a
-   * result of expiration or {@link Region#localDestroyRegion()}. However, the
-   * {@link #close}method is invoked regardless of whether a region is
-   * destroyed locally. A non-local region destroy results in an invocation of
-   * {@link #beforeRegionDestroy}followed by an invocation of {@link #close}.
-   * <p>
-   * WARNING: This method should not destroy or create any regions itself or a
-   * deadlock will occur.
-   * 
-   * @param event
-   *          a RegionEvent that provides information about the
-   * 
-   * @throws CacheWriterException
-   *           if thrown, will abort the operation in progress, and the
-   *           exception will be propagated back to the caller that initiated
-   *           the operation
-   * 
-   * @see Region#destroyRegion()
-   */
-  public void beforeRegionDestroy(RegionEvent event)
-      throws CacheWriterException
-  {
-    throw new IllegalStateException("this method should not be called"); 
-  }
-
-  
-  /**
-   * Called before a region is cleared. The <code>CacheWriter</code> will
-   * not additionally be called for each entry that is cleared in the region
-   * as a result of a region clear. If the region's subregions have
-   * <code>CacheWriter</code> s installed, then they will be called for the
-   * cascading subregion clears. This method is <em>not</em> called as a
-   * result of expiration or {@link Region#localDestroyRegion()}. However, the
-   * {@link #close}method is invoked regardless of whether a region is
-   * cleared locally. A non-local region clear results in an invocation of
-   * {@link #beforeRegionClear}followed by an invocation of {@link #close}.
-   * <p>
-   * WARNING: This method should not destroy or create or clear any regions itself or a
-   * deadlock will occur.
-   * 
-   * @param event
-   *          a RegionEvent that provides information about the
-   * 
-   * @throws CacheWriterException
-   *           if thrown, will abort the operation in progress, and the
-   *           exception will be propagated back to the caller that initiated
-   *           the operation
-   * 
-   */
-  
-  public void beforeRegionClear(RegionEvent event) throws CacheWriterException
-  {
-    throw new IllegalStateException("this method should not be called"); 
-  }
-
-  /**
-   * Return true if this writer has not been closed and it was configured to
-   * establish a callback connection.
-   * 
-   * @since 4.3
-   */
-  public boolean hasEstablishCallbackConnection()
-  {
-    if (this.isClosed) {
-      return false;
-    }
-    else {
-      return this.proxy.getEstablishCallbackConnection();
-    }
-  }
-
-  // removed unregisterInterest
-
-  // removed getInterestList
-
-  // removed getObjectFromPrimaryServer
-
-  // removed keySet
-
-  // removed containsKey
-
-  /** Returns the retry interval in use. Retry interval refers to the interval
-   *  at which dead servers are attempted to be reconnected.
-   *  Internal use only.
-   */
-  public int getRetryInterval()
-  {
-    return proxy.getRetryInterval();
-  }
-
-  /**
-   * Returns the read timeout being used to time out requests to the server
-   * Internal use only.
-   */
-  public int getReadTimeout()
-  {
-    return proxy.getReadTimeout();
-  }
-
-  /**
-   * Returns the number of times the bridge writer tries to write data on
-   * encountering certain types of exceptions. Internal use only
-   */
-  public int getRetryAttempts()
-  {
-    return this.proxy.getRetryAttempts();
-  }
-
-  /**
-   * Returns the load balancing policy being used by the bridge writer Internal
-   * use only
-   */
-  public String getLBPolicy()
-  {
-    return proxy.getLBPolicy();
-  }
-
-  /**
-   * Returns the properties that defined this <code>BridgeWriter</code>.
-   * 
-   * @return the properties that defined this <code>BridgeWriter</code>
-   * 
-   * @since 4.2
-   */
-  public Properties getProperties()
-  {
-    return this.properties;
-  }
-
-  
-  /**
-   * Add an <code>Endpoint</code> to the known <code>Endpoint</code>s.
-   * 
-   * @param name The name of the endpoint to add
-   * @param host The host name or ip address of the endpoint to add
-   * @param port The port of the endpoint to add
-   * 
-   * @throws EndpointExistsException if the <code>Endpoint</code> to be
-   * added already exists.
-   * 
-   * @since 5.0.2
-   */
-  public void addEndpoint(String name, String host, int port)
-  throws EndpointExistsException {
-    this.proxy.addEndpoint(name, host, port);
-  }
-
-  /**
-   * Remove an <code>Endpoint</code> from the dead <code>Endpoint</code>s.
-   * The specified <code>Endpoint</code> must be dead.
-   * 
-   * @param name The name of the endpoint to remove
-   * @param host The host name or ip address of the endpoint to remove
-   * @param port The port of the endpoint to remove
-   * 
-   * @throws EndpointDoesNotExistException if the <code>Endpoint</code> to be
-   * removed doesn't exist.
-   * 
-   * @throws EndpointInUseException if the <code>Endpoint</code> to be removed
-   * contains <code>Connection</code>s
-   * 
-   * @since 5.0.2
-   */
-  public void removeEndpoint(String name, String host, int port)
-  throws EndpointDoesNotExistException, EndpointInUseException {
-    this.proxy.removeEndpoint(name, host, port);
-  }
-
-  // removed handleException
-
-  // removed getExceptionMessage
-
-  /**
-   * Returns a brief description of this <code>BridgeWriter</code>
-   * 
-   * @since 4.0
-   */
-  @Override
-  public String toString()
-  {
-    return LocalizedStrings.BridgeWriter_BRIDGEWRITER_CONNECTED_TO_0.toLocalizedString(this.proxy);
-  }
-
-  /**
-   * Notify the BridgeWriter that the given Region will begin delivering events
-   * to this BridgeWriter. This method effects the behavior of {@link #close()}
-   * 
-   * This is called internally when the BridgeWriter is added to a Region via
-   * {@link AttributesFactory#setCacheWriter(CacheWriter)}}
-   * 
-   * @param r
-   *          the Region which will begin use this BridgeWriter.
-   * @since 4.3
-   * 
-   * @see #detach(Region)
-   * @see #close()
-   */
-  public void attach(Region r)
-  {
-    checkClosed();
-    this.refCount.incrementAndGet();
-  }
-
-  /**
-   * Returns the <code>ConnectionProxy</code> associated with this
-   * <code>BridgeWriter</code>.
-   * 
-   * For internal use only.
-   * 
-   * @return the <code>ConnectionProxy</code> associated with this
-   *         <code>BridgeWriter</code>
-   */
-  public Object/*ConnectionProxy*/ getConnectionProxy() {
-    return proxy;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriterException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriterException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriterException.java
deleted file mode 100755
index e481c65..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/BridgeWriterException.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-import com.gemstone.gemfire.cache.CacheWriterException;
-
-/**
- * An exception that is thrown by a {@link BridgeWriter} when a
- * problem occurs when communicating with a bridge server.
- *
- * @author David Whitlock
- * @since 3.5.2
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-@Deprecated
-public class BridgeWriterException extends CacheWriterException {
-private static final long serialVersionUID = -295001316745954159L;
-
-  /**
-   * Creates a new <code>BridgeWriterException</code> with the given
-   * message. 
-   */
-  public BridgeWriterException(String message) {
-    super(message);
-  }
-
-  /**
-   * Creates a new <code>BridgeWriterException</code> with the given
-   * message and cause.
-   */
-  public BridgeWriterException(String message, Throwable cause) {
-    super(message, cause);
-  }
-
-  /**
-   * Creates a new <code>BridgeWriterException</code> with the given
-   * cause.
-   */
-  public BridgeWriterException(Throwable cause) {
-    super(cause);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointDoesNotExistException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointDoesNotExistException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointDoesNotExistException.java
deleted file mode 100755
index 4f5eabd..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointDoesNotExistException.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-/**
- * An <code>EndpointDoesNotExistException</code> indicates a client
- * <code>Endpoint</code> does not exist for the input name, host and
- * port.
- *
- * @author Barry Oglesby
- *
- * @since 5.0.2
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-@Deprecated
-public class EndpointDoesNotExistException extends EndpointException {
-private static final long serialVersionUID = 1654241470788247283L;
-
-  /**
-   * Constructs a new <code>EndpointDoesNotExistException</code>.
-   * 
-   * @param name The name of the requested <code>Endpoint</code>
-   * @param host The host of the requested <code>Endpoint</code>
-   * @param port The port of the requested <code>Endpoint</code>
-   */
-  public EndpointDoesNotExistException(String name, String host, int port) {
-    super(name+"->"+host+":"+port);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointException.java
deleted file mode 100755
index 445a75f..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointException.java
+++ /dev/null
@@ -1,61 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-/**
- * An <code>EndpointException</code> is a generic exception that indicates
- * a client <code>Endpoint</code> exception has occurred. All other
- * <code>Endpoint</code> exceptions are subclasses of this class. Since
- * this class is abstract, only subclasses are instantiated.
- *
- * @author Barry Oglesby
- *
- * @since 5.0.2
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-@Deprecated
-public abstract class EndpointException extends Exception {
-  
-  /** Constructs a new <code>EndpointException</code>. */
-  public EndpointException() {
-    super();
-  }
-
-  /** Constructs a new <code>EndpointException</code> with a message string. */
-  public EndpointException(String s) {
-    super(s);
-  }
-
-  /** Constructs a <code>EndpointException</code> with a message string and
-   * a base exception
-   */
-  public EndpointException(String s, Throwable cause) {
-    super(s, cause);
-  }
-
-  /** Constructs a <code>EndpointException</code> with a cause */
-  public EndpointException(Throwable cause) {
-    super(cause);
-  }
-
-  @Override
-  public String toString() {
-    String result = super.toString();
-    Throwable cause = getCause();
-    if (cause != null) {
-      String causeStr = cause.toString();
-      final String glue = ", caused by ";
-      StringBuffer sb = new StringBuffer(result.length() + causeStr.length() + glue.length());
-      sb.append(result)
-        .append(glue)
-        .append(causeStr);
-      result = sb.toString();
-    }
-    return result;
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointExistsException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointExistsException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointExistsException.java
deleted file mode 100755
index 3db6453..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointExistsException.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-
-/**
- * An <code>EndpointExistsException</code> indicates a client
- * <code>Endpoint</code> already exists.
- *
- * @author Barry Oglesby
- *
- * @since 5.0.2
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-@Deprecated
-public class EndpointExistsException extends EndpointException {
-private static final long serialVersionUID = 950617116786308012L;
-
-  public EndpointExistsException(String msg) {
-    super(msg);
-  }
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointInUseException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointInUseException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointInUseException.java
deleted file mode 100755
index 5c9093e..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/EndpointInUseException.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-
-/**
- * An <code>EndpointInUseException</code> indicates a client <code>Endpoint</code>
- * is in use (meaning that it contains one or more <code>Connection</code>s.
- *
- * @author Barry Oglesby
- *
- * @since 5.0.2
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client pools} instead.
- */
-@Deprecated
-public class EndpointInUseException extends EndpointException {
-private static final long serialVersionUID = -4087729485272321469L;
-
-  public EndpointInUseException(String msg) {
-    super(msg);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/IncompatibleVersionException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/IncompatibleVersionException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/IncompatibleVersionException.java
deleted file mode 100755
index fa72cd9..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/IncompatibleVersionException.java
+++ /dev/null
@@ -1,47 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-import com.gemstone.gemfire.internal.Version;
-
-/**
- * An <code>Incompatible</code> indicates an unknown version.
- *
- * @author Barry Oglesby
- * @deprecated
- *
- * @since 5.6
- */
-public class IncompatibleVersionException extends VersionException {
-
-  private static final long serialVersionUID = 7008667865037538081L;
-
-  /**
-   * Constructs a new <code>IncompatibleVersionException</code>.
-   *
-   * @param clientVersion The client version
-   * @param serverVersion The server version
-   */
-  public IncompatibleVersionException(Object clientVersion,
-      Object serverVersion) {
-    // the arguments should be of class Version, but that's an
-    // internal class and this is an external class that shouldn't
-    // ref internals in method signatures
-    this("Client version " + clientVersion
-        + " is incompatible with server version " + serverVersion);
-  }
-
-  /**
-   * Constructs a new <code>IncompatibleVersionException</code>.
-   *
-   * @param message The exception message
-   */
-  public IncompatibleVersionException(String message) {
-    super(message);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/ServerRefusedConnectionException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/ServerRefusedConnectionException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/ServerRefusedConnectionException.java
deleted file mode 100755
index 2545e00..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/ServerRefusedConnectionException.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-import com.gemstone.gemfire.distributed.DistributedMember;
-
-import edu.umd.cs.findbugs.annotations.SuppressFBWarnings;
-
-/**
- * A <code>ServerRefusedConnectionException</code> indicates a client attempted
- * to connect to a server, but the handshake was rejected.
- *
- * @author Barry Oglesby
- *
- * @since 5.5
- * @deprecated as of 5.7 use {@link com.gemstone.gemfire.cache.client.ServerRefusedConnectionException} from the <code>client</code> package instead.
- */
-@Deprecated
-@SuppressFBWarnings(value="NM_SAME_SIMPLE_NAME_AS_SUPERCLASS", justification="class deprecated")
-public class ServerRefusedConnectionException extends com.gemstone.gemfire.cache.client.ServerRefusedConnectionException {
-private static final long serialVersionUID = -4996327025772566931L;
-  /**
-   * Constructs an instance of <code>ServerRefusedConnectionException</code> with the
-   * specified detail message.
-   * @param server the server that rejected the connection
-   * @param msg the detail message
-   */
-  public ServerRefusedConnectionException(DistributedMember server, String msg) {
-    super(server, msg);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UniversalMembershipListenerAdapter.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UniversalMembershipListenerAdapter.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UniversalMembershipListenerAdapter.java
deleted file mode 100755
index 840ae09..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UniversalMembershipListenerAdapter.java
+++ /dev/null
@@ -1,352 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-
-package com.gemstone.gemfire.cache.util;
-
-import com.gemstone.gemfire.admin.AdminDistributedSystem;
-import com.gemstone.gemfire.admin.SystemMembershipEvent;
-import com.gemstone.gemfire.admin.SystemMembershipListener;
-import com.gemstone.gemfire.distributed.DistributedMember;
-import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
-
-import java.util.*;
-
-/**
- * <p>The <code>UniversalMembershipListenerAdapter</code> is a wrapper 
- * for {@link com.gemstone.gemfire.admin.SystemMembershipListener} and 
- * {@link BridgeMembershipListener}, providing a facade that makes both
- * appear to customer code as a single <code>SystemMembershipListener</code>
- * from the Admin API. This includes adapting 
- * <code>BridgeMembershipListener</code> events to appear as events for the 
- * <code>SystemMembershipListener</code>.</p>
- *
- * <p><code>UniversalMembershipListenerAdapter</code> implements
- * <code>SystemMembershipListener</code>, exposing the callbacks in that
- * interface as methods to be overridden by the customer.</p>
- *
- * <p>An internal implementation of <code>BridgeMembershipListener</code> is 
- * registered when this class is instantiated. This implementation creates a
- * {@link com.gemstone.gemfire.admin.SystemMembershipEvent} and calls the
- * corresponding <code>SystemMembershipListener</code> public methods on 
- * <code>UniversalMembershipListenerAdapter</code>. To the customer code, the
- * <code>BridgeMembershipEvent</code>s are wrapped to appear as 
- * <code>SystemMembershipEvent</code>s. In this way, both types of membership
- * events appear as <code>SystemMembershipEvent</code>s, allowing customer
- * code written using the Admin API to continue working by changing the
- * listener implementation to simply extend this class.</p>
- *
- * <p>Any BridgeServer using the <code>UniversalMembershipListenerAdapter</code>
- * will receive notifications of system membership changes and bridge
- * membership changes through a single listener.</p>
- *
- * <p>Any bridge client using the <code>UniversalMembershipListenerAdapter</code>
- * would receive notifications of bridge server connection changes. If that
- * bridge client also creates a connection to the GemFire {@link 
- * com.gemstone.gemfire.distributed.DistributedSystem}, then it will also
- * receive notifications of system membership changes.</p>
- *
- * <p>Subclasses of <code>UniversalMembershipListenerAdapter</code> may be
- * registered as a <code>SystemMembershipListener</code> using {@link 
- * com.gemstone.gemfire.admin.AdminDistributedSystem#addMembershipListener}.
- * It is best, however, to register the listener using {@link
- * #registerMembershipListener} since this allows the adapter to prevent
- * duplicate events for members that are both a system member and a bridge
- * member.</p>
- *
- * <p>Simply constructing the <code>UniversalMembershipListenerAdapter</code>
- * results in the underlying <code>BridgeMembershipListener</code> also being
- * registered.</p>
- *
- * <p>The following code illustrates how a BridgeServer application would use
- * <code>UniversalMembershipListenerAdapter</code>. The code in this example
- * assumes that the class MyMembershipListenerImpl extends 
- * <code>UniversalMembershipListenerAdapter</code>:
- * <pre><code>
- * public class MyMembershipListenerImpl extends UniversalMembershipListenerAdapter {
- *   public void memberCrashed(SystemMembershipEvent event) {
- *     // customer code
- *   }
- *   public void memberLeft(SystemMembershipEvent event) {
- *     // customer code
- *   }
- *   public void memberJoined(SystemMembershipEvent event) {
- *     // customer code
- *   }
- * }
- *
- * DistributedSystemConfig config = 
- *   AdminDistributedSystemFactory.defineDistributedSystem(myDS, null);
- * AdminDistributedSystem adminDS = 
- *   AdminDistributedSystemFactory.getDistributedSystem(config);
- * adminDS.connect();
- * MyMembershipListenerImpl myListener = new MyMembershipListenerImpl();
- * myListener.registerMembershipListener(adminDS);
- * </code></pre>
- * The callbacks on MyMembershipListenerImpl would then be
- * invoked for all <code>SystemMembershipEvent</code>s and 
- * <code>BridgeMembershipEvent</code>s. The latter will appear to be 
- * <code>SystemMembershipEvent</code>s.</p>
- *
- * <p>Similarly, the following code illustrates how a bridge client application
- * would use <code>UniversalMembershipListenerAdapter</code>, where 
- * MyMembershipListenerImpl is a subclass. Simply by constructing this subclass
- * of <code>UniversalMembershipListenerAdapter</code> it is registering itself
- * as a <code>BridgeMembershipListener</code>:
- * <pre><code>
- * new MyMembershipListenerImpl();
- * </code></pre>
- * A bridge client that also connects to the <code>DistributedSystem</code>
- * could register with the<code>AdminDistributedSystem</code> as shown 
- * above.</p>
- *
- * <p>It is recommended that subclasses register with the 
- * <code>AdminDistributedSystem</code> using {@link 
- * #registerMembershipListener}, as this will prevent duplicate events for
- * members that are both bridge members and system members. If duplicate
- * events are acceptable, you may register subclasses using {@link 
- * com.gemstone.gemfire.admin.AdminDistributedSystem#addMembershipListener 
- * AdminDistributedSystem#addMembershipListener}.</p>
- *
- * @author Kirk Lund
- * @since 4.2.1
- * @deprecated Use com.gemstone.gemfire.management.membership.UniversalMembershipListenerAdapter instead.
- */
-public abstract class UniversalMembershipListenerAdapter 
-implements SystemMembershipListener {
-  
-  /** 
-   * Default number of historical events to track in order to avoid duplicate
-   * events for members that are both bridge members and system members;
-   * value is 100.
-   */
-  public static final int DEFAULT_HISTORY_SIZE = 100;
-  
-//  private final Object[] eventHistory;
-//  private final boolean[] eventJoined;
-//  private boolean registered = false;
-  
-  protected final int historySize;
-  protected final LinkedList<String> eventHistory; // list of String memberIds
-  protected final Map<String,Boolean> eventJoined; // key: memberId, value: Boolean
-  
-  // TODO: perhaps ctor should require AdminDistributedSystem as arg?
-  
-  /** Constructs an instance of UniversalMembershipListenerAdapter. */
-  public UniversalMembershipListenerAdapter() {
-    this(DEFAULT_HISTORY_SIZE);
-  }
-  
-  /** 
-   * Constructs an instance of UniversalMembershipListenerAdapter.
-   * @param historySize number of historical events to track in order to avoid
-   * duplicate events for members that are both bridge members and system
-   * members; must a number between 10 and <code>Integer.MAX_INT</code>
-   * @throws IllegalArgumentException if historySizde is less than 10
-   */
-  public UniversalMembershipListenerAdapter(int historySize) {
-    if (historySize < 10) {
-      throw new IllegalArgumentException(LocalizedStrings.UniversalMembershipListenerAdapter_ARGUMENT_HISTORYSIZE_MUST_BE_BETWEEN_10_AND_INTEGERMAX_INT_0.toLocalizedString(Integer.valueOf(historySize)));
-    }
-    this.historySize = historySize;
-    this.eventHistory = new LinkedList<String>();
-    this.eventJoined = new HashMap<String,Boolean>();
-    BridgeMembership.registerBridgeMembershipListener(this.bridgeMembershipListener);
-  }
-  
-  /**
-   * Registers this adapter with the <code>AdminDistributedSystem</code>. 
-   * Registering in this way allows the adapter to ensure that callbacks will
-   * not be invoked twice for members that have a bridge connection and a
-   * system connection. If you register with {@link
-   * com.gemstone.gemfire.admin.AdminDistributedSystem#addMembershipListener}
-   * then duplicate events may occur for members that are both bridge members
-   * and system.
-   */
-  public void registerMembershipListener(AdminDistributedSystem admin) {
-    synchronized (this.eventHistory) {
-//      this.registered = true;
-      admin.addMembershipListener(this.systemMembershipListener);
-    }
-  }
-
-  /**
-   * Unregisters this adapter with the <code>AdminDistributedSystem</code>. 
-   * If registration is performed with {@link #registerMembershipListener}
-   * then this method must be used to successfuly unregister the adapter.
-   */
-  public void unregisterMembershipListener(AdminDistributedSystem admin) {
-    synchronized (this.eventHistory) {
-//      this.registered = false;
-      admin.removeMembershipListener(this.systemMembershipListener);
-    }
-    unregisterBridgeMembershipListener();
-  }
-  
-  /**
-   * Registers this adapter as a <code>BridgeMembershipListener</code>.
-   * Registration is automatic when constructing this adapter, so this call
-   * is no necessary unless it was previously unregistered by calling
-   * {@link #unregisterBridgeMembershipListener}.
-   */
-  public void registerBridgeMembershipListener() {
-    BridgeMembership.registerBridgeMembershipListener(this.bridgeMembershipListener);
-  }
-  
-  /**
-   * Unregisters this adapter as a <code>BridgeMembershipListener</code>.
-   * @see #registerBridgeMembershipListener
-   */
-  public void unregisterBridgeMembershipListener() {
-    BridgeMembership.unregisterBridgeMembershipListener(this.bridgeMembershipListener);
-  }
-  
-  /**
-   * Invoked when a member has joined the distributed system. Also invoked when
-   * a client has connected to this process or when this process has connected
-   * to a <code>BridgeServer</code>.
-   */
-  public void memberJoined(SystemMembershipEvent event) {}
-
-  /**
-   * Invoked when a member has gracefully left the distributed system. Also
-   * invoked when a client has gracefully disconnected from this process.
-   * or when this process has gracefully disconnected from a 
-   * <code>BridgeServer</code>.   */
-  public void memberLeft(SystemMembershipEvent event) {}
-
-  /**
-   * Invoked when a member has unexpectedly left the distributed system. Also
-   * invoked when a client has unexpectedly disconnected from this process
-   * or when this process has unexpectedly disconnected from a 
-   * <code>BridgeServer</code>.
-   */
-  public void memberCrashed(SystemMembershipEvent event) {}
-  
-  /** Adapts BridgeMembershipEvent to look like a SystemMembershipEvent */
-  public static class AdaptedMembershipEvent implements SystemMembershipEvent {
-    private final BridgeMembershipEvent event;
-
-    protected AdaptedMembershipEvent(BridgeMembershipEvent event) {
-      this.event = event;
-    }
-    /**
-     * Returns true if the member is a bridge client to a BridgeServer hosted
-     * by this process. Returns false if the member is a BridgeServer that this
-     * process is connected to.
-     */
-    public boolean isClient() {
-      return event.isClient();
-    }
-
-    public String getMemberId() {
-      return event.getMemberId();
-    }
-    
-    public DistributedMember getDistributedMember() {
-      return event.getMember();
-    }
-    
-    @Override
-    public boolean equals(Object other) {
-      if (other == this) return true;
-      if (other == null) return false;
-      if (!(other instanceof AdaptedMembershipEvent)) return  false;
-      final AdaptedMembershipEvent that = (AdaptedMembershipEvent) other;
-  
-      if (this.event != that.event &&
-          !(this.event != null &&
-          this.event.equals(that.event))) return false;
-  
-      return true;
-    }
-
-    @Override
-    public int hashCode() {
-      return this.event.hashCode();
-    }
-
-    @Override
-    public String toString() {
-      final StringBuffer sb = new StringBuffer("[AdaptedMembershipEvent: ");
-      sb.append(this.event);
-      sb.append("]");
-      return sb.toString();
-    }
-  }
-
-  private final BridgeMembershipListener bridgeMembershipListener =
-  new BridgeMembershipListener() {
-    public void memberJoined(BridgeMembershipEvent event) {
-      systemMembershipListener.memberJoined(new AdaptedMembershipEvent(event));
-    }
-    public void memberLeft(BridgeMembershipEvent event) {
-      systemMembershipListener.memberLeft(new AdaptedMembershipEvent(event));
-    }
-    public void memberCrashed(BridgeMembershipEvent event) {
-      systemMembershipListener.memberCrashed(new AdaptedMembershipEvent(event));
-    }
-  };
-  
-  protected final SystemMembershipListener systemMembershipListener =
-  new SystemMembershipListener() {
-    public void memberJoined(SystemMembershipEvent event) {
-      if (!isDuplicate(event, true)) {
-        UniversalMembershipListenerAdapter.this.memberJoined(event);
-      }
-    }
-    public void memberLeft(SystemMembershipEvent event) {
-      if (!isDuplicate(event, false)) {
-        UniversalMembershipListenerAdapter.this.memberLeft(event);
-      }
-    }
-    public void memberCrashed(SystemMembershipEvent event) {
-      if (!isDuplicate(event, false)) {
-        UniversalMembershipListenerAdapter.this.memberCrashed(event);
-      }
-    }
-    protected boolean isDuplicate(SystemMembershipEvent event, boolean joined) {
-      synchronized (eventHistory) {
-        boolean duplicate = false;
-        String memberId = event.getMemberId();
-        
-        // find memberId in eventHistory...
-        int indexOf = eventHistory.indexOf(memberId);
-        if (indexOf > -1) {
-          // found an event for this member
-          if ((eventJoined.get(memberId)).booleanValue() == joined) {
-            // we already recorded a matching event for this member
-            duplicate = true;
-          }
-          else {
-            // remove the event from history and map... will be re-inserted
-            Assert.assertTrue(eventHistory.remove(memberId),
-              "Failed to replace entry in eventHistory for " + memberId);
-            Assert.assertTrue(eventJoined.remove(memberId) != null,
-              "Failed to replace entry in eventJoined for " + memberId);
-          }
-        }
-        
-        if (!duplicate) {
-          // add the event to the history and map
-          if (eventHistory.size() == historySize) {
-            // filled the eventHistory, so need to remove first entry
-            eventHistory.removeFirst();
-          }
-          eventHistory.addLast(memberId); // linked list
-          eventJoined.put(memberId, Boolean.valueOf(joined)); // boolean map
-          Assert.assertTrue(eventHistory.size() <= historySize,
-            "Attempted to grow eventHistory beyond maximum of " + historySize);
-        }
-        return duplicate;
-      } // sync
-    }
-  };
-  
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UnknownVersionException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UnknownVersionException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UnknownVersionException.java
deleted file mode 100755
index 00743db..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/UnknownVersionException.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-/**
- * An <code>UnknownVersionException</code> indicates an unknown version.
- *
- * @author Barry Oglesby
- * @deprecated
- *
- * @since 5.6
- */
-public class UnknownVersionException extends VersionException {
-
-  private static final long serialVersionUID = 7379530185697556990L;
-
-  /**
-   * Constructs a new <code>UnknownVersionException</code>.
-   * 
-   * @param versionOrdinal The ordinal of the requested <code>Version</code>
-   */
-  public UnknownVersionException(byte versionOrdinal) {
-    super(String.valueOf(versionOrdinal));
-  }
-  
-  /**
-   * Constructs a new <code>UnknownVersionException</code>.
-   * 
-   * @param message The exception message
-   */
-  public UnknownVersionException(String message) {
-    super(message);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/VersionException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/VersionException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/VersionException.java
deleted file mode 100755
index 200fac6..0000000
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/VersionException.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *========================================================================
- */
-package com.gemstone.gemfire.cache.util;
-
-import com.gemstone.gemfire.GemFireCheckedException;
-
-/**
- * An <code>VersionException</code> is an exception that indicates
- * a client / server version mismatch exception has occurred.
- *
- * @author Barry Oglesby
- * @deprecated Use {@link com.gemstone.gemfire.cache.VersionException} instead.
- *
- * @since 5.6
- */
-@Deprecated
-public abstract class VersionException extends GemFireCheckedException {
-
-  /** Constructs a new <code>VersionException</code>. */
-  public VersionException() {
-    super();
-  }
-
-  /** Constructs a new <code>VersionException</code> with a message string. */
-  public VersionException(String s) {
-    super(s);
-  }
-
-  /** Constructs a <code>VersionException</code> with a message string and
-   * a base exception
-   */
-  public VersionException(String s, Throwable cause) {
-    super(s, cause);
-  }
-
-  /** Constructs a <code>VersionException</code> with a cause */
-  public VersionException(Throwable cause) {
-    super(cause);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/package.html
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/package.html b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/package.html
index 296eba2..0bd948f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/package.html
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/util/package.html
@@ -12,8 +12,5 @@ Adapter classes are provided for convenience in implementing the
 CacheListener, RegionMembershipListener, RegionRoleListener, TransactionListener, and CacheWriter interfaces. These adapter
 classes simply implement the interfaces with empty methods so that subclasses
 only need implement the methods that are of interest.
-<p>
-Also provided are 
-BridgeLoader/BridgeWriter/BridgeServer, which are used for Hierarchical Caching.
   </BODY>
 </HTML>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/ServerLauncher.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/ServerLauncher.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/ServerLauncher.java
index a7cefbd..68efa34 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/ServerLauncher.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/ServerLauncher.java
@@ -40,7 +40,7 @@ import com.gemstone.gemfire.distributed.internal.DistributionConfig;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.internal.GemFireVersion;
 import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.AbstractBridgeServer;
+import com.gemstone.gemfire.internal.cache.AbstractCacheServer;
 import com.gemstone.gemfire.internal.cache.CacheConfig;
 import com.gemstone.gemfire.internal.cache.CacheServerLauncher;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
@@ -205,7 +205,7 @@ public final class ServerLauncher extends AbstractLauncher<String> {
   }
 
   private static Integer getDefaultServerPort() {
-    return Integer.getInteger(AbstractBridgeServer.TEST_OVERRIDE_DEFAULT_PORT_PROPERTY, CacheServer.DEFAULT_PORT);
+    return Integer.getInteger(AbstractCacheServer.TEST_OVERRIDE_DEFAULT_PORT_PROPERTY, CacheServer.DEFAULT_PORT);
   }
 
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
index e30b20b..76c2b92 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/InternalDistributedSystem.java
@@ -74,14 +74,14 @@ import com.gemstone.gemfire.internal.StatisticsManager;
 import com.gemstone.gemfire.internal.StatisticsTypeFactoryImpl;
 import com.gemstone.gemfire.internal.SystemTimer;
 import com.gemstone.gemfire.internal.admin.remote.DistributionLocatorId;
-import com.gemstone.gemfire.internal.cache.BridgeServerImpl;
+import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.CacheConfig;
 import com.gemstone.gemfire.internal.cache.EventID;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import com.gemstone.gemfire.internal.cache.execute.FunctionServiceStats;
 import com.gemstone.gemfire.internal.cache.execute.FunctionStats;
 import com.gemstone.gemfire.internal.cache.tier.sockets.HandShake;
-import com.gemstone.gemfire.internal.cache.xmlcache.BridgeServerCreation;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheServerCreation;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.logging.InternalLogWriter;
 import com.gemstone.gemfire.internal.logging.LogService;
@@ -2569,7 +2569,7 @@ public final class InternalDistributedSystem
     // the membership manager when forced-disconnect starts.  If we're
     // reconnecting for lost roles then this will be null
     String cacheXML = null;
-    List<BridgeServerCreation> cacheServerCreation = null;
+    List<CacheServerCreation> cacheServerCreation = null;
     
     GemFireCacheImpl cache = GemFireCacheImpl.getInstance();
     boolean inhibitCacheForSQLFire = false;
@@ -2835,8 +2835,8 @@ public final class InternalDistributedSystem
             }
             cache = GemFireCacheImpl.create(this.reconnectDS, config);
             if (cacheServerCreation != null) {
-              for (BridgeServerCreation bridge: cacheServerCreation) {
-                BridgeServerImpl impl = (BridgeServerImpl)cache.addCacheServer();
+              for (CacheServerCreation bridge: cacheServerCreation) {
+                CacheServerImpl impl = (CacheServerImpl)cache.addCacheServer();
                 impl.configureFrom(bridge);
                 try {
                   if (!impl.isRunning()) {
@@ -2844,7 +2844,7 @@ public final class InternalDistributedSystem
                   }
                 } catch (IOException ex) {
                   throw new GemFireIOException(
-                      LocalizedStrings.CacheCreation_WHILE_STARTING_BRIDGE_SERVER_0
+                      LocalizedStrings.CacheCreation_WHILE_STARTING_CACHE_SERVER_0
                           .toLocalizedString(impl), ex);
                 }
               }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/ServerLocator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/ServerLocator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/ServerLocator.java
index 33991bf..07cab82 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/ServerLocator.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/ServerLocator.java
@@ -46,7 +46,7 @@ import com.gemstone.gemfire.distributed.internal.tcpserver.TcpHandler;
 import com.gemstone.gemfire.distributed.internal.tcpserver.TcpServer;
 import com.gemstone.gemfire.i18n.LogWriterI18n;
 import com.gemstone.gemfire.internal.SocketCreator;
-import com.gemstone.gemfire.internal.cache.BridgeServerAdvisor.BridgeServerProfile;
+import com.gemstone.gemfire.internal.cache.CacheServerAdvisor.CacheServerProfile;
 import com.gemstone.gemfire.internal.cache.ControllerAdvisor;
 import com.gemstone.gemfire.internal.cache.ControllerAdvisor.ControllerProfile;
 import com.gemstone.gemfire.internal.cache.FindDurableQueueProcessor;
@@ -375,8 +375,8 @@ public class ServerLocator implements TcpHandler, DistributionAdvisee {
    * @param profile
    */
   public void profileCreated(Profile profile) {
-    if(profile instanceof BridgeServerProfile) {
-      BridgeServerProfile bp = (BridgeServerProfile) profile;
+    if(profile instanceof CacheServerProfile) {
+      CacheServerProfile bp = (CacheServerProfile) profile;
       ServerLocation location = buildServerLocation(bp);
       String[] groups = bp.getGroups();
       loadSnapshot.addServer(location, groups,
@@ -398,8 +398,8 @@ public class ServerLocator implements TcpHandler, DistributionAdvisee {
    * @param profile
    */
   public void profileRemoved(Profile profile) {
-    if(profile instanceof BridgeServerProfile) {
-      BridgeServerProfile bp = (BridgeServerProfile) profile;
+    if(profile instanceof CacheServerProfile) {
+      CacheServerProfile bp = (CacheServerProfile) profile;
       //InternalDistributedMember id = bp.getDistributedMember();
       ServerLocation location = buildServerLocation(bp);
       loadSnapshot.removeServer(location);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/jgroup/JGroupMembershipManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/jgroup/JGroupMembershipManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/jgroup/JGroupMembershipManager.java
index c589feb..c18d250 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/jgroup/JGroupMembershipManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/distributed/internal/membership/jgroup/JGroupMembershipManager.java
@@ -79,7 +79,7 @@ import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.admin.remote.RemoteTransportConfig;
 import com.gemstone.gemfire.internal.cache.DirectReplyMessage;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
-import com.gemstone.gemfire.internal.cache.xmlcache.BridgeServerCreation;
+import com.gemstone.gemfire.internal.cache.xmlcache.CacheServerCreation;
 import com.gemstone.gemfire.internal.cache.xmlcache.CacheXmlGenerator;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 import com.gemstone.gemfire.internal.logging.LogService;
@@ -2716,10 +2716,10 @@ public class JGroupMembershipManager implements MembershipManager
         }
       } else if (sharedConfigEnabled && !cache.getCacheServers().isEmpty()) {
         // we need to retain a cache-server description if this JVM was started by gfsh
-        List<BridgeServerCreation> list = new ArrayList<BridgeServerCreation>(cache.getCacheServers().size());
+        List<CacheServerCreation> list = new ArrayList<CacheServerCreation>(cache.getCacheServers().size());
         for (Iterator it = cache.getCacheServers().iterator(); it.hasNext(); ) {
           CacheServer cs = (CacheServer)it.next();
-          BridgeServerCreation bsc = new BridgeServerCreation(cache, cs);
+          CacheServerCreation bsc = new CacheServerCreation(cache, cs);
           list.add(bsc);
         }
         cache.getCacheConfig().setCacheServerCreation(list);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
index 3c33553..d556ce2 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DSFIDFactory.java
@@ -30,7 +30,7 @@ import com.gemstone.gemfire.admin.internal.PrepareBackupResponse;
 import com.gemstone.gemfire.admin.internal.SystemMemberCacheEventProcessor;
 import com.gemstone.gemfire.admin.jmx.internal.StatAlertNotification;
 import com.gemstone.gemfire.cache.InterestResultPolicy;
-import com.gemstone.gemfire.cache.client.internal.BridgeServerLoadMessage;
+import com.gemstone.gemfire.cache.client.internal.CacheServerLoadMessage;
 import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionRequest;
 import com.gemstone.gemfire.cache.client.internal.locator.ClientConnectionResponse;
 import com.gemstone.gemfire.cache.client.internal.locator.ClientReplacementRequest;
@@ -180,8 +180,8 @@ import com.gemstone.gemfire.internal.admin.remote.VersionInfoResponse;
 import com.gemstone.gemfire.internal.admin.statalerts.GaugeThresholdDecoratorImpl;
 import com.gemstone.gemfire.internal.admin.statalerts.NumberThresholdDecoratorImpl;
 import com.gemstone.gemfire.internal.cache.AddCacheServerProfileMessage;
-import com.gemstone.gemfire.internal.cache.BridgeRegionEventImpl;
-import com.gemstone.gemfire.internal.cache.BridgeServerAdvisor.BridgeServerProfile;
+import com.gemstone.gemfire.internal.cache.ClientRegionEventImpl;
+import com.gemstone.gemfire.internal.cache.CacheServerAdvisor.CacheServerProfile;
 import com.gemstone.gemfire.internal.cache.BucketAdvisor;
 import com.gemstone.gemfire.internal.cache.CacheDistributionAdvisor;
 import com.gemstone.gemfire.internal.cache.CloseCacheMessage;
@@ -820,7 +820,7 @@ public final class DSFIDFactory implements DataSerializableFixedID {
     registerDSFID(GATEWAY_SENDER_PROFILE,
         GatewaySenderAdvisor.GatewaySenderProfile.class);
     registerDSFID(ROLE_EVENT, RoleEventImpl.class);
-    registerDSFID(BRIDGE_REGION_EVENT, BridgeRegionEventImpl.class);
+    registerDSFID(CLIENT_REGION_EVENT, ClientRegionEventImpl.class);
     registerDSFID(PR_INVALIDATE_MESSAGE, InvalidateMessage.class);
     registerDSFID(PR_INVALIDATE_REPLY_MESSAGE,
         InvalidateMessage.InvalidateReplyMessage.class);
@@ -860,8 +860,8 @@ public final class DSFIDFactory implements DataSerializableFixedID {
     registerDSFID(ALERTS_NOTIF_MESSAGE, AlertsNotificationMessage.class);
     registerDSFID(FIND_DURABLE_QUEUE, FindDurableQueueMessage.class);
     registerDSFID(FIND_DURABLE_QUEUE_REPLY, FindDurableQueueReply.class);
-    registerDSFID(BRIDGE_SERVER_LOAD_MESSAGE, BridgeServerLoadMessage.class);
-    registerDSFID(BRIDGE_SERVER_PROFILE, BridgeServerProfile.class);
+    registerDSFID(CACHE_SERVER_LOAD_MESSAGE, CacheServerLoadMessage.class);
+    registerDSFID(CACHE_SERVER_PROFILE, CacheServerProfile.class);
     registerDSFID(CONTROLLER_PROFILE, ControllerProfile.class);
     registerDSFID(DLOCK_QUERY_MESSAGE,
         DLockQueryProcessor.DLockQueryMessage.class);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
index a8a1715..84f038a 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/DataSerializableFixedID.java
@@ -135,7 +135,7 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte PR_FUNCTION_REPLY_MESSAGE = -93;
 
   public static final byte PROFILES_REPLY_MESSAGE = -92;
-  public static final byte BRIDGE_SERVER_PROFILE = -91;
+  public static final byte CACHE_SERVER_PROFILE = -91;
   public static final byte CONTROLLER_PROFILE = -90;
 
   public static final byte CREATE_REGION_MESSAGE = -89;
@@ -341,12 +341,12 @@ public interface DataSerializableFixedID extends SerializationVersions {
   public static final byte PARTITION_PROFILE = 18;
 
   public static final byte ROLE_EVENT = 19;
-  public static final byte BRIDGE_REGION_EVENT = 20;
+  public static final byte CLIENT_REGION_EVENT = 20;
 
   public static final byte CONCURRENT_HASH_MAP = 21;
   public static final byte FIND_DURABLE_QUEUE = 22;
   public static final byte FIND_DURABLE_QUEUE_REPLY = 23;
-  public static final byte BRIDGE_SERVER_LOAD_MESSAGE = 24;
+  public static final byte CACHE_SERVER_LOAD_MESSAGE = 24;
 
   /** A header byte meaning that the next element in the stream is a
    * <code>ObjectPartList</code>.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/ClientStatsManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/ClientStatsManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/ClientStatsManager.java
index 7166024..b8ceb0b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/ClientStatsManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/ClientStatsManager.java
@@ -19,7 +19,6 @@ import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.client.internal.PoolImpl;
 import com.gemstone.gemfire.cache.client.internal.ServerRegionProxy;
 import com.gemstone.gemfire.cache.query.CqQuery;
-import com.gemstone.gemfire.cache.util.BridgeWriterException;
 import com.gemstone.gemfire.distributed.DistributedSystemDisconnectedException;
 import com.gemstone.gemfire.distributed.internal.InternalDistributedSystem;
 import com.gemstone.gemfire.i18n.LogWriterI18n;
@@ -88,12 +87,6 @@ public class ClientStatsManager {
     catch (DistributedSystemDisconnectedException e) {
       throw e;
     }
-    catch (BridgeWriterException bgx) {
-      pool.getCancelCriterion().checkCancelInProgress(bgx);
-      currentCache.getCancelCriterion().checkCancelInProgress(bgx);
-      //TODO: Need to analyze these exception scenarios.
-      logger.warning(LocalizedStrings.ClientStatsManager_FAILED_TO_SEND_CLIENT_HEALTH_STATS_TO_CACHESERVER, bgx);
-    }
     catch (CacheWriterException cwx) {
       pool.getCancelCriterion().checkCancelInProgress(cwx);
       currentCache.getCancelCriterion().checkCancelInProgress(cwx);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/GemFireVM.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/GemFireVM.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/GemFireVM.java
index 289587a..1223152 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/GemFireVM.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/GemFireVM.java
@@ -314,7 +314,7 @@ public interface GemFireVM {
    *
    * @since 4.0
    */
-  public AdminBridgeServer addBridgeServer(CacheInfo cache)
+  public AdminBridgeServer addCacheServer(CacheInfo cache)
     throws AdminException;
 
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/BridgeServerResponse.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/BridgeServerResponse.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/BridgeServerResponse.java
index 62eae9b..6bfeef3 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/BridgeServerResponse.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/BridgeServerResponse.java
@@ -12,7 +12,7 @@ import com.gemstone.gemfire.DataSerializer;
 import com.gemstone.gemfire.cache.CacheFactory;
 import com.gemstone.gemfire.distributed.internal.DistributionManager;
 import com.gemstone.gemfire.internal.Assert;
-import com.gemstone.gemfire.internal.cache.BridgeServerImpl;
+import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.cache.GemFireCacheImpl;
 import java.io.*;
 import java.util.*;
@@ -55,8 +55,8 @@ public final class BridgeServerResponse extends AdminResponse {
         int operation = request.getOperation();
         switch (operation) {
         case BridgeServerRequest.ADD_OPERATION: {
-          BridgeServerImpl bridge =
-            (BridgeServerImpl) cache.addBridgeServer();
+          CacheServerImpl bridge =
+            (CacheServerImpl) cache.addCacheServer();
           m.bridgeInfo = new RemoteBridgeServer(bridge);
           break;
         }
@@ -65,9 +65,9 @@ public final class BridgeServerResponse extends AdminResponse {
           int id = request.getBridgeId();
           // Note that since this is only an informational request
           // it is not necessary to synchronize on allBridgeServersLock
-          for (Iterator iter = cache.getBridgeServers().iterator();
+          for (Iterator iter = cache.getCacheServers().iterator();
                iter.hasNext(); ) {
-            BridgeServerImpl bridge = (BridgeServerImpl) iter.next();
+            CacheServerImpl bridge = (CacheServerImpl) iter.next();
             if (System.identityHashCode(bridge) == id) {
               m.bridgeInfo = new RemoteBridgeServer(bridge);
               break;
@@ -81,9 +81,9 @@ public final class BridgeServerResponse extends AdminResponse {
 
         case BridgeServerRequest.START_OPERATION: {
           RemoteBridgeServer config = request.getBridgeInfo();
-          for (Iterator iter = cache.getBridgeServers().iterator();
+          for (Iterator iter = cache.getCacheServers().iterator();
                iter.hasNext(); ) {
-            BridgeServerImpl bridge = (BridgeServerImpl) iter.next();
+            CacheServerImpl bridge = (CacheServerImpl) iter.next();
             if (System.identityHashCode(bridge) == config.getId()) {
               bridge.configureFrom(config);
               bridge.start();
@@ -99,9 +99,9 @@ public final class BridgeServerResponse extends AdminResponse {
 
         case BridgeServerRequest.STOP_OPERATION: {
           RemoteBridgeServer config = request.getBridgeInfo();
-          for (Iterator iter = cache.getBridgeServers().iterator();
+          for (Iterator iter = cache.getCacheServers().iterator();
                iter.hasNext(); ) {
-            BridgeServerImpl bridge = (BridgeServerImpl) iter.next();
+            CacheServerImpl bridge = (CacheServerImpl) iter.next();
             if (System.identityHashCode(bridge) == config.getId()) {
               bridge.stop();
               m.bridgeInfo = new RemoteBridgeServer(bridge);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/DurableClientInfoResponse.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/DurableClientInfoResponse.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/DurableClientInfoResponse.java
index dd5aeba..ecd4967 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/DurableClientInfoResponse.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/DurableClientInfoResponse.java
@@ -45,9 +45,9 @@ public class DurableClientInfoResponse extends AdminResponse
     try {
       GemFireCacheImpl c = (GemFireCacheImpl)CacheFactory.getInstanceCloseOk(dm
           .getSystem());
-      if (c.getBridgeServers().size() > 0) {
+      if (c.getCacheServers().size() > 0) {
 
-        BridgeServerImpl server = (BridgeServerImpl)c.getBridgeServers()
+        CacheServerImpl server = (CacheServerImpl)c.getCacheServers()
             .iterator().next();
         switch (request.action) {
         case DurableClientInfoRequest.HAS_DURABLE_CLIENT_REQUEST: {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteBridgeServer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteBridgeServer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteBridgeServer.java
index ec0bb34..cd40327 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteBridgeServer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteBridgeServer.java
@@ -27,8 +27,8 @@ import com.gemstone.gemfire.cache.server.ClientSubscriptionConfig;
 import com.gemstone.gemfire.internal.InternalDataSerializer;
 import com.gemstone.gemfire.internal.Version;
 import com.gemstone.gemfire.internal.admin.AdminBridgeServer;
-import com.gemstone.gemfire.internal.cache.AbstractBridgeServer;
-import com.gemstone.gemfire.internal.cache.BridgeServerImpl;
+import com.gemstone.gemfire.internal.cache.AbstractCacheServer;
+import com.gemstone.gemfire.internal.cache.CacheServerImpl;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 
 /**
@@ -40,7 +40,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  * @since 4.0
  */
 public class RemoteBridgeServer
-  extends AbstractBridgeServer
+  extends AbstractCacheServer
   implements AdminBridgeServer, DataSerializable {
 
   private static final long serialVersionUID = 8417391824652384959L;
@@ -64,12 +64,12 @@ public class RemoteBridgeServer
    * <code>RemoteBridgeServer</code> from the contents of the given
    * <code>BridgeServerImpl</code>.
    */
-  RemoteBridgeServer(BridgeServerImpl impl) {
+  RemoteBridgeServer(CacheServerImpl impl) {
     super(null);
     this.port = impl.getPort();
     this.bindAddress = impl.getBindAddress();
     this.hostnameForClients = impl.getHostnameForClients();
-    if (BridgeServerImpl.ENABLE_NOTIFY_BY_SUBSCRIPTION_FALSE) {
+    if (CacheServerImpl.ENABLE_NOTIFY_BY_SUBSCRIPTION_FALSE) {
       this.notifyBySubscription = impl.getNotifyBySubscription();
     }
     this.socketBufferSize = impl.getSocketBufferSize();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/2eb4e175/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo.java
index 689ef92..a3a283d 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/admin/remote/RemoteCacheInfo.java
@@ -12,7 +12,7 @@ import com.gemstone.gemfire.DataSerializer;
 import com.gemstone.gemfire.internal.admin.*;
 //import com.gemstone.gemfire.internal.*;
 import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.cache.util.BridgeServer;
+import com.gemstone.gemfire.cache.server.CacheServer;
 import com.gemstone.gemfire.internal.cache.*;
 import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 
@@ -79,11 +79,11 @@ public class RemoteCacheInfo implements CacheInfo, DataSerializable {
 
       // Note that since this is only a snapshot, so no synchronization
       // on allBridgeServersLock is needed.
-      Collection bridges = c.getBridgeServers();
+      Collection bridges = c.getCacheServers();
       this.bridgeServerIds = new int[bridges.size()];
       Iterator iter = bridges.iterator();
       for (int i = 0; iter.hasNext(); i++) {
-        BridgeServer bridge = (BridgeServer) iter.next();
+        CacheServer bridge = (CacheServer) iter.next();
         this.bridgeServerIds[i] = System.identityHashCode(bridge);
       }