You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by up...@apache.org on 2016/10/24 18:16:49 UTC

[04/55] [abbrv] [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/CacheWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java b/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
index 318fed0..ae4dcb5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheWriter.java
@@ -1,42 +1,41 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.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;
 
-/** A user-defined object defined in the {@link RegionAttributes} that is
- * called synchronously before a region or entry in the cache is
- * modified. The typical use for a <code>CacheWriter</code> is to update a database.
- * Application writers should implement these methods to execute
+/**
+ * A user-defined object defined in the {@link RegionAttributes} that is called synchronously before
+ * a region or entry in the cache is modified. The typical use for a <code>CacheWriter</code> is to
+ * update a database. Application writers should implement these methods to execute
  * application-specific behavior before the cache is modified.
  *
- * <p>Before the region is updated via a put, create, or destroy operation,
- * GemFire will call a <code>CacheWriter</code> that is installed anywhere in any
- * participating cache for that region, preferring a local <code>CacheWriter</code>
- * if there is one. Usually there will be only one <code>CacheWriter</code> in
- * the distributed system. If there are multiple <code>CacheWriter</code>s
- * available in the distributed system, the GemFire
- * implementation always prefers one that is stored locally, or else picks one
- * arbitrarily; in any case only one <code>CacheWriter</code> will be invoked.
+ * <p>
+ * Before the region is updated via a put, create, or destroy operation, GemFire will call a
+ * <code>CacheWriter</code> that is installed anywhere in any participating cache for that region,
+ * preferring a local <code>CacheWriter</code> if there is one. Usually there will be only one
+ * <code>CacheWriter</code> in the distributed system. If there are multiple
+ * <code>CacheWriter</code>s available in the distributed system, the GemFire implementation always
+ * prefers one that is stored locally, or else picks one arbitrarily; in any case only one
+ * <code>CacheWriter</code> will be invoked.
  *
- * <p>The <code>CacheWriter</code> is capable of aborting the update to the cache by throwing
- * a <code>CacheWriterException</code>. This exception or any runtime exception
- * thrown by the <code>CacheWriter</code> will abort the operation and the
- * exception will be propagated to the initiator of the operation, regardless
- * of whether the initiator is in the same VM as the <code>CacheWriter</code>.
+ * <p>
+ * The <code>CacheWriter</code> is capable of aborting the update to the cache by throwing a
+ * <code>CacheWriterException</code>. This exception or any runtime exception thrown by the
+ * <code>CacheWriter</code> will abort the operation and the exception will be propagated to the
+ * initiator of the operation, regardless of whether the initiator is in the same VM as the
+ * <code>CacheWriter</code>.
  *
  *
  * @see AttributesFactory#setCacheWriter
@@ -44,107 +43,88 @@ package org.apache.geode.cache;
  * @see AttributesMutator#setCacheWriter
  * @since GemFire 3.0
  */
-public interface CacheWriter<K,V> extends CacheCallback {
+public interface CacheWriter<K, V> extends CacheCallback {
 
   /**
-   * Called before an entry is updated. The entry update is initiated by a <code>put</code>
-   * or a <code>get</code> that causes the loader 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
+   * Called before an entry is updated. The entry update is initiated by a <code>put</code> or a
+   * <code>get</code> that causes the loader 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
+   * @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<K,V> event)
-  throws CacheWriterException;
+  public void beforeUpdate(EntryEvent<K, V> event) throws CacheWriterException;
 
-  /** 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 by evaluating the {@link CacheEvent#getOperation() Operation}'s {@link Operation#isLoad()} method.
-   * 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.
+  /**
+   * 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 by evaluating the
+   * {@link CacheEvent#getOperation() Operation}'s {@link Operation#isLoad()} method. 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
+   * @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<K,V> event)
-  throws CacheWriterException;
+  public void beforeCreate(EntryEvent<K, V> event) throws CacheWriterException;
 
   /**
-   * 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)}.
+   * 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
+   * @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<K,V> event)
-  throws CacheWriterException;
+  public void beforeDestroy(EntryEvent<K, V> event) throws CacheWriterException;
 
   /**
-   * 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
-   * {@link Region#close}, {@link Cache#close}, or {@link Region#localDestroyRegion()}.  However, the
-   * {@link Region#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 Region#close}.
-   *<p>
-   * WARNING: This method should not destroy or create any regions itself or a
-   * deadlock will occur.
+   * 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
+   * {@link Region#close}, {@link Cache#close}, or {@link Region#localDestroyRegion()}. However, the
+   * {@link Region#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 Region#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 operation
+   * @param event a RegionEvent that provides information about the operation
    *
-   * @throws CacheWriterException
-   *         if thrown, will abort the operation in progress, and the
-   *         exception will be propagated back to the caller that
-   *         initiated the operation
+   * @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<K,V> event)
-  throws CacheWriterException;
+  public void beforeRegionDestroy(RegionEvent<K, V> event) throws CacheWriterException;
 
   /**
-   * 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. 
+   * 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.
    * 
-   *<p>
-   * WARNING: This method should not clear/destroy any regions 
+   * <p>
+   * WARNING: This method should not clear/destroy any regions
    * 
    *
-   * @param event
-   *        a RegionEvent that provides information about the operation
+   * @param event a RegionEvent that provides information about the operation
    *
-   * @throws CacheWriterException
-   *         if thrown, will abort the operation in progress, and the
-   *         exception will be propagated back to the caller that
-   *         initiated the operation
+   * @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#clear
    */
-  public void beforeRegionClear(RegionEvent<K,V> event)
-  throws CacheWriterException;
+  public void beforeRegionClear(RegionEvent<K, V> event) throws CacheWriterException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
index 081cbc3..59bdab1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheWriterException.java
@@ -1,26 +1,24 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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;
 
 /**
- * An exception thrown by a <code>CacheWriter</code> method. This exception
- * is propagated back to the caller that initiated modification of the
- * cache, even if the caller is not in the same cache VM.
+ * An exception thrown by a <code>CacheWriter</code> method. This exception is propagated back to
+ * the caller that initiated modification of the cache, even if the caller is not in the same cache
+ * VM.
  *
  *
  * @see CacheWriter
@@ -32,35 +30,37 @@ package org.apache.geode.cache;
  * @since GemFire 3.0
  */
 public class CacheWriterException extends OperationAbortedException {
-private static final long serialVersionUID = -2872212342970454458L;
-  
+  private static final long serialVersionUID = -2872212342970454458L;
+
   /**
    * Creates a new instance of <code>CacheWriterException</code>.
    */
-  public CacheWriterException() {
-  }
-  
-  
+  public CacheWriterException() {}
+
+
   /**
    * Constructs an instance of <code>CacheWriterException</code> with the specified detail message.
+   * 
    * @param msg the detail message
    */
   public CacheWriterException(String msg) {
     super(msg);
   }
-  
+
   /**
    * Constructs an instance of <code>CacheWriterException</code> with the specified detail message
    * and cause.
+   * 
    * @param msg the detail message
    * @param cause the causal Throwable
    */
   public CacheWriterException(String msg, Throwable cause) {
     super(msg, cause);
   }
-  
+
   /**
    * Constructs an instance of <code>CacheWriterException</code> with the specified cause.
+   * 
    * @param cause the causal Throwable
    */
   public CacheWriterException(Throwable cause) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java b/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
index c6db5c7..7883d05 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheXmlException.java
@@ -1,26 +1,23 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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 a problem is encountered while parsing a <A
- * href="package-summary.html#declarative">declarative caching XML
- * file</A>.  Examples of such problems are a malformed XML file or
- * the inability to load a {@link Declarable} class.
+ * Thrown when a problem is encountered while parsing a
+ * <A href="package-summary.html#declarative">declarative caching XML file</A>. Examples of such
+ * problems are a malformed XML file or the inability to load a {@link Declarable} class.
  *
  * @see CacheFactory#create
  *
@@ -28,19 +25,17 @@ package org.apache.geode.cache;
  * @since GemFire 3.0
  */
 public class CacheXmlException extends CacheRuntimeException {
-private static final long serialVersionUID = -4343870964883131754L;
+  private static final long serialVersionUID = -4343870964883131754L;
 
   /**
-   * Creates a new <code>CacheXmlException</code> with the given
-   * description and cause.
+   * Creates a new <code>CacheXmlException</code> with the given description and cause.
    */
   public CacheXmlException(String message, Throwable cause) {
     super(message, cause);
   }
 
   /**
-   * Creates a new <code>CacheXmlException</code> with the given
-   * description.
+   * Creates a new <code>CacheXmlException</code> with the given description.
    */
   public CacheXmlException(String message) {
     super(message);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java b/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
index 321791e..648882e 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/ClientSession.java
@@ -1,31 +1,29 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.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;
 
 /**
- * Class <code>ClientSession</code> represents a client connection on the
- * server. <code>ClientSessions</code> can be used from the cache server to
- * perform interest registrations and unregistrations on behalf of clients.
- * <code>ClientSessions</code> are only available on the cache server.
+ * Class <code>ClientSession</code> represents a client connection on the server.
+ * <code>ClientSessions</code> can be used from the cache server to perform interest registrations
+ * and unregistrations on behalf of clients. <code>ClientSessions</code> are only available on the
+ * cache server.
  * 
  * <p>
- * The ClientSession is often used in conjunction with a callback
- * <code>EntryEvent</code> as shown below.
+ * The ClientSession is often used in conjunction with a callback <code>EntryEvent</code> as shown
+ * below.
  * 
  * <pre>
  * String durableClientId = ...; // Some part of the event's key or value would contain this id
@@ -36,8 +34,7 @@ package org.apache.geode.cache;
  * </pre>
  * 
  * @since GemFire 6.0
- * @see org.apache.geode.cache.server.CacheServer#getClientSession(String)
- *      getClientSession
+ * @see org.apache.geode.cache.server.CacheServer#getClientSession(String) getClientSession
  * @see org.apache.geode.cache.server.CacheServer#getClientSession(org.apache.geode.distributed.DistributedMember)
  *      getClientSession
  *
@@ -47,146 +44,103 @@ public interface ClientSession {
   /**
    * Registers interest in a particular region and key
    * 
-   * @param regionName
-   *          The name of the region in which to register interest
-   * @param keyOfInterest
-   *          The key on which to register interest
-   * @param policy
-   *          The {@link org.apache.geode.cache.InterestResultPolicy}. Note:
-   *          For the special token 'ALL_KEYS' and lists of keys, values are not
-   *          pushed to the client.
-   * @param isDurable
-   *          Whether the interest is durable
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to register interest
+   * @param keyOfInterest The key on which to register interest
+   * @param policy The {@link org.apache.geode.cache.InterestResultPolicy}. Note: For the special
+   *        token 'ALL_KEYS' and lists of keys, values are not pushed to the client.
+   * @param isDurable Whether the interest is durable
+   * @throws IllegalStateException if this is not the primary server for the given client
    */
-  public void registerInterest(String regionName, Object keyOfInterest,
-      InterestResultPolicy policy, boolean isDurable);
+  public void registerInterest(String regionName, Object keyOfInterest, InterestResultPolicy policy,
+      boolean isDurable);
 
   /**
    * Registers interest in a particular region and key
    *
-   * @param regionName
-   *          The name of the region in which to register interest
-   * @param keyOfInterest
-   *          The key to on which to register interest
-   * @param policy
-   *          The {@link org.apache.geode.cache.InterestResultPolicy}. Note:
-   *          For the special token 'ALL_KEYS' and lists of keys, values are not
-   *          pushed to the client.
-   * @param isDurable
-   *          Whether the interest is durable
-   * @param receiveValues
-   *          Whether to receive create or update events as invalidates similar
-   *          to notify-by-subscription false. The default is true.
-   * @throws IllegalStateException
-   *          if this is not the primary server for the given client
+   * @param regionName The name of the region in which to register interest
+   * @param keyOfInterest The key to on which to register interest
+   * @param policy The {@link org.apache.geode.cache.InterestResultPolicy}. Note: For the special
+   *        token 'ALL_KEYS' and lists of keys, values are not pushed to the client.
+   * @param isDurable Whether the interest is durable
+   * @param receiveValues Whether to receive create or update events as invalidates similar to
+   *        notify-by-subscription false. The default is true.
+   * @throws IllegalStateException if this is not the primary server for the given client
    * @since GemFire 6.5
    */
-  public void registerInterest(String regionName, Object keyOfInterest,
-      InterestResultPolicy policy, boolean isDurable, boolean receiveValues);
-  
+  public void registerInterest(String regionName, Object keyOfInterest, InterestResultPolicy policy,
+      boolean isDurable, boolean receiveValues);
+
   /**
    * Registers interest in a particular region and regular expression
    *
-   * @param regionName
-   *          The name of the region in which to register interest
-   * @param regex
-   *          The regular expression on which to register interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @throws IllegalStateException
-   *          if this is not the primary server for the given client
+   * @param regionName The name of the region in which to register interest
+   * @param regex The regular expression on which to register interest
+   * @param isDurable Whether the interest is durable
+   * @throws IllegalStateException if this is not the primary server for the given client
    */
-  public void registerInterestRegex(String regionName, String regex,
-      boolean isDurable);
-  
+  public void registerInterestRegex(String regionName, String regex, boolean isDurable);
+
   /**
    * Registers interest in a particular region and regular expression
    * 
-   * @param regionName
-   *          The name of the region in which to register interest
-   * @param regex
-   *          The regular expression to on which to register interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @param receiveValues
-   *          Whether to receive create or update events as invalidates similar
-   *          to notify-by-subscription false. The default is true.
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to register interest
+   * @param regex The regular expression to on which to register interest
+   * @param isDurable Whether the interest is durable
+   * @param receiveValues Whether to receive create or update events as invalidates similar to
+   *        notify-by-subscription false. The default is true.
+   * @throws IllegalStateException if this is not the primary server for the given client
    * @since GemFire 6.5
    */
-  public void registerInterestRegex(String regionName, String regex,
-      boolean isDurable, boolean receiveValues);
+  public void registerInterestRegex(String regionName, String regex, boolean isDurable,
+      boolean receiveValues);
 
   /**
    * Unregisters interest in a particular region and key
    * 
-   * @param regionName
-   *          The name of the region in which to unregister interest
-   * @param keyOfInterest
-   *          The key on which to unregister interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to unregister interest
+   * @param keyOfInterest The key on which to unregister interest
+   * @param isDurable Whether the interest is durable
+   * @throws IllegalStateException if this is not the primary server for the given client
    */
-  public void unregisterInterest(String regionName, Object keyOfInterest,
-      boolean isDurable);
-  
+  public void unregisterInterest(String regionName, Object keyOfInterest, boolean isDurable);
+
   /**
    * Unregisters interest in a particular region and key
    * 
-   * @param regionName
-   *          The name of the region in which to unregister interest
-   * @param keyOfInterest
-   *          The key on which to unregister interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @param receiveValues
-   *          Whether to receive create or update events as invalidates similar
-   *          to notify-by-subscription false. The default is true.
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to unregister interest
+   * @param keyOfInterest The key on which to unregister interest
+   * @param isDurable Whether the interest is durable
+   * @param receiveValues Whether to receive create or update events as invalidates similar to
+   *        notify-by-subscription false. The default is true.
+   * @throws IllegalStateException if this is not the primary server for the given client
    * @since GemFire 6.5
    */
-  public void unregisterInterest(String regionName, Object keyOfInterest,
-      boolean isDurable, boolean receiveValues);
+  public void unregisterInterest(String regionName, Object keyOfInterest, boolean isDurable,
+      boolean receiveValues);
 
   /**
    * Unregisters interest in a particular region and regular expression
    * 
-   * @param regionName
-   *          The name of the region in which to unregister interest
-   * @param regex
-   *          The regular expression on which to unregister interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to unregister interest
+   * @param regex The regular expression on which to unregister interest
+   * @param isDurable Whether the interest is durable
+   * @throws IllegalStateException if this is not the primary server for the given client
    */
-  public void unregisterInterestRegex(String regionName, String regex,
-      boolean isDurable);
+  public void unregisterInterestRegex(String regionName, String regex, boolean isDurable);
 
   /**
    * Unregisters interest in a particular region and regular expression
    * 
-   * @param regionName
-   *          The name of the region in which to unregister interest
-   * @param regex
-   *          The regular expression on which to unregister interest
-   * @param isDurable
-   *          Whether the interest is durable
-   * @param receiveValues
-   *          Whether to receive create or update events as invalidates similar
-   *          to notify-by-subscription false. The default is true.
-   * @throws IllegalStateException
-   *           if this is not the primary server for the given client
+   * @param regionName The name of the region in which to unregister interest
+   * @param regex The regular expression on which to unregister interest
+   * @param isDurable Whether the interest is durable
+   * @param receiveValues Whether to receive create or update events as invalidates similar to
+   *        notify-by-subscription false. The default is true.
+   * @throws IllegalStateException if this is not the primary server for the given client
    * @since GemFire 6.5
    */
-  public void unregisterInterestRegex(String regionName, String regex,
-      boolean isDurable, boolean receiveValues);
+  public void unregisterInterestRegex(String regionName, String regex, boolean isDurable,
+      boolean receiveValues);
 
   /**
    * Returns whether this server is the primary for this client

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
index be3575f..282c9c5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitConflictException.java
@@ -1,23 +1,22 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.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 a commit fails due to a write conflict.
+/**
+ * Thrown when a commit fails due to a write conflict.
  *
  *
  * @see CacheTransactionManager#commit
@@ -27,30 +26,34 @@ public class CommitConflictException extends TransactionException {
   private static final long serialVersionUID = -1491184174802596675L;
 
   /**
-   * Constructs an instance of <code>CommitConflictException</code> with the specified detail message.
+   * Constructs an instance of <code>CommitConflictException</code> with the specified detail
+   * message.
+   * 
    * @param msg the detail message
    */
   public CommitConflictException(String msg) {
     super(msg);
   }
-  
+
   /**
-   * Constructs an instance of <code>CommitConflictException</code> with the specified detail message
-   * and cause.
+   * Constructs an instance of <code>CommitConflictException</code> with the specified detail
+   * message and cause.
+   * 
    * @param msg the detail message
    * @param cause the causal Throwable
    */
   public CommitConflictException(String msg, Throwable cause) {
     super(msg, cause);
   }
-  
+
   /**
    * Constructs an instance of <code>CommitConflictException</code> with the specified cause.
+   * 
    * @param cause the causal Throwable
    * @since GemFire 6.5
    */
   public CommitConflictException(Throwable cause) {
     super(cause);
   }
-  
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
index eea0b56..84e4953 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitDistributionException.java
@@ -1,46 +1,42 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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;
 
 import java.util.*;
 
 /**
- * Indicates that an attempt to notify required participants of a transaction 
- * involving one or more regions that are configured with {@link 
- * MembershipAttributes} may have failed. The commit itself was completed but
- * one or more regions affected by the transaction have one or more required
- * roles that were not successfully notified. Failure may be caused by 
- * departure of one or more required roles while sending the operation to
- * them. This exception will contain one {@link RegionDistributionException}
- * for every region that had a reliability failure. Details of the failed
- * {@link MembershipAttributes#getRequiredRoles required roles} are provided
- *  in each RegionDistributionException.
+ * Indicates that an attempt to notify required participants of a transaction involving one or more
+ * regions that are configured with {@link MembershipAttributes} may have failed. The commit itself
+ * was completed but one or more regions affected by the transaction have one or more required roles
+ * that were not successfully notified. Failure may be caused by departure of one or more required
+ * roles while sending the operation to them. This exception will contain one
+ * {@link RegionDistributionException} for every region that had a reliability failure. Details of
+ * the failed {@link MembershipAttributes#getRequiredRoles required roles} are provided in each
+ * RegionDistributionException.
  *
  * @since GemFire 5.0
  */
 public class CommitDistributionException extends TransactionException {
   private static final long serialVersionUID = -3517820638706581823L;
-  /** 
-   * The RegionDistributionExceptions for every region that had a reliability
-   * failure during distribution of the operation.
+  /**
+   * The RegionDistributionExceptions for every region that had a reliability failure during
+   * distribution of the operation.
    */
   private Set regionDistributionExceptions = Collections.EMPTY_SET;
-  
-  /** 
+
+  /**
    * Constructs a <code>CommitDistributionException</code> with a message.
    *
    * @param s the String message
@@ -48,14 +44,13 @@ public class CommitDistributionException extends TransactionException {
   public CommitDistributionException(String s) {
     super(s);
   }
-  
-  /** 
-   * Constructs a <code>CommitDistributionException</code> with a message and
-   * a cause.
+
+  /**
+   * Constructs a <code>CommitDistributionException</code> with a message and a cause.
    *
    * @param s the String message
-   * @param regionDistributionExceptions set of RegionDistributionExceptions
-   * for each region that had a reliability failure
+   * @param regionDistributionExceptions set of RegionDistributionExceptions for each region that
+   *        had a reliability failure
    */
   public CommitDistributionException(String s, Set regionDistributionExceptions) {
     super(s);
@@ -64,17 +59,17 @@ public class CommitDistributionException extends TransactionException {
       this.regionDistributionExceptions = Collections.EMPTY_SET;
     }
   }
-  
-  /** 
-   * Returns set of RegionDistributionExceptions for each region that had a 
-   * reliability failure during distribution of the operation.
+
+  /**
+   * Returns set of RegionDistributionExceptions for each region that had a reliability failure
+   * during distribution of the operation.
    *
-   * @return set of RegionDistributionExceptions for each region that had a 
-   * reliability failure during distribution of the operation
+   * @return set of RegionDistributionExceptions for each region that had a reliability failure
+   *         during distribution of the operation
    */
   public Set getRegionDistributionExceptions() {
     return this.regionDistributionExceptions;
   }
-  
+
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java b/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
index 26544e8..d1e3bea 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CommitIncompleteException.java
@@ -1,27 +1,26 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.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 a commit fails to complete due to errors
+ * 
  * @since GemFire 5.7
  */
 public class CommitIncompleteException extends TransactionException {
-private static final long serialVersionUID = 1017741483744420800L;
+  private static final long serialVersionUID = 1017741483744420800L;
 
   public CommitIncompleteException(String message) {
     super(message);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java b/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
index 25f89eb..a387044 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CustomExpiry.java
@@ -1,41 +1,39 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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;
 
 /**
- * This is the contract that a <code>custom-expiry</code> element must honor.
- * It determines the expiration characteristics for a specific entry in a region.
- * <p>Note that if you wish to refer to an implementation of this interface in XML,
- * the implementation must also implement the Declarable interface.
+ * This is the contract that a <code>custom-expiry</code> element must honor. It determines the
+ * expiration characteristics for a specific entry in a region.
+ * <p>
+ * Note that if you wish to refer to an implementation of this interface in XML, the implementation
+ * must also implement the Declarable interface.
  * 
  *
  */
-public interface CustomExpiry<K,V> extends CacheCallback {
+public interface CustomExpiry<K, V> extends CacheCallback {
 
   /**
-   * Calculate the expiration for a given entry.
-   * Returning null indicates that the
-   * default for the region should be used.
+   * Calculate the expiration for a given entry. Returning null indicates that the default for the
+   * region should be used.
    * <p>
    * The entry parameter should not be used after this method invocation completes.
+   * 
    * @param entry the entry to calculate the expiration for
-   * @return the expiration to be used, null if the region's defaults should be
-   * used.
+   * @return the expiration to be used, null if the region's defaults should be used.
    */
-  public ExpirationAttributes getExpiry(Region.Entry<K,V> entry);
+  public ExpirationAttributes getExpiry(Region.Entry<K, V> entry);
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
index 8d1c2e0..e761eb2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DataPolicy.java
@@ -1,36 +1,46 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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;
+
 import org.apache.geode.internal.i18n.LocalizedStrings;
 
 import java.io.*;
 
 /**
- * Enumerated type for region data policy.
- * The data policy specifies how this local cache will handle the data for a region.
+ * Enumerated type for region data policy. The data policy specifies how this local cache will
+ * handle the data for a region.
  * <ol>
- * <li><code>EMPTY</code> causes data to never be stored in local memory. The region will always appear empty. It can be used to for zero footprint producers that only want to distribute their data to others and for zero footprint consumers that only want to see events.
- * <li><code>NORMAL</code> causes data that this region is interested in to be stored in local memory. It allows the contents in this cache to differ from other caches.
- * <li><code>PARTITION</code> causes data that this region holds to be spread across processes.  The amount of data held in this cache is configured in {@link PartitionAttributes} with a {@link PartitionAttributesFactory}.
- * <li><code>PERSISTENT_PARTITION</code> in addition to <code>PARTITION</code> also causes data to be stored to disk. The region initialization uses the data stored on disk.
- * <li><code>REPLICATE</code> causes data that this region is interested in to be stored in local memory. A distributed region will be initialized with the data from other caches. On distributed region operations that would cause the contents to differ with other caches are not allowed. This policy is allowed on local scope region but it behaves the same as <code>NORMAL</code>.
- * <li><code>PERSISTENT_REPLICATE</code> in addition to <code>REPLICATE</code> also causes data to be stored to disk. The region initialization uses the data stored on disk. Note that the persistence applies to both local scope and distributed scope.
+ * <li><code>EMPTY</code> causes data to never be stored in local memory. The region will always
+ * appear empty. It can be used to for zero footprint producers that only want to distribute their
+ * data to others and for zero footprint consumers that only want to see events.
+ * <li><code>NORMAL</code> causes data that this region is interested in to be stored in local
+ * memory. It allows the contents in this cache to differ from other caches.
+ * <li><code>PARTITION</code> causes data that this region holds to be spread across processes. The
+ * amount of data held in this cache is configured in {@link PartitionAttributes} with a
+ * {@link PartitionAttributesFactory}.
+ * <li><code>PERSISTENT_PARTITION</code> in addition to <code>PARTITION</code> also causes data to
+ * be stored to disk. The region initialization uses the data stored on disk.
+ * <li><code>REPLICATE</code> causes data that this region is interested in to be stored in local
+ * memory. A distributed region will be initialized with the data from other caches. On distributed
+ * region operations that would cause the contents to differ with other caches are not allowed. This
+ * policy is allowed on local scope region but it behaves the same as <code>NORMAL</code>.
+ * <li><code>PERSISTENT_REPLICATE</code> in addition to <code>REPLICATE</code> also causes data to
+ * be stored to disk. The region initialization uses the data stored on disk. Note that the
+ * persistence applies to both local scope and distributed scope.
  * </ol>
  *
  *
@@ -46,96 +56,103 @@ public class DataPolicy implements java.io.Serializable {
   private static final DataPolicy[] VALUES = new DataPolicy[11];
 
   /**
-   * Data is never stored in local memory.
-   * The region will always be empty locally.
-   * It can be used to for zero footprint producers that only want to distribute
-   * their data to others
-   * and for zero footprint consumers that only want to see events.
+   * Data is never stored in local memory. The region will always be empty locally. It can be used
+   * to for zero footprint producers that only want to distribute their data to others and for zero
+   * footprint consumers that only want to see events.
    */
   public static final DataPolicy EMPTY = new DataPolicy(0, "EMPTY");
 
   /**
-   * Allows the contents in this cache to differ from other caches.<p>
+   * Allows the contents in this cache to differ from other caches.
+   * <p>
    * Data that this region is interested in is stored in local memory.
    */
   public static final DataPolicy NORMAL = new DataPolicy(1, "NORMAL");
 
   /**
-   * The region will be initialized with the data from other caches and accepts
-   * any new entries created in other caches.<p>
-   * Operations that would cause the contents to differ with other caches
-   * are not allowed.<p>
+   * The region will be initialized with the data from other caches and accepts any new entries
+   * created in other caches.
+   * <p>
+   * Operations that would cause the contents to differ with other caches are not allowed.
+   * <p>
    * Data that this region is interested in is stored in local memory.
    */
   public static final DataPolicy REPLICATE = new DataPolicy(2, "REPLICATE");
 
   /**
-   * In addition to <code>REPLICATE</code> also causes data to be stored to
-   * disk. The region initialization may use the data stored on disk.
+   * In addition to <code>REPLICATE</code> also causes data to be stored to disk. The region
+   * initialization may use the data stored on disk.
    */
   public static final DataPolicy PERSISTENT_REPLICATE = new DataPolicy(3, "PERSISTENT_REPLICATE");
-  
-  
+
+
   /**
-   * Data in this region may be spread across a number of processes.  This is
-   * further configured with {@link PartitionAttributes partitioning attributes}
+   * Data in this region may be spread across a number of processes. This is further configured with
+   * {@link PartitionAttributes partitioning attributes}
    */
   public static final DataPolicy PARTITION = new DataPolicy(4, "PARTITION");
 
   /**
-  * In addition to <code>NORMAL</code>, contents inside of this cache are
-  * (partially) initialized with data from other caches, if available.
-  */
+   * In addition to <code>NORMAL</code>, contents inside of this cache are (partially) initialized
+   * with data from other caches, if available.
+   */
   public static final DataPolicy PRELOADED = new DataPolicy(5, "PRELOADED");
 
   /**
-   * In addition to <code>PARTITION</code> also causes data to be stored to
-   * disk. The region initialization may use the data stored on disk.
+   * In addition to <code>PARTITION</code> also causes data to be stored to disk. The region
+   * initialization may use the data stored on disk.
+   * 
    * @since GemFire 6.5
    */
   public static final DataPolicy PERSISTENT_PARTITION = new DataPolicy(6, "PERSISTENT_PARTITION");
-  
-   /**
+
+  /**
    * The data policy used by default; it is {@link #NORMAL}.
    */
   public static final DataPolicy DEFAULT = NORMAL;
 
-    
+
   /** The name of this mirror type. */
   private final transient String name;
-    
+
   /** used as ordinal to represent this DataPolicy */
   public final byte ordinal;
 
   private Object readResolve() throws ObjectStreamException {
-    return VALUES[ordinal];  // Canonicalize
+    return VALUES[ordinal]; // Canonicalize
   }
-    
-    
+
+
   /** Creates a new instance of DataPolicy. */
   private DataPolicy(int ordinal, String name) {
     if (ordinal >= VALUES.length) {
-      throw new IllegalArgumentException(LocalizedStrings.DataPolicy_ONLY_0_DATAPOLICIES_MAY_BE_DEFINED.toLocalizedString(Integer.valueOf(VALUES.length+1)));
+      throw new IllegalArgumentException(
+          LocalizedStrings.DataPolicy_ONLY_0_DATAPOLICIES_MAY_BE_DEFINED
+              .toLocalizedString(Integer.valueOf(VALUES.length + 1)));
     }
     if (VALUES[ordinal] != null) {
-      throw new IllegalArgumentException(LocalizedStrings.DataPolicy_ORDINAL_0_IS_ALREADY_DEFINED_BY_1.toLocalizedString(new Object[] {Integer.valueOf(ordinal), VALUES[ordinal]}));
+      throw new IllegalArgumentException(
+          LocalizedStrings.DataPolicy_ORDINAL_0_IS_ALREADY_DEFINED_BY_1
+              .toLocalizedString(new Object[] {Integer.valueOf(ordinal), VALUES[ordinal]}));
     }
     this.name = name;
-    this.ordinal = (byte)(ordinal & 0xff);
+    this.ordinal = (byte) (ordinal & 0xff);
     VALUES[this.ordinal] = this;
   }
-    
+
   /** Return the DataPolicy represented by specified ordinal */
   public static DataPolicy fromOrdinal(byte ordinal) {
     return VALUES[ordinal];
   }
-    
-    
-  /** Return true if regions with this policy store data locally.<p>
-   * Although DataPolicy {@link #PARTITION} will return true to this query,
-   * it is possible to turn off local storage with
-   * {@link PartitionAttributesFactory#setLocalMaxMemory(int)} by setting
-   * localMaxMemory to zero. 
+
+
+  /**
+   * Return true if regions with this policy store data locally.
+   * <p>
+   * Although DataPolicy {@link #PARTITION} will return true to this query, it is possible to turn
+   * off local storage with {@link PartitionAttributesFactory#setLocalMaxMemory(int)} by setting
+   * localMaxMemory to zero.
+   * 
    * @return true if regions with this policy store data locally.
    * @see #NORMAL
    * @see #PRELOADED
@@ -148,7 +165,9 @@ public class DataPolicy implements java.io.Serializable {
     return this != EMPTY;
   }
 
-  /** Return whether this policy does replication.
+  /**
+   * Return whether this policy does replication.
+   * 
    * @return true if this policy does replication.
    * @see #REPLICATE
    * @see #PERSISTENT_REPLICATE
@@ -156,8 +175,10 @@ public class DataPolicy implements java.io.Serializable {
   public boolean withReplication() {
     return this == REPLICATE || this == PERSISTENT_REPLICATE;
   }
-  
-  /** Return whether this policy does persistence.
+
+  /**
+   * Return whether this policy does persistence.
+   * 
    * @return true if this policy does persistence.
    * @see #PERSISTENT_PARTITION
    * @see #PERSISTENT_REPLICATE
@@ -167,7 +188,9 @@ public class DataPolicy implements java.io.Serializable {
     return this == PERSISTENT_PARTITION || this == PERSISTENT_REPLICATE;
   }
 
-  /** Return whether this policy does partitioning.
+  /**
+   * Return whether this policy does partitioning.
+   * 
    * @return true if this policy does partitioning
    * @see #PARTITION
    * @see #PERSISTENT_PARTITION
@@ -177,7 +200,9 @@ public class DataPolicy implements java.io.Serializable {
     return this == PARTITION || this == PERSISTENT_PARTITION;
   }
 
-  /** Return whether this policy does preloaded.
+  /**
+   * Return whether this policy does preloaded.
+   * 
    * @return true if this policy does preloaded.
    * @see #PRELOADED
    * @since GemFire 6.5
@@ -188,65 +213,79 @@ public class DataPolicy implements java.io.Serializable {
 
   /**
    * Return true if this policy is {@link #EMPTY}.
+   * 
    * @return true if this policy is {@link #EMPTY}.
    * @deprecated from version 6.5 forward please use withStorage()
    */
   public boolean isEmpty() {
     return this == EMPTY;
   }
+
   /**
    * Return true if this policy is {@link #NORMAL}.
+   * 
    * @return true if this policy is {@link #NORMAL}.
    * @deprecated from version 6.5 forward please use an identity comparison instead of this method
    */
   public boolean isNormal() {
     return this == NORMAL;
   }
+
   /**
    * Return true if this policy is {@link #PRELOADED}.
+   * 
    * @return true if this policy is {@link #PRELOADED}
    * @deprecated from version 6.5 forward please use withPreloaded()
    */
   public boolean isPreloaded() {
     return this == PRELOADED;
   }
+
   /**
    * Return true if this policy is the default.
+   * 
    * @return true if this policy is the default.
    * @deprecated from version 6.5 forward please use an identity comparison instead of this method
    */
   public boolean isDefault() {
     return this == DEFAULT;
   }
+
   /**
    * Return true if this policy is {@link #REPLICATE}.
+   * 
    * @return true if this policy is {@link #REPLICATE}.
    * @deprecated from version 6.5 forward please use withReplication()
    */
   public boolean isReplicate() {
     return this == REPLICATE;
   }
+
   /**
    * Return true if this policy is {@link #PERSISTENT_REPLICATE}.
+   * 
    * @return true if this policy is {@link #PERSISTENT_REPLICATE}.
    * @deprecated from version 6.5 forward please use withPersistence() and withReplication()
    */
   public boolean isPersistentReplicate() {
     return this == PERSISTENT_REPLICATE;
   }
-  
+
   /**
    * Return true if this policy is {@link #PARTITION}.
+   * 
    * @return true if this policy is {@link #PARTITION}
    * @deprecated from version 6.5 forward please use withPartitioning()
    */
   public boolean isPartition() {
     return this == PARTITION;
   }
-  
-  /** Returns a string representation for this data policy.
-     * @return the name of this data policy.
-     */
+
+  /**
+   * Returns a string representation for this data policy.
+   * 
+   * @return the name of this data policy.
+   */
   @Override
   public String toString() {
     return this.name;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Declarable.java b/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
index 113d098..57e1e63 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Declarable.java
@@ -1,35 +1,33 @@
 /*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more contributor license
+ * agreements. See the NOTICE file distributed with this work for additional information regarding
+ * copyright ownership. The ASF licenses this file to You under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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;
 
 import java.util.Properties;
 
-/** 
+/**
  * An object that can be described in a declarative caching XML file.
  *
  * <p>
  *
- * Any user-defined object in the declarative caching xml file
- * should implement this interface in order to be constructed.
+ * Any user-defined object in the declarative caching xml file should implement this interface in
+ * order to be constructed.
  *
  * <p>
  *
- * For example, the user can declare a <code>CacheLoader</code> in a declarative
- * XML file as follows:
+ * For example, the user can declare a <code>CacheLoader</code> in a declarative XML file as
+ * follows:
  *
  * <pre>
  *        &lt;cache-loader&gt;
@@ -42,12 +40,10 @@ import java.util.Properties;
  *
  * <p>
  *
- * In this case, <code>com.company.app.DBLoader</code> must 
- * implement both the {@link CacheLoader} and <code>Declarable</code>
- * interfaces. The cache service will construct a
- * <code>com.company.app.DBLoader</code> object by invoking the loader's
- * zero-argument constructor and then calling the {@link #init} method
- * to pass in the parameters.
+ * In this case, <code>com.company.app.DBLoader</code> must implement both the {@link CacheLoader}
+ * and <code>Declarable</code> interfaces. The cache service will construct a
+ * <code>com.company.app.DBLoader</code> object by invoking the loader's zero-argument constructor
+ * and then calling the {@link #init} method to pass in the parameters.
  *
  * <P>
  *
@@ -60,17 +56,13 @@ import java.util.Properties;
 public interface Declarable {
 
   /**
-   * Initializes a user-defined object using the given properties.
-   * Note that any uncaught exception thrown by this method will cause
-   * the <code>Cache</code> initialization to fail.
+   * Initializes a user-defined object using the given properties. Note that any uncaught exception
+   * thrown by this method will cause the <code>Cache</code> initialization to fail.
    *
-   * @param props 
-   *        Contains the parameters declared in the declarative xml
-   *        file.
+   * @param props Contains the parameters declared in the declarative xml file.
    *
-   * @throws IllegalArgumentException
-   *         If one of the configuration options in <code>props</code>
-   *         is illegal or malformed.
+   * @throws IllegalArgumentException If one of the configuration options in <code>props</code> is
+   *         illegal or malformed.
    */
   public void init(Properties props);
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java b/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
index 9571f93..e77e485 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskAccessException.java
@@ -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;
 
@@ -29,14 +27,14 @@ public class DiskAccessException extends CacheRuntimeException {
   private static final long serialVersionUID = 5799100281147167888L;
 
   private transient boolean isRemote;
-  
+
   /**
    * Constructs a new <code>DiskAccessException</code>.
    */
   public DiskAccessException() {
     super();
   }
-  
+
   /**
    * Constructs a new <code>DiskAccessException</code> with a message string.
    *
@@ -46,7 +44,7 @@ public class DiskAccessException extends CacheRuntimeException {
   public DiskAccessException(String msg, Region r) {
     this(msg, null, r == null ? null : r.getFullPath());
   }
-  
+
   /**
    * Constructs a new <code>DiskAccessException</code> with a message string.
    *
@@ -68,10 +66,9 @@ public class DiskAccessException extends CacheRuntimeException {
   public DiskAccessException(String msg, DiskStore ds) {
     this(msg, null, ds);
   }
-  
+
   /**
-   * Constructs a new <code>DiskAccessException</code> with a message string
-   * and a cause.
+   * Constructs a new <code>DiskAccessException</code> with a message string and a cause.
    *
    * @param msg the message string
    * @param cause a causal Throwable
@@ -79,12 +76,11 @@ public class DiskAccessException extends CacheRuntimeException {
    * @since GemFire 6.5
    */
   public DiskAccessException(String msg, Throwable cause, String regionName) {
-    super((regionName!=null ? "For Region: " + regionName + ": " : "") + msg, cause);
+    super((regionName != null ? "For Region: " + regionName + ": " : "") + msg, cause);
   }
 
   /**
-   * Constructs a new <code>DiskAccessException</code> with a message string
-   * and a cause.
+   * Constructs a new <code>DiskAccessException</code> with a message string and a cause.
    *
    * @param msg the message string
    * @param cause a causal Throwable
@@ -92,9 +88,9 @@ public class DiskAccessException extends CacheRuntimeException {
    * @since GemFire 6.5
    */
   public DiskAccessException(String msg, Throwable cause, DiskStore ds) {
-    super((ds!=null ? "For DiskStore: " + ds.getName() + ": " : "") + msg, cause);
+    super((ds != null ? "For DiskStore: " + ds.getName() + ": " : "") + msg, cause);
   }
-  
+
   /**
    * Constructs a new <code>DiskAccessException</code> with a cause.
    *
@@ -103,10 +99,9 @@ public class DiskAccessException extends CacheRuntimeException {
   public DiskAccessException(Throwable cause) {
     super(cause);
   }
-  
+
   /**
-   * Constructs a new <code>DiskAccessException</code> with a message string
-   * and a cause.
+   * Constructs a new <code>DiskAccessException</code> with a message string and a cause.
    *
    * @param msg the message string
    * @param cause a causal Throwable
@@ -115,7 +110,7 @@ public class DiskAccessException extends CacheRuntimeException {
   public DiskAccessException(String msg, Throwable cause) {
     super(msg, cause);
   }
-  
+
   /**
    * Returns true if this exception originated from a remote node.
    */
@@ -125,8 +120,7 @@ public class DiskAccessException extends CacheRuntimeException {
 
   // Overrides to set "isRemote" flag after deserialization
 
-  private synchronized void writeObject(final java.io.ObjectOutputStream out)
-      throws IOException {
+  private synchronized void writeObject(final java.io.ObjectOutputStream out) throws IOException {
     getStackTrace(); // Ensure that stackTrace field is initialized.
     out.defaultWriteObject();
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java b/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
index f425b90..96f186e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskStore.java
@@ -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,15 +18,18 @@ import java.io.File;
 import java.util.UUID;
 
 /**
- * Provides disk storage for one or more regions. The regions in the same disk store will
- * share the same disk persistence attributes. A region without a disk store name
- * belongs to the default disk store.
- * <p>Instances of this interface are created using
- * {@link DiskStoreFactory#create}. So to create a <code>DiskStore</code> named <code>myDiskStore</code> do this:
+ * Provides disk storage for one or more regions. The regions in the same disk store will share the
+ * same disk persistence attributes. A region without a disk store name belongs to the default disk
+ * store.
+ * <p>
+ * Instances of this interface are created using {@link DiskStoreFactory#create}. So to create a
+ * <code>DiskStore</code> named <code>myDiskStore</code> do this:
+ * 
  * <PRE>
- *   new DiskStoreFactory().create("myDiskStore");
+ * new DiskStoreFactory().create("myDiskStore");
  * </PRE>
- * <p>Existing DiskStore instances can be found using {@link Cache#findDiskStore(String)}
+ * <p>
+ * Existing DiskStore instances can be found using {@link Cache#findDiskStore(String)}
  *
  * @since GemFire 6.5
  *
@@ -46,23 +47,25 @@ public interface DiskStore {
   /**
    * Returns true if the disk files are to be automatically compacted.
    *
-   * @return Returns true if the disk files are to be automatically compacted;
-   *         false if automatic compaction is turned off
+   * @return Returns true if the disk files are to be automatically compacted; false if automatic
+   *         compaction is turned off
    */
   public boolean getAutoCompact();
 
   /**
-   * Returns the threshold at which an oplog will become compactable. Until it reaches
-   * this threshold the oplog will not be compacted.
-   * The threshold is a percentage in the range 0..100.
+   * Returns the threshold at which an oplog will become compactable. Until it reaches this
+   * threshold the oplog will not be compacted. The threshold is a percentage in the range 0..100.
+   * 
    * @return the threshold, as a percentage, at which an oplog is considered compactable.
    */
   public int getCompactionThreshold();
 
   /**
-   * Returns true if manual compaction of disk files is allowed on this region.
-   * Manual compaction is done be calling {@link #forceCompaction}.
-   * <p>Note that calls to {@link #forceCompaction} will also be allowed if {@link #getAutoCompact automatic compaction} is enabled.
+   * Returns true if manual compaction of disk files is allowed on this region. Manual compaction is
+   * done be calling {@link #forceCompaction}.
+   * <p>
+   * Note that calls to {@link #forceCompaction} will also be allowed if {@link #getAutoCompact
+   * automatic compaction} is enabled.
    *
    * @return Returns true if manual compaction of disk files is allowed on this region.
    */
@@ -76,27 +79,24 @@ public interface DiskStore {
   public long getMaxOplogSize();
 
   /**
-   * Returns the number of milliseconds that can elapse before
-   * unwritten data is written to disk.
+   * Returns the number of milliseconds that can elapse before unwritten data is written to disk.
    *
    * @return Returns the time interval in milliseconds that can elapse between two writes to disk
    */
   public long getTimeInterval();
 
   /**
-   * Returns the size of the write buffer that this disk store will use when
-   * writing data to disk. Larger values may increase performance but will use
-   * more memory.
-   * The disk store will allocate one direct memory buffer of this size.
+   * Returns the size of the write buffer that this disk store will use when writing data to disk.
+   * Larger values may increase performance but will use more memory. The disk store will allocate
+   * one direct memory buffer of this size.
    *
    * @return Returns the size of the write buffer.
    */
   public int getWriteBufferSize();
 
   /**
-   * Returns the directories to which the region's data are written.  If
-   * multiple directories are used, GemFire will attempt to distribute the
-   * data evenly amongst them.
+   * Returns the directories to which the region's data are written. If multiple directories are
+   * used, GemFire will attempt to distribute the data evenly amongst them.
    *
    */
   public File[] getDiskDirs();
@@ -107,83 +107,79 @@ public interface DiskStore {
   public int[] getDiskDirSizes();
 
   /**
-   * Returns the universally unique identifier for the Disk Store across the GemFire distributed system.
+   * Returns the universally unique identifier for the Disk Store across the GemFire distributed
+   * system.
    * </p>
+   * 
    * @return a UUID uniquely identifying this Disk Store in the GemFire distributed system.
    * @see java.util.UUID
    */
   public UUID getDiskStoreUUID();
 
   /**
-   * Returns the maximum number of operations that can be asynchronously
-   * queued to be written to disk. When this limit is reached, it will cause
-   * operations to block until they can be put in the queue.
-   * If this <code>DiskStore</code> configures synchronous writing, then
+   * Returns the maximum number of operations that can be asynchronously queued to be written to
+   * disk. When this limit is reached, it will cause operations to block until they can be put in
+   * the queue. If this <code>DiskStore</code> configures synchronous writing, then
    * <code>queueSize</code> is ignored.
    *
-   * @return the maxinum number of entries that can be queued concurrently
-   * for asynchronous writting to disk.
+   * @return the maxinum number of entries that can be queued concurrently for asynchronous writting
+   *         to disk.
    *
    */
   public int getQueueSize();
 
   /**
-   * Causes any data that is currently in the asynchronous queue to be written
-   * to disk. Does not return until the flush is complete.
+   * Causes any data that is currently in the asynchronous queue to be written to disk. Does not
+   * return until the flush is complete.
    *
-   * @throws DiskAccessException
-   *         If problems are encounter while writing to disk
+   * @throws DiskAccessException If problems are encounter while writing to disk
    */
   public void flush();
 
   /**
-   * Asks the disk store to start writing to a new oplog.
-   * The old oplog will be asynchronously compressed if compaction is set to true.
-   * The new oplog will be created in the next available directory with free space.
-   * If there is no directory with free space available and compaction is set to false,
-   * then a <code>DiskAccessException</code> saying that the disk is full will be
-   * thrown.
-   * If compaction is true then the application will wait for the other oplogs
-   * to be compacted and more space to be created.
+   * Asks the disk store to start writing to a new oplog. The old oplog will be asynchronously
+   * compressed if compaction is set to true. The new oplog will be created in the next available
+   * directory with free space. If there is no directory with free space available and compaction is
+   * set to false, then a <code>DiskAccessException</code> saying that the disk is full will be
+   * thrown. If compaction is true then the application will wait for the other oplogs to be
+   * compacted and more space to be created.
    *
    * @throws DiskAccessException
    */
   public void forceRoll();
 
-   /**
-    * Allows a disk compaction to be forced on this disk store. The compaction
-    * is done even if automatic compaction is not configured.
-    * If the current active oplog has had data written to it and it is
-    * compactable then an implicit call to {@link #forceRoll} will be made
-    * so that the active oplog can be compacted.
-    * <P>This method will block until the compaction completes.
-    * @return <code>true</code> if one or more oplogs were compacted;
-    * <code>false</code> indicates that no oplogs were ready
-    * to be compacted or that a compaction was already in progress.
-    * @see #getAllowForceCompaction
-    */
+  /**
+   * Allows a disk compaction to be forced on this disk store. The compaction is done even if
+   * automatic compaction is not configured. If the current active oplog has had data written to it
+   * and it is compactable then an implicit call to {@link #forceRoll} will be made so that the
+   * active oplog can be compacted.
+   * <P>
+   * This method will block until the compaction completes.
+   * 
+   * @return <code>true</code> if one or more oplogs were compacted; <code>false</code> indicates
+   *         that no oplogs were ready to be compacted or that a compaction was already in progress.
+   * @see #getAllowForceCompaction
+   */
   public boolean forceCompaction();
-  
+
   /**
-   * Destroys this disk store. Removes the disk store from the cache,
-   * and removes all files related to the disk store from disk.
+   * Destroys this disk store. Removes the disk store from the cache, and removes all files related
+   * to the disk store from disk.
    * 
-   * If there are any currently open regions in the disk store
-   * this method will throw an exception. If there are any closed regions that 
-   * are persisted in this disk store, the data for those regions 
-   * will be destroyed. 
+   * If there are any currently open regions in the disk store this method will throw an exception.
+   * If there are any closed regions that are persisted in this disk store, the data for those
+   * regions will be destroyed.
    *
-   * @throws IllegalStateException if the disk store is currently
-   * in use by any regions, gateway senders, or a PDX type registry.
+   * @throws IllegalStateException if the disk store is currently in use by any regions, gateway
+   *         senders, or a PDX type registry.
    * 
    * @since GemFire 8.0
    */
   public void destroy();
-  
+
 
   /**
-   * Returns the warning threshold for disk usage as a percentage of the total 
-   * disk volume.
+   * Returns the warning threshold for disk usage as a percentage of the total disk volume.
    * 
    * @return the warning percent
    * @since GemFire 8.0
@@ -191,21 +187,20 @@ public interface DiskStore {
   public float getDiskUsageWarningPercentage();
 
   /**
-   * Returns the critical threshold for disk usage as a percentage of the total 
-   * disk volume.
+   * Returns the critical threshold for disk usage as a percentage of the total disk volume.
    * 
    * @return the critical percent
    * @since GemFire 8.0
    */
   public float getDiskUsageCriticalPercentage();
-  
+
   /**
    * Sets the value of the disk usage warning percentage.
    * 
    * @param warningPercent the warning percent
    */
   public void setDiskUsageWarningPercentage(float warningPercent);
-  
+
   /**
    * Sets the value of the disk usage critical percentage.
    *