You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by mb...@apache.org on 2016/10/21 20:30:45 UTC

[06/51] [partial] incubator-geode git commit: Added Spotless plugin to enforce formatting standards. Added Google Java Style guide formatter templates, removed existing formatter templates.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
index d3aaf9c..51301bc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
@@ -1,32 +1,28 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 
 package org.apache.geode.cache;
 
 
 /**
- * Supports modification of certain region attributes after the region has been
- * created. It is recommended that the attributes be completely initialized
- * using an {@link AttributesFactory} before creating the region instead of
- * using an <code>AttributesMutator</code> after region creation. This will
- * avoid a potential performance penalty due to the additional
- * network traffic.
- *<p>
- * The setter methods all return the previous value of the attribute. 
+ * Supports modification of certain region attributes after the region has been created. It is
+ * recommended that the attributes be completely initialized using an {@link AttributesFactory}
+ * before creating the region instead of using an <code>AttributesMutator</code> after region
+ * creation. This will avoid a potential performance penalty due to the additional network traffic.
+ * <p>
+ * The setter methods all return the previous value of the attribute.
  *
  *
  *
@@ -35,176 +31,195 @@ package org.apache.geode.cache;
  * @see AttributesFactory
  * @since GemFire 3.0
  */
-public interface AttributesMutator<K,V> {
-  
-  /** Returns the Region whose attributes this mutator affects.
+public interface AttributesMutator<K, V> {
+
+  /**
+   * Returns the Region whose attributes this mutator affects.
+   * 
    * @return the Region this mutator affects
    */
-  public Region<K,V> getRegion();
-  
-  /** Changes the timeToLive expiration attributes for the region as a whole
+  public Region<K, V> getRegion();
+
+  /**
+   * Changes the timeToLive expiration attributes for the region as a whole
    *
    * @param timeToLive the expiration attributes for the region timeToLive
    * @return the previous value of region timeToLive
-   * @throws IllegalArgumentException if timeToLive is null or if the
-   * ExpirationAction is LOCAL_INVALIDATE and the region is
-   * {@link DataPolicy#withReplication replicated}
+   * @throws IllegalArgumentException if timeToLive is null or if the ExpirationAction is
+   *         LOCAL_INVALIDATE and the region is {@link DataPolicy#withReplication replicated}
    * @throws IllegalStateException if statistics are disabled for this region.
    */
   public ExpirationAttributes setRegionTimeToLive(ExpirationAttributes timeToLive);
-  
-  /** Changes the idleTimeout expiration attributes for the region as a whole.
-   * Resets the {@link CacheStatistics#getLastAccessedTime} for the region.
+
+  /**
+   * Changes the idleTimeout expiration attributes for the region as a whole. Resets the
+   * {@link CacheStatistics#getLastAccessedTime} for the region.
    *
    * @param idleTimeout the ExpirationAttributes for this region idleTimeout
    * @return the previous value of region idleTimeout
-   * @throws IllegalArgumentException if idleTimeout is null or if the
-   * ExpirationAction is LOCAL_INVALIDATE and the region is
-   * {@link DataPolicy#withReplication replicated}
+   * @throws IllegalArgumentException if idleTimeout is null or if the ExpirationAction is
+   *         LOCAL_INVALIDATE and the region is {@link DataPolicy#withReplication replicated}
    * @throws IllegalStateException if statistics are disabled for this region.
    */
   public ExpirationAttributes setRegionIdleTimeout(ExpirationAttributes idleTimeout);
-    
-  /** Changes the timeToLive expiration attributes for values in this region.
+
+  /**
+   * Changes the timeToLive expiration attributes for values in this region.
    *
    * @param timeToLive the timeToLive expiration attributes for entries
    * @return the previous value of entry timeToLive
-   * @throws IllegalArgumentException if timeToLive is null or if the
-   * ExpirationAction is LOCAL_DESTROY and the region is {@link DataPolicy#withReplication replicated} or if 
-   * the ExpirationAction is LOCAL_INVALIDATE and the region is 
-   * {@link DataPolicy#withReplication replicated}
+   * @throws IllegalArgumentException if timeToLive is null or if the ExpirationAction is
+   *         LOCAL_DESTROY and the region is {@link DataPolicy#withReplication replicated} or if the
+   *         ExpirationAction is LOCAL_INVALIDATE and the region is
+   *         {@link DataPolicy#withReplication replicated}
    * @throws IllegalStateException if statistics are disabled for this region.
    */
   public ExpirationAttributes setEntryTimeToLive(ExpirationAttributes timeToLive);
-  
+
   /**
    * Changes the custom timeToLive for values in this region
+   * 
    * @param custom the new CustomExpiry
    * @return the old CustomExpiry
    */
-  public CustomExpiry<K,V> setCustomEntryTimeToLive(CustomExpiry<K,V> custom);
-  
-  /** Changes the idleTimeout expiration attributes for values in the region.
+  public CustomExpiry<K, V> setCustomEntryTimeToLive(CustomExpiry<K, V> custom);
+
+  /**
+   * Changes the idleTimeout expiration attributes for values in the region.
    *
    * @param idleTimeout the idleTimeout expiration attributes for entries
    * @return the previous value of entry idleTimeout
-   * @throws IllegalArgumentException if idleTimeout is null or if the
-   * ExpirationAction is LOCAL_DESTROY and the region is
-   * {@link DataPolicy#withReplication replicated}
-   * or if the the ExpirationAction is LOCAL_INVALIDATE and the region is 
-   * {@link DataPolicy#withReplication replicated}
+   * @throws IllegalArgumentException if idleTimeout is null or if the ExpirationAction is
+   *         LOCAL_DESTROY and the region is {@link DataPolicy#withReplication replicated} or if the
+   *         the ExpirationAction is LOCAL_INVALIDATE and the region is
+   *         {@link DataPolicy#withReplication replicated}
    * @see AttributesFactory#setStatisticsEnabled
    * @throws IllegalStateException if statistics are disabled for this region.
    */
   public ExpirationAttributes setEntryIdleTimeout(ExpirationAttributes idleTimeout);
-  
-  /** Changes the CustomExpiry for idleTimeout for values in the region
+
+  /**
+   * Changes the CustomExpiry for idleTimeout for values in the region
    * 
    * @param custom the new CustomExpiry
    * @return the old CustomExpiry
    */
-  public CustomExpiry<K,V> setCustomEntryIdleTimeout(CustomExpiry<K,V> custom);
-  
-  /** Changes the CacheListener for the region.
-   * Removes listeners already added and calls {@link CacheCallback#close} on each of them.
+  public CustomExpiry<K, V> setCustomEntryIdleTimeout(CustomExpiry<K, V> custom);
+
+  /**
+   * Changes the CacheListener for the region. Removes listeners already added and calls
+   * {@link CacheCallback#close} on each of them.
+   * 
    * @param aListener a user defined cache listener
    * @return the previous CacheListener if a single one exists; otherwise null.
    * @throws IllegalStateException if more than one cache listener has already been added
-   * @deprecated as of GemFire 5.0, use {@link #addCacheListener} or {@link #initCacheListeners} instead.
+   * @deprecated as of GemFire 5.0, use {@link #addCacheListener} or {@link #initCacheListeners}
+   *             instead.
    */
   @Deprecated
-  public CacheListener<K,V> setCacheListener(CacheListener<K,V> aListener);
+  public CacheListener<K, V> setCacheListener(CacheListener<K, V> aListener);
+
   /**
    * Adds a cache listener to the end of the list of cache listeners on this region.
+   * 
    * @param aListener the user defined cache listener to add to the region.
    * @throws IllegalArgumentException if <code>aListener</code> is null
    * @since GemFire 5.0
    */
-  public void addCacheListener(CacheListener<K,V> aListener);
+  public void addCacheListener(CacheListener<K, V> aListener);
+
   /**
-   * Removes a cache listener from the list of cache listeners on this region.
-   * Does nothing if the specified listener has not been added.
-   * If the specified listener has been added then {@link CacheCallback#close} will
-   * be called on it; otherwise does nothing.
+   * Removes a cache listener from the list of cache listeners on this region. Does nothing if the
+   * specified listener has not been added. If the specified listener has been added then
+   * {@link CacheCallback#close} will be called on it; otherwise does nothing.
+   * 
    * @param aListener the cache listener to remove from the region.
    * @throws IllegalArgumentException if <code>aListener</code> is null
    * @since GemFire 5.0
    */
-  public void removeCacheListener(CacheListener<K,V> aListener);
+  public void removeCacheListener(CacheListener<K, V> aListener);
+
   /**
-   * Removes all cache listeners, calling {@link CacheCallback#close} on each of them, and then adds each listener in the specified array.
+   * Removes all cache listeners, calling {@link CacheCallback#close} on each of them, and then adds
+   * each listener in the specified array.
+   * 
    * @param newListeners a possibly null or empty array of listeners to add to this region.
    * @throws IllegalArgumentException if the <code>newListeners</code> array has a null element
    * @since GemFire 5.0
    */
-  public void initCacheListeners(CacheListener<K,V>[] newListeners);
-  
-  /** Changes the cache writer for the region.
+  public void initCacheListeners(CacheListener<K, V>[] newListeners);
+
+  /**
+   * Changes the cache writer for the region.
+   * 
    * @param cacheWriter the cache writer
    * @return the previous CacheWriter
    */
-  public CacheWriter<K,V> setCacheWriter(CacheWriter<K,V> cacheWriter);
-  
+  public CacheWriter<K, V> setCacheWriter(CacheWriter<K, V> cacheWriter);
+
   /**
    * Changes the cache loader for the region.
    * 
-   * Changing the cache loader for partitioned regions is not recommended due to
-   * the fact that it can result in an inconsistent cache loader configuration.
-   * This feature may be removed in future releases.
+   * Changing the cache loader for partitioned regions is not recommended due to the fact that it
+   * can result in an inconsistent cache loader configuration. This feature may be removed in future
+   * releases.
    * 
-   * @param cacheLoader
-   *          the cache loader
+   * @param cacheLoader the cache loader
    * @return the previous CacheLoader
    */
-  public CacheLoader<K,V> setCacheLoader(CacheLoader<K,V> cacheLoader);
-  
+  public CacheLoader<K, V> setCacheLoader(CacheLoader<K, V> cacheLoader);
+
 
-  /** Allows changing the eviction controller attributes for the region.
+  /**
+   * Allows changing the eviction controller attributes for the region.
    * 
    * @return the {@link EvictionAttributesMutator} used to change the EvictionAttributes
    */
   public EvictionAttributesMutator getEvictionAttributesMutator();
 
   /**
-   * Sets cloning on region
-   * Note: off-heap regions always behave as if cloning is enabled.
+   * Sets cloning on region Note: off-heap regions always behave as if cloning is enabled.
+   * 
    * @param cloningEnable
    * @since GemFire 6.1
    */
   public void setCloningEnabled(boolean cloningEnable);
+
   /**
    * Returns whether or not cloning is enabled on region
    *
-   * @return True if cloning is enabled (default);
-   *         false cloning is not enabled.
+   * @return True if cloning is enabled (default); false cloning is not enabled.
    *
    * @since GemFire 6.1
    */
   public boolean getCloningEnabled();
-  
+
   /**
-   * Adds GatewaySenderId to the list of GatewaySenderIds of the region.
-   * If the GatewaySenderId is not present on this VM then it will try to send it to other VM's
+   * Adds GatewaySenderId to the list of GatewaySenderIds of the region. If the GatewaySenderId is
+   * not present on this VM then it will try to send it to other VM's
    * 
    * @param gatewaySenderId
    */
-   public void addGatewaySenderId(String gatewaySenderId);
-   
-   /**
-    * Removes GatewaySenderId from the list of GatewaySenderIds of the region.
-    * @param gatewaySenderId 
-    */
-   public void removeGatewaySenderId(String gatewaySenderId);
-   
-   /**
-    * Adds AsyncEventQueueId to the list of AsyncEventQueueId of the region.
-    * @param asyncEventQueueId 
-    */
-   public void addAsyncEventQueueId(String asyncEventQueueId);
-   
-   /**
-    * Removes AsyncEventQueueId from the list of AsyncEventQueuesId of the region.
-    * @param asyncEventQueueId 
-    */
-   public void removeAsyncEventQueueId(String asyncEventQueueId);
+  public void addGatewaySenderId(String gatewaySenderId);
+
+  /**
+   * Removes GatewaySenderId from the list of GatewaySenderIds of the region.
+   * 
+   * @param gatewaySenderId
+   */
+  public void removeGatewaySenderId(String gatewaySenderId);
+
+  /**
+   * Adds AsyncEventQueueId to the list of AsyncEventQueueId of the region.
+   * 
+   * @param asyncEventQueueId
+   */
+  public void addAsyncEventQueueId(String asyncEventQueueId);
+
+  /**
+   * Removes AsyncEventQueueId from the list of AsyncEventQueuesId of the region.
+   * 
+   * @param asyncEventQueueId
+   */
+  public void removeAsyncEventQueueId(String asyncEventQueueId);
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/Cache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Cache.java b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
index 773654b..bc4aa19 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Cache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
@@ -1,18 +1,16 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 
 package org.apache.geode.cache;
@@ -37,25 +35,23 @@ import org.apache.geode.distributed.DistributedSystem;
 import org.apache.geode.i18n.LogWriterI18n;
 
 
-/** 
- * Caches are obtained from the {@link CacheFactory#create()} method.
- * See {@link CacheFactory} for common usage patterns for creating the cache instance.
+/**
+ * Caches are obtained from the {@link CacheFactory#create()} method. See {@link CacheFactory} for
+ * common usage patterns for creating the cache instance.
  * <p>
- * When a cache is created a {@link DistributedSystem} is also created.
- * This system tells the cache where to find other caches on the network
- * and how to communicate with them.
- * The system can also specify a
- * <a href="../distribution/DistributedSystem.html#cache-xml-file">"cache-xml-file"</a>
- * property which will cause this cache to be initialized with the contents
- * of that file. The contents must comply with the
- * <code>"doc-files/cache8_0.dtd"</code> file
- * and the top level element must be a <code>cache</code> element.
+ * When a cache is created a {@link DistributedSystem} is also created. This system tells the cache
+ * where to find other caches on the network and how to communicate with them. The system can also
+ * specify a <a href="../distribution/DistributedSystem.html#cache-xml-file">"cache-xml-file"</a>
+ * property which will cause this cache to be initialized with the contents of that file. The
+ * contents must comply with the <code>"doc-files/cache8_0.dtd"</code> file and the top level
+ * element must be a <code>cache</code> element.
  * <p>
- * When a cache will no longer be used it should be {@link #close() closed}.
- * Once it {@link #isClosed is closed} any attempt to use it or any {@link Region}
- * obtained from it will cause a {@link CacheClosedException} to be thrown.
+ * When a cache will no longer be used it should be {@link #close() closed}. Once it
+ * {@link #isClosed is closed} any attempt to use it or any {@link Region} obtained from it will
+ * cause a {@link CacheClosedException} to be thrown.
  *
- * <p>A cache can have multiple root regions, each with a different name.
+ * <p>
+ * A cache can have multiple root regions, each with a different name.
  *
  *
  * @since GemFire 2.0
@@ -63,28 +59,27 @@ import org.apache.geode.i18n.LogWriterI18n;
 @SuppressWarnings("deprecation")
 public interface Cache extends GemFireCache {
   /**
-   * Terminates this object cache and releases all the resources.
-   * Calls {@link Region#close} on each region in the cache.
-   * After this cache is closed, any further
-   * method call on this cache or any region object will throw
-   * {@link CacheClosedException}, unless otherwise noted.
-   * @param keepalive whether the server should keep the durable client's queues alive for the timeout period
+   * Terminates this object cache and releases all the resources. Calls {@link Region#close} on each
+   * region in the cache. After this cache is closed, any further method call on this cache or any
+   * region object will throw {@link CacheClosedException}, unless otherwise noted.
+   * 
+   * @param keepalive whether the server should keep the durable client's queues alive for the
+   *        timeout period
    * @throws CacheClosedException if the cache is already closed.
    * @deprecated as of 6.5 use {@link ClientCache#close(boolean)} instead.
    */
   @Deprecated
-  public void close(boolean keepalive);  
-  
+  public void close(boolean keepalive);
+
   /**
-   * Creates a VM region using the specified
-   * RegionAttributes.
+   * Creates a VM region using the specified RegionAttributes.
    *
    * @param name the name of the region to create
    * @param aRegionAttributes the attributes of the root region
    * @return the region object
-   * @throws RegionExistsException if a region is already in
-   * this cache
-   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws RegionExistsException if a region is already in this cache
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock
+   *         for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheClosedException if the cache is closed
    * @throws IllegalStateException If the supplied RegionAttributes violate the
@@ -93,8 +88,8 @@ public interface Cache extends GemFireCache {
    * @deprecated as of GemFire 5.0, use {@link #createRegion} instead.
    */
   @Deprecated
-  public <K,V> Region<K,V> createVMRegion(String name, RegionAttributes<K,V> aRegionAttributes)
-  throws RegionExistsException, TimeoutException;
+  public <K, V> Region<K, V> createVMRegion(String name, RegionAttributes<K, V> aRegionAttributes)
+      throws RegionExistsException, TimeoutException;
 
   /**
    * Creates a region using the specified RegionAttributes.
@@ -103,7 +98,8 @@ public interface Cache extends GemFireCache {
    * @param aRegionAttributes the attributes of the root region
    * @return the region object
    * @throws RegionExistsException if a region is already in this cache
-   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock for Scope.GLOBAL
+   * @throws org.apache.geode.distributed.LeaseExpiredException if lease expired on distributed lock
+   *         for Scope.GLOBAL
    * @throws TimeoutException if timed out getting distributed lock for Scope.GLOBAL
    * @throws CacheClosedException if the cache is closed
    * @throws IllegalStateException If the supplied RegionAttributes violate the
@@ -113,138 +109,133 @@ public interface Cache extends GemFireCache {
    * @deprecated as of 6.5 use {@link #createRegionFactory(RegionAttributes)} instead
    */
   @Deprecated
-  public <K,V> Region<K,V> createRegion(String name, RegionAttributes<K,V> aRegionAttributes)
-    throws RegionExistsException, TimeoutException;
+  public <K, V> Region<K, V> createRegion(String name, RegionAttributes<K, V> aRegionAttributes)
+      throws RegionExistsException, TimeoutException;
 
   /**
-   * Creates a {@link RegionFactory} which can be used to specify additional
-   * attributes for {@link Region} creation.
+   * Creates a {@link RegionFactory} which can be used to specify additional attributes for
+   * {@link Region} creation.
+   * 
    * @see #createRegionFactory(RegionShortcut)
    * @since GemFire 6.5
    */
-  public <K,V> RegionFactory<K,V> createRegionFactory();
-  
+  public <K, V> RegionFactory<K, V> createRegionFactory();
+
   /**
-   * Creates a {@link RegionFactory} for the most commonly used {@link Region} types
-   * defined by {@link RegionShortcut}
+   * Creates a {@link RegionFactory} for the most commonly used {@link Region} types defined by
+   * {@link RegionShortcut}
+   * 
    * @since GemFire 6.5
    */
-  public <K,V> RegionFactory<K,V> createRegionFactory(RegionShortcut atts);
-  
+  public <K, V> RegionFactory<K, V> createRegionFactory(RegionShortcut atts);
+
   /**
-   * Creates a {@link RegionFactory} for creating a {@link Region} from
-   * {@link RegionAttributes} mapped to this regionAttributesId
+   * Creates a {@link RegionFactory} for creating a {@link Region} from {@link RegionAttributes}
+   * mapped to this regionAttributesId
+   * 
    * @param regionAttributesId the Id of RegionAttributes to be used
    * @see #setRegionAttributes(String, RegionAttributes)
    * @since GemFire 6.5
    */
-  public <K,V> RegionFactory<K,V> createRegionFactory(String regionAttributesId);
-  
+  public <K, V> RegionFactory<K, V> createRegionFactory(String regionAttributesId);
+
   /**
-   * Creates a {@link RegionFactory} for creating a {@link Region} from
-   * the given regionAttributes
+   * Creates a {@link RegionFactory} for creating a {@link Region} from the given regionAttributes
+   * 
    * @param regionAttributes regionAttributes for the new region
    * @see #createRegionFactory(RegionShortcut)
    * @since GemFire 6.5
    */
-  public <K,V> RegionFactory<K,V> createRegionFactory(RegionAttributes<K,V> regionAttributes);
-  
+  public <K, V> RegionFactory<K, V> createRegionFactory(RegionAttributes<K, V> regionAttributes);
+
   /**
-   * Internal GemStone method for accessing the internationalized 
-   * logging object for GemFire, use {@link #getLogger()} instead.
-   * This method does not throw
-   * <code>CacheClosedException</code> if the cache is closed.
+   * Internal GemStone method for accessing the internationalized logging object for GemFire, use
+   * {@link #getLogger()} instead. This method does not throw <code>CacheClosedException</code> if
+   * the cache is closed.
+   * 
    * @return the logging object
    * @deprecated as of 6.5 use getLogger().convertToLogWriterI18n() instead
    */
   @Deprecated
   public LogWriterI18n getLoggerI18n();
-  
+
   /**
-   * Internal GemStone method for accessing the internationalized 
-   * logging object for GemFire, use {@link #getSecurityLogger()} instead.
-   * This method does not throw
+   * Internal GemStone method for accessing the internationalized logging object for GemFire, use
+   * {@link #getSecurityLogger()} instead. This method does not throw
    * <code>CacheClosedException</code> if the cache is closed.
+   * 
    * @return the security logging object
    * @deprecated as of 6.5 use getSecurityLogger().convertToLogWriterI18n() instead
    */
   @Deprecated
   public LogWriterI18n getSecurityLoggerI18n();
-  
+
   /**
-   * Gets the number of seconds a cache operation will wait to obtain
-   * a distributed lock lease.
-   * This method does not throw
-   * <code>CacheClosedException</code> if the cache is closed.
+   * Gets the number of seconds a cache operation will wait to obtain a distributed lock lease. This
+   * method does not throw <code>CacheClosedException</code> if the cache is closed.
    */
   public int getLockTimeout();
+
   /**
-   * Sets the number of seconds a cache operation may wait to obtain a
-   * distributed lock lease before timing out.
+   * Sets the number of seconds a cache operation may wait to obtain a distributed lock lease before
+   * timing out.
    *
    * @throws IllegalArgumentException if <code>seconds</code> is less than zero
    */
   public void setLockTimeout(int seconds);
 
   /**
-   * Gets the frequency (in seconds) at which a message will be sent by the
-   * primary cache-server to all the secondary cache-server nodes to remove the
-   * events which have already been dispatched from the queue.
+   * Gets the frequency (in seconds) at which a message will be sent by the primary cache-server to
+   * all the secondary cache-server nodes to remove the events which have already been dispatched
+   * from the queue.
    * 
    * @return The time interval in seconds
    */
   public int getMessageSyncInterval();
 
   /**
-   * Sets the frequency (in seconds) at which a message will be sent by the
-   * primary cache-server node to all the secondary cache-server nodes to remove
-   * the events which have already been dispatched from the queue.
+   * Sets the frequency (in seconds) at which a message will be sent by the primary cache-server
+   * node to all the secondary cache-server nodes to remove the events which have already been
+   * dispatched from the queue.
    * 
-   * @param seconds -
-   *          the time interval in seconds
-   * @throws IllegalArgumentException
-   *           if <code>seconds</code> is less than zero
+   * @param seconds - the time interval in seconds
+   * @throws IllegalArgumentException if <code>seconds</code> is less than zero
    */
   public void setMessageSyncInterval(int seconds);
-  
+
   /**
-   * Gets the length, in seconds, of distributed lock leases obtained
-   * by this cache.
-   * This method does not throw
-   * <code>CacheClosedException</code> if the cache is closed.
+   * Gets the length, in seconds, of distributed lock leases obtained by this cache. This method
+   * does not throw <code>CacheClosedException</code> if the cache is closed.
    */
   public int getLockLease();
+
   /**
-   * Sets the length, in seconds, of distributed lock leases obtained
-   * by this cache.
+   * Sets the length, in seconds, of distributed lock leases obtained by this cache.
    *
    * @throws IllegalArgumentException if <code>seconds</code> is less than zero.
    */
   public void setLockLease(int seconds);
-  
-  /**
-   * Gets the number of seconds a cache
-   * {@link org.apache.geode.cache.Region#get(Object) get} operation
-   * can spend searching for a value before it times out.
-   * The search includes any time spent loading the object.
-   * When the search times out it causes the get to fail by throwing
-   * an exception.
-   * This method does not throw
-   * <code>CacheClosedException</code> if the cache is closed.
+
+  /**
+   * Gets the number of seconds a cache {@link org.apache.geode.cache.Region#get(Object) get}
+   * operation can spend searching for a value before it times out. The search includes any time
+   * spent loading the object. When the search times out it causes the get to fail by throwing an
+   * exception. This method does not throw <code>CacheClosedException</code> if the cache is closed.
    */
   public int getSearchTimeout();
+
   /**
-   * Sets the number of seconds a cache get operation can spend searching
-   * for a value.
+   * Sets the number of seconds a cache get operation can spend searching for a value.
    *
    * @throws IllegalArgumentException if <code>seconds</code> is less than zero
    */
   public void setSearchTimeout(int seconds);
 
   /**
-   * Creates a new cache server, with the default configuration,
-   * that will allow clients to access this cache.
-   * <p>For the default configuration see the constants in
+   * Creates a new cache server, with the default configuration, that will allow clients to access
+   * this cache.
+   * <p>
+   * For the default configuration see the constants in
    * {@link org.apache.geode.cache.server.CacheServer}.
    * 
    * @see org.apache.geode.cache.server.CacheServer
@@ -254,41 +245,40 @@ public interface Cache extends GemFireCache {
   public CacheServer addCacheServer();
 
   /**
-   * Returns a collection of all of the <code>CacheServer</code>s
-   * that can serve the contents of this <code>Cache</code> to clients.
+   * Returns a collection of all of the <code>CacheServer</code>s that can serve the contents of
+   * this <code>Cache</code> to clients.
    *
    * @see #addCacheServer
    *
    * @since GemFire 5.7
    */
   public List<CacheServer> getCacheServers();
-  
-  /**
-   * Adds a gateway event conflict resolution resolver.  This is invoked
-   * if an event is processed that comes from a different distributed system
-   * than the last event to modify the affected entry.  It may alter
-   * the event or disallow the event.  If it does neither the event is applied
-   * to the cache if its timestamp is newer than what is in the cache or if
-   * it is the same and the event's distributed system ID is larger than that
-   * of the last event to modify the affected entry.
+
+  /**
+   * Adds a gateway event conflict resolution resolver. This is invoked if an event is processed
+   * that comes from a different distributed system than the last event to modify the affected
+   * entry. It may alter the event or disallow the event. If it does neither the event is applied to
+   * the cache if its timestamp is newer than what is in the cache or if it is the same and the
+   * event's distributed system ID is larger than that of the last event to modify the affected
+   * entry.
+   * 
    * @param resolver
    * @since GemFire 7.0
    */
   public void setGatewayConflictResolver(GatewayConflictResolver resolver);
-  
+
   /**
    * Returns the current gateway event conflict resolver
+   * 
    * @since GemFire 7.0
    */
   public GatewayConflictResolver getGatewayConflictResolver();
-  
-  /**
-   * Sets whether or not this <code>Cache</code> resides in a
-   * long-running "cache server" VM.  A cache server may be an
-   * application VM or may be a stand-along VM launched using {@linkplain
-   * org.apache.geode.admin.AdminDistributedSystem#addCacheServer
-   * administration API} or the <code>cacheserver</code> command line
-   * utility.
+
+  /**
+   * Sets whether or not this <code>Cache</code> resides in a long-running "cache server" VM. A
+   * cache server may be an application VM or may be a stand-along VM launched using
+   * {@linkplain org.apache.geode.admin.AdminDistributedSystem#addCacheServer administration API} or
+   * the <code>cacheserver</code> command line utility.
    *
    * @since GemFire 4.0
    */
@@ -304,15 +294,13 @@ public interface Cache extends GemFireCache {
   public boolean isServer();
 
   /**
-   * Notifies the server that this client is ready to receive updates.
-   * This method is used by durable clients to notify servers that they
-   * are ready to receive updates. As soon as the server receives this message, 
-   * it will forward updates to this client (if necessary).
+   * Notifies the server that this client is ready to receive updates. This method is used by
+   * durable clients to notify servers that they are ready to receive updates. As soon as the server
+   * receives this message, it will forward updates to this client (if necessary).
    * <p>
-   * Durable clients must call this method after they are done creating regions.
-   * If it is called before the client creates the regions then updates will be lost.
-   * Any time a new {@link Pool} is created and regions have been added to it then
-   * this method needs to be called again.
+   * Durable clients must call this method after they are done creating regions. If it is called
+   * before the client creates the regions then updates will be lost. Any time a new {@link Pool} is
+   * created and regions have been added to it then this method needs to be called again.
    * <p>
    *
    * @throws IllegalStateException if called by a non-durable client
@@ -324,8 +312,7 @@ public interface Cache extends GemFireCache {
   public void readyForEvents();
 
   /**
-   * Creates {@link GatewaySenderFactory} for creating a
-   * SerialGatewaySender
+   * Creates {@link GatewaySenderFactory} for creating a SerialGatewaySender
    * 
    * @return SerialGatewaySenderFactory
    * @since GemFire 7.0
@@ -333,14 +320,13 @@ public interface Cache extends GemFireCache {
   public GatewaySenderFactory createGatewaySenderFactory();
 
   /**
-   * Creates {@link AsyncEventQueueFactory} for creating a
-   * AsyncEventQueue
+   * Creates {@link AsyncEventQueueFactory} for creating a AsyncEventQueue
    * 
    * @return AsyncEventQueueFactory
    * @since GemFire 7.0
    */
   public AsyncEventQueueFactory createAsyncEventQueueFactory();
-  
+
   /**
    * Creates {@link GatewayReceiverFactory} for creating a GatewayReceiver
    * 
@@ -350,7 +336,7 @@ public interface Cache extends GemFireCache {
   public GatewayReceiverFactory createGatewayReceiverFactory();
 
   /**
-   * Returns all {@link GatewaySender}s for this Cache. 
+   * Returns all {@link GatewaySender}s for this Cache.
    * 
    * @return Set of GatewaySenders
    * @since GemFire 7.0
@@ -362,8 +348,9 @@ public interface Cache extends GemFireCache {
    * 
    * @return GatewaySender with id
    * @since GemFire 7.0
-   */  
+   */
   public GatewaySender getGatewaySender(String id);
+
   /**
    * Returns all {@link GatewayReceiver}s for this Cache
    * 
@@ -371,66 +358,68 @@ public interface Cache extends GemFireCache {
    * @since GemFire 7.0
    */
   public Set<GatewayReceiver> getGatewayReceivers();
-  
+
   /**
    * Returns all {@link AsyncEventQueue}s for this Cache
    * 
    * @return Set of AsyncEventQueue
    * @since GemFire 7.0
    */
-  public Set<AsyncEventQueue> getAsyncEventQueues(); 
-  
+  public Set<AsyncEventQueue> getAsyncEventQueues();
+
   /**
    * Returns the {@link AsyncEventQueue} with the given id added to this Cache.
    * 
    * @return AsyncEventQueue with id
    * @since GemFire 7.0
-   */  
+   */
   public AsyncEventQueue getAsyncEventQueue(String id);
 
   /**
    * Returns a set of the other non-administrative members in the distributed system.
+   * 
    * @since GemFire 6.6
    */
   public Set<DistributedMember> getMembers();
-  
+
   /**
    * Returns a set of the administrative members in the distributed system.
+   * 
    * @since GemFire 6.6
    */
   public Set<DistributedMember> getAdminMembers();
-  
+
   /**
-   * Returns a set of the members in the distributed system that have the
-   * given region.  For regions with local scope an empty set is returned.
+   * Returns a set of the members in the distributed system that have the given region. For regions
+   * with local scope an empty set is returned.
+   * 
    * @param r a Region in the cache
    * @since GemFire 6.6
    */
   public Set<DistributedMember> getMembers(Region r);
-  
+
   /**
-   * Obtains the snapshot service to allow the cache data to be imported
-   * or exported.
+   * Obtains the snapshot service to allow the cache data to be imported or exported.
    * 
    * @return the snapshot service
    */
   public CacheSnapshotService getSnapshotService();
-  
-  /**
-   * Test to see whether the Cache is in the process of reconnecting
-   * and recreating a new cache after it has been removed from the system
-   * by other members or has shut down due to missing Roles and is reconnecting.<p>
-   * This will also return true if the Cache has finished reconnecting.
-   * When reconnect has completed you can use {@link Cache#getReconnectedCache} to
-   * retrieve the new cache instance.
+
+  /**
+   * Test to see whether the Cache is in the process of reconnecting and recreating a new cache
+   * after it has been removed from the system by other members or has shut down due to missing
+   * Roles and is reconnecting.
+   * <p>
+   * This will also return true if the Cache has finished reconnecting. When reconnect has completed
+   * you can use {@link Cache#getReconnectedCache} to retrieve the new cache instance.
    * 
    * @return true if the Cache is attempting to reconnect or has finished reconnecting
    */
   public boolean isReconnecting();
 
   /**
-   * Wait for the Cache to finish reconnecting to the distributed system
-   * and recreate a new Cache.
+   * Wait for the Cache to finish reconnecting to the distributed system and recreate a new Cache.
+   * 
    * @see #getReconnectedCache
    * @param time amount of time to wait, or -1 to wait forever
    * @param units
@@ -438,17 +427,16 @@ public interface Cache extends GemFireCache {
    * @throws InterruptedException if the thread is interrupted while waiting
    */
   public boolean waitUntilReconnected(long time, TimeUnit units) throws InterruptedException;
-  
+
   /**
-   * Force the Cache to stop reconnecting.  If the Cache
-   * is currently connected this will disconnect and close it.
+   * Force the Cache to stop reconnecting. If the Cache is currently connected this will disconnect
+   * and close it.
    * 
    */
   public void stopReconnecting();
-  
+
   /**
-   * Returns the new Cache if there was an auto-reconnect and the cache was
-   * recreated.
+   * Returns the new Cache if there was an auto-reconnect and the cache was recreated.
    */
   public Cache getReconnectedCache();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java b/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
index 9b6964d..a272afb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheCallback.java
@@ -1,40 +1,38 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 
 package org.apache.geode.cache;
 
 /**
- * User-defined objects that can be plugged into caching to receive callback
- * notifications.
+ * User-defined objects that can be plugged into caching to receive callback notifications.
  *
  *
  * @since GemFire 3.0
  */
 public interface CacheCallback {
-  /** Called when the region containing this callback is closed or destroyed, when
-   * the cache is closed, or when a callback is removed from a region
-   * using an <code>AttributesMutator</code>.
+  /**
+   * Called when the region containing this callback is closed or destroyed, when the cache is
+   * closed, or when a callback is removed from a region using an <code>AttributesMutator</code>.
    *
-   * <p>Implementations should cleanup any external
-   * resources such as database connections. Any runtime exceptions this method
-   * throws will be logged.
+   * <p>
+   * Implementations should cleanup any external resources such as database connections. Any runtime
+   * exceptions this method throws will be logged.
    *
-   * <p>It is possible for this method to be called multiple times on a single
-   * callback instance, so implementations must be tolerant of this.
+   * <p>
+   * It is possible for this method to be called multiple times on a single callback instance, so
+   * implementations must be tolerant of this.
    *
    * @see Cache#close()
    * @see Region#close

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
index 9c2be5d..b24bc2f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheClosedException.java
@@ -1,18 +1,16 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 package org.apache.geode.cache;
 
@@ -20,9 +18,8 @@ import org.apache.geode.CancelException;
 import org.apache.geode.internal.cache.GemFireCacheImpl;
 
 /**
- * Indicates that the caching system has 
- * been closed. Can be thrown from almost any method related to regions or the
- * <code>Cache</code> after the cache has been closed.
+ * Indicates that the caching system has been closed. Can be thrown from almost any method related
+ * to regions or the <code>Cache</code> after the cache has been closed.
  *
  *
  *
@@ -30,15 +27,15 @@ import org.apache.geode.internal.cache.GemFireCacheImpl;
  * @since GemFire 3.0
  */
 public class CacheClosedException extends CancelException {
-private static final long serialVersionUID = -6479561694497811262L;
-  
+  private static final long serialVersionUID = -6479561694497811262L;
+
   /**
    * Constructs a new <code>CacheClosedException</code>.
    */
   public CacheClosedException() {
     super();
   }
-  
+
   /**
    * Constructs a new <code>CacheClosedException</code> with a message string.
    *
@@ -52,10 +49,9 @@ private static final long serialVersionUID = -6479561694497811262L;
       initCause(cache.getDisconnectCause());
     }
   }
-  
+
   /**
-   * Constructs a new <code>CacheClosedException</code> with a message string
-   * and a cause.
+   * Constructs a new <code>CacheClosedException</code> with a message string and a cause.
    *
    * @param msg the message string
    * @param cause a causal Throwable
@@ -63,7 +59,7 @@ private static final long serialVersionUID = -6479561694497811262L;
   public CacheClosedException(String msg, Throwable cause) {
     super(msg, cause);
   }
-  
+
   /**
    * Constructs a new <code>CacheClosedException</code> with a cause.
    *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java b/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
index 44e4745..fc4cfc4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheEvent.java
@@ -1,18 +1,16 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 
 package org.apache.geode.cache;
@@ -22,14 +20,12 @@ import org.apache.geode.internal.cache.EnumListenerEvent;
 
 /**
  * A region- or entry-related event affecting the cache.
-   * <P>
-   * Prior to release <code>6.0</code> the <code>NOT_AVAILABLE</code> constant
-   * was used to indicate an object value was not available.
-   * However in <code>6.0</code> generic typing was added
-   * to {@link Region} and since this constant's type will not be an
-   * instance of the generic type <code>V</code> returning it would cause
-   * a ClassCastException. So in <code>6.0</code> and later
-   * <code>null</code> is now used in place of <code>NOT_AVAILABLE</code>.
+ * <P>
+ * Prior to release <code>6.0</code> the <code>NOT_AVAILABLE</code> constant was used to indicate an
+ * object value was not available. However in <code>6.0</code> generic typing was added to
+ * {@link Region} and since this constant's type will not be an instance of the generic type
+ * <code>V</code> returning it would cause a ClassCastException. So in <code>6.0</code> and later
+ * <code>null</code> is now used in place of <code>NOT_AVAILABLE</code>.
  *
  * @see CacheListener
  *
@@ -37,56 +33,66 @@ import org.apache.geode.internal.cache.EnumListenerEvent;
  *
  * @since GemFire 2.0
  */
-public interface CacheEvent<K,V> {
+public interface CacheEvent<K, V> {
 
-  /** Returns the region to which this cached object belongs or
-   * the region that raised this event for <code>RegionEvent</code>s.
-   * @return the region associated with this object or the region that raised
-   * this event.
+  /**
+   * Returns the region to which this cached object belongs or the region that raised this event for
+   * <code>RegionEvent</code>s.
+   * 
+   * @return the region associated with this object or the region that raised this event.
    */
-  public Region<K,V> getRegion();
+  public Region<K, V> getRegion();
 
   /**
    * Return a description of the operation that triggered this event.
+   * 
    * @return the operation that triggered this event.
    * @since GemFire 5.0
    */
   public Operation getOperation();
-  
-  /** Returns the callbackArgument passed to the method that generated this event.
-   * Provided primarily in case this object or region has already been
-   * destroyed. See the {@link Region} interface methods that take a
-   * callbackArgument parameter.
-   * @return the callbackArgument associated with this event. <code>null</code>
-   * is returned if the callback argument is not propagated to the event.
-   * This happens for events given to {@link TransactionListener}
-   * and to {@link CacheListener} on the remote side of a transaction commit.
+
+  /**
+   * Returns the callbackArgument passed to the method that generated this event. Provided primarily
+   * in case this object or region has already been destroyed. See the {@link Region} interface
+   * methods that take a callbackArgument parameter.
+   * 
+   * @return the callbackArgument associated with this event. <code>null</code> is returned if the
+   *         callback argument is not propagated to the event. This happens for events given to
+   *         {@link TransactionListener} and to {@link CacheListener} on the remote side of a
+   *         transaction commit.
    */
   public Object getCallbackArgument();
+
   /**
-   * Returns <code>true</code> if the callback argument is "available".
-   * Not available means that the callback argument may have existed but it could
-   * not be obtained.
-   * Note that {@link #getCallbackArgument} will return <code>null</code>
-   * when this method returns <code>false</code>.
+   * Returns <code>true</code> if the callback argument is "available". Not available means that the
+   * callback argument may have existed but it could not be obtained. Note that
+   * {@link #getCallbackArgument} will return <code>null</code> when this method returns
+   * <code>false</code>.
+   * 
    * @since GemFire 6.0
    */
   public boolean isCallbackArgumentAvailable();
 
-  /** Answer true if this event originated in a cache other than this one.
-   * Answer false if this event originated in this cache.
+  /**
+   * Answer true if this event originated in a cache other than this one. Answer false if this event
+   * originated in this cache.
+   * 
    * @return true if this event originated remotely
    *
    */
   public boolean isOriginRemote();
+
   /**
    * Returns the {@link DistributedMember} that this event originated in.
+   * 
    * @return the member that performed the operation that originated this event.
    * @since GemFire 5.0
    */
   public DistributedMember getDistributedMember();
 
-  /** Answer true if this event resulted from expiration.
+  /**
+   * Answer true if this event resulted from expiration.
+   * 
    * @return true if this event resulted from expiration
    * @deprecated as of GemFire 5.0, use {@link Operation#isExpiration} instead.
    *
@@ -94,11 +100,11 @@ public interface CacheEvent<K,V> {
   @Deprecated
   public boolean isExpiration();
 
-  /** Answers true if this event resulted from a distributed operation;
-   * false if a local operation.
+  /**
+   * Answers true if this event resulted from a distributed operation; false if a local operation.
    * 
-   * This is useful to distinguish between invalidate and localInvalidate, and
-   * destroy and localDestroy.
+   * This is useful to distinguish between invalidate and localInvalidate, and destroy and
+   * localDestroy.
    *
    * @return true if this event resulted from a distributed operation
    * @deprecated as of GemFire 5.0, use {@link Operation#isDistributed} instead.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
index cc39fb3..79591d6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheException.java
@@ -1,18 +1,16 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 package org.apache.geode.cache;
 
@@ -20,34 +18,33 @@ import org.apache.geode.GemFireException;
 
 
 /**
- * A generic exception, which indicates
- * a cache error has occurred. All the other cache exceptions are 
- * subclasses of this class. This class is abstract and therefore only
- * subclasses are instantiated.
+ * A generic exception, which indicates a cache error has occurred. All the other cache exceptions
+ * are subclasses of this class. This class is abstract and therefore only subclasses are
+ * instantiated.
  *
  *
  * @since GemFire 2.0
  */
 public abstract class CacheException extends GemFireException {
   public static final long serialVersionUID = 7699432887938858940L;
-  
+
   /** Constructs a new <code>CacheException</code>. */
   public CacheException() {
     super();
   }
-  
+
   /** Constructs a new <code>CacheException</code> with a message string. */
   public CacheException(String s) {
     super(s);
   }
-  
-  /** Constructs a <code>CacheException</code> with a message string and
-   * a base exception
+
+  /**
+   * Constructs a <code>CacheException</code> with a message string and a base exception
    */
   public CacheException(String s, Throwable cause) {
     super(s, cause);
   }
-  
+
   /** Constructs a <code>CacheException</code> with a cause */
   public CacheException(Throwable cause) {
     super(cause);
@@ -61,9 +58,7 @@ public abstract class CacheException extends GemFireException {
       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);
+      sb.append(result).append(glue).append(causeStr);
       result = sb.toString();
     }
     return result;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
index 610eb4c..ec79aa3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheExistsException.java
@@ -1,49 +1,50 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance with the License. You may obtain a
+ * copy of the License at
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
+ * http://www.apache.org/licenses/LICENSE-2.0
  *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing, software distributed under the License
+ * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express
+ * or implied. See the License for the specific language governing permissions and limitations under
+ * the License.
  */
 
 package org.apache.geode.cache;
 
 
-/** Thrown when attempting to create a {@link Cache} if one already exists.
+/**
+ * Thrown when attempting to create a {@link Cache} if one already exists.
  *
  *
  * @see CacheFactory#create
  * @since GemFire 3.0
  */
 public class CacheExistsException extends CacheException {
-private static final long serialVersionUID = 4090002289325418100L;
+  private static final long serialVersionUID = 4090002289325418100L;
 
   /** The <code>Cache</code> that already exists */
   private final transient Cache cache;
 
-  ///////////////////////  Constructors  ///////////////////////
+  /////////////////////// Constructors ///////////////////////
 
   /**
    * Constructs an instance of <code>CacheExistsException</code> with the specified detail message.
+   * 
    * @param msg the detail message
    */
   public CacheExistsException(Cache cache, String msg) {
     super(msg);
     this.cache = cache;
   }
-  
+
   /**
    * Constructs an instance of <code>CacheExistsException</code> with the specified detail message
    * and cause.
+   * 
    * @param msg the detail message
    * @param cause the causal Throwable
    */
@@ -52,7 +53,7 @@ private static final long serialVersionUID = 4090002289325418100L;
     this.cache = cache;
   }
 
-  ///////////////////////  Instance Methods  ///////////////////////
+  /////////////////////// Instance Methods ///////////////////////
 
   /**
    * Returns the <code>Cache</code> that already exists.