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

[23/52] [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/admin/internal/BackupDataStoreHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
index 0d68f02..551aaa1 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreHelper.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.admin.internal;
 
@@ -31,15 +29,15 @@ public class BackupDataStoreHelper {
   public static String LOCK_SERVICE_NAME = BackupDataStoreHelper.class.getSimpleName();
 
   private static String LOCK_NAME = LOCK_SERVICE_NAME + "_token";
-  
+
   private static Object LOCK_SYNC = new Object();
 
   @SuppressWarnings("rawtypes")
-  public static BackupDataStoreResult backupAllMembers(
-      DM dm, Set recipients, File targetDir, File baselineDir) {
+  public static BackupDataStoreResult backupAllMembers(DM dm, Set recipients, File targetDir,
+      File baselineDir) {
     FlushToDiskRequest.send(dm, recipients);
 
-    boolean abort= true;
+    boolean abort = true;
     Map<DistributedMember, Set<PersistentID>> successfulMembers;
     Map<DistributedMember, Set<PersistentID>> existingDataStores;
     try {
@@ -50,7 +48,7 @@ public class BackupDataStoreHelper {
     }
     return new BackupDataStoreResult(existingDataStores, successfulMembers);
   }
-  
+
   private static DistributedLockService getLockService(DM dm) {
     DistributedLockService dls = DistributedLockService.getServiceNamed(LOCK_SERVICE_NAME);
     if (dls == null) {
@@ -65,11 +63,11 @@ public class BackupDataStoreHelper {
     Assert.assertTrue(dls != null);
     return dls;
   }
-  
+
   public static boolean obtainLock(DM dm) {
     return getLockService(dm).lock(LOCK_NAME, 0, -1);
   }
-  
+
   public static void releaseLock(DM dm) {
     getLockService(dm).unlock(LOCK_NAME);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
index b2a201d..eae674b 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupDataStoreResult.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.admin.internal;
 
@@ -23,13 +21,12 @@ import org.apache.geode.cache.persistence.PersistentID;
 import org.apache.geode.distributed.DistributedMember;
 
 public class BackupDataStoreResult {
-  
+
   private Map<DistributedMember, Set<PersistentID>> existingDataStores;
 
   private Map<DistributedMember, Set<PersistentID>> successfulMembers;
 
-  public BackupDataStoreResult(
-      Map<DistributedMember, Set<PersistentID>> existingDataStores,
+  public BackupDataStoreResult(Map<DistributedMember, Set<PersistentID>> existingDataStores,
       Map<DistributedMember, Set<PersistentID>> successfulMembers) {
     this.existingDataStores = existingDataStores;
     this.successfulMembers = successfulMembers;
@@ -42,16 +39,10 @@ public class BackupDataStoreResult {
   public Map<DistributedMember, Set<PersistentID>> getSuccessfulMembers() {
     return this.successfulMembers;
   }
-  
+
   public String toString() {
-    return new StringBuilder()
-      .append(getClass().getSimpleName())
-      .append("[")
-      .append("existingDataStores=")
-      .append(this.existingDataStores)
-      .append("; successfulMembers=")
-      .append(this.successfulMembers)
-      .append("]")
-      .toString();
+    return new StringBuilder().append(getClass().getSimpleName()).append("[")
+        .append("existingDataStores=").append(this.existingDataStores)
+        .append("; successfulMembers=").append(this.successfulMembers).append("]").toString();
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
index 074ecb3..4256c3c 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/BackupStatusImpl.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.admin.internal;
 
@@ -31,12 +29,11 @@ import org.apache.geode.distributed.DistributedMember;
  */
 public class BackupStatusImpl implements BackupStatus, Serializable {
   private static final long serialVersionUID = 3704162840296921840L;
-  
+
   private Map<DistributedMember, Set<PersistentID>> backedUpDiskStores;
   private Set<PersistentID> offlineDiskStores;
-  
-  public BackupStatusImpl(
-      Map<DistributedMember, Set<PersistentID>> backedUpDiskStores,
+
+  public BackupStatusImpl(Map<DistributedMember, Set<PersistentID>> backedUpDiskStores,
       Set<PersistentID> offlineDiskStores) {
     super();
     this.backedUpDiskStores = backedUpDiskStores;
@@ -53,9 +50,10 @@ public class BackupStatusImpl implements BackupStatus, Serializable {
 
   @Override
   public String toString() {
-    return "BackupStatus[backedUpDiskStores=" + backedUpDiskStores + ", offlineDiskStores=" + offlineDiskStores + "]"; 
+    return "BackupStatus[backedUpDiskStores=" + backedUpDiskStores + ", offlineDiskStores="
+        + offlineDiskStores + "]";
   }
-  
-  
+
+
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
index fd82b24..3c57ef4 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthConfigImpl.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.admin.internal;
 
@@ -24,37 +22,39 @@ import org.apache.geode.admin.*;
  *
  * @since GemFire 3.5
  */
-public abstract class CacheHealthConfigImpl
-  extends MemberHealthConfigImpl implements CacheHealthConfig {
+public abstract class CacheHealthConfigImpl extends MemberHealthConfigImpl
+    implements CacheHealthConfig {
 
-  /** The maximum number of milliseconds a
-   * <code>netSearch</code> operation can take before the cache member
-   * is considered to be unhealthy. */
+  /**
+   * The maximum number of milliseconds a <code>netSearch</code> operation can take before the cache
+   * member is considered to be unhealthy.
+   */
   private long maxNetSearchTime = DEFAULT_MAX_NET_SEARCH_TIME;
 
-  /** The maximum mumber of milliseconds a cache
-   * <code>load</code> operation can take before the cache member is
-   * considered to be unhealthy. */
+  /**
+   * The maximum mumber of milliseconds a cache <code>load</code> operation can take before the
+   * cache member is considered to be unhealthy.
+   */
   private long maxLoadTime = DEFAULT_MAX_LOAD_TIME;
 
   /** The minimum hit ratio of a healthy cache member. */
   private double minHitRatio = DEFAULT_MIN_HIT_RATIO;
 
-  /** The maximum number of entries in the event delivery queue
-   * of a healthy cache member. */
+  /**
+   * The maximum number of entries in the event delivery queue of a healthy cache member.
+   */
   private long maxEventQueueSize = DEFAULT_MAX_EVENT_QUEUE_SIZE;
 
-  ///////////////////////  Constructors  ///////////////////////
+  /////////////////////// Constructors ///////////////////////
 
   /**
-   * Creates a new <code>CacheHealthConfigImpl</code> with the default
-   * configuration.
+   * Creates a new <code>CacheHealthConfigImpl</code> with the default configuration.
    */
   CacheHealthConfigImpl() {
 
   }
 
-  //////////////////////  Instance Methods  /////////////////////
+  ////////////////////// Instance Methods /////////////////////
 
   public long getMaxNetSearchTime() {
     return this.maxNetSearchTime;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
index 6ab9f34..f7ff9ed 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheHealthEvaluator.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.admin.internal;
 
@@ -34,26 +32,25 @@ import org.apache.geode.internal.i18n.LocalizedStrings;
 import org.apache.geode.internal.logging.LogService;
 
 /**
- * Contains the logic for evaluating the health of a GemFire
- * <code>Cache</code> instance according to the thresholds provided in
- * a {@link CacheHealthConfig}.
+ * Contains the logic for evaluating the health of a GemFire <code>Cache</code> instance according
+ * to the thresholds provided in a {@link CacheHealthConfig}.
  *
  *
  * @since GemFire 3.5
  */
-class CacheHealthEvaluator extends AbstractHealthEvaluator 
-  implements CacheLifecycleListener {
+class CacheHealthEvaluator extends AbstractHealthEvaluator implements CacheLifecycleListener {
 
   private static final Logger logger = LogService.getLogger();
-  
+
   /** The config from which we get the evaulation criteria */
   private CacheHealthConfig config;
 
   /** The description of the cache being evaluated */
   private String description;
 
-  /** Statistics about the <code>Cache</code> instance.  If no cache
-   * has been created in this VM, this field will be <code>null</code>
+  /**
+   * Statistics about the <code>Cache</code> instance. If no cache has been created in this VM, this
+   * field will be <code>null</code>
    */
   private CachePerfStats cacheStats;
 
@@ -72,13 +69,12 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
   /** The previous value of the gets stat */
   private long prevGets;
 
-  //////////////////////  Constructors  //////////////////////
+  ////////////////////// Constructors //////////////////////
 
   /**
    * Creates a new <code>CacheHealthEvaluator</code>
    */
-  CacheHealthEvaluator(GemFireHealthConfig config,
-                       DM dm) {
+  CacheHealthEvaluator(GemFireHealthConfig config, DM dm) {
     super(config, dm);
 
     this.config = config;
@@ -96,7 +92,7 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
     GemFireCacheImpl.addCacheLifecycleListener(this);
   }
 
-  ////////////////////  Instance Methods  ////////////////////
+  //////////////////// Instance Methods ////////////////////
 
   @Override
   protected String getDescription() {
@@ -104,8 +100,7 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
   }
 
   /**
-   * Initializes the state of this evaluator based on the given cache
-   * instance. 
+   * Initializes the state of this evaluator based on the given cache instance.
    */
   private void initialize(GemFireCacheImpl cache, DM dm) {
     StringBuffer sb = new StringBuffer();
@@ -131,66 +126,58 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
   }
 
   public void cacheCreated(GemFireCacheImpl cache) {
-    InternalDistributedSystem system =
-      (InternalDistributedSystem) cache.getDistributedSystem();
+    InternalDistributedSystem system = (InternalDistributedSystem) cache.getDistributedSystem();
     DM dm = system.getDistributionManager();
     initialize(cache, dm);
   }
 
   /**
-   * Checks to make sure that the average <code>netSearch</code> time
-   * during the previous health check interval is less than the
-   * {@linkplain CacheHealthConfig#getMaxNetSearchTime threshold}.  If
-   * not, the status is "okay" health.
+   * Checks to make sure that the average <code>netSearch</code> time during the previous health
+   * check interval is less than the {@linkplain CacheHealthConfig#getMaxNetSearchTime threshold}.
+   * If not, the status is "okay" health.
    *
    * @see CachePerfStats#getNetsearchTime
    * @see CachePerfStats#getNetsearchesCompleted
    */
   void checkNetSearchTime(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
+    if (this.cacheStats == null || isFirstEvaluation() || this.cacheStats.isClosed()) {
       return;
     }
 
-    long deltaNetsearchTime =
-      this.cacheStats.getNetsearchTime() - this.prevNetsearchTime;
+    long deltaNetsearchTime = this.cacheStats.getNetsearchTime() - this.prevNetsearchTime;
     long deltaNetsearchesCompleted =
-      this.cacheStats.getNetsearchesCompleted() -
-      this.prevNetsearchesCompleted;
+        this.cacheStats.getNetsearchesCompleted() - this.prevNetsearchesCompleted;
 
     if (deltaNetsearchesCompleted != 0) {
       long ratio = deltaNetsearchTime / deltaNetsearchesCompleted;
       ratio /= 1000000;
       long threshold = this.config.getMaxNetSearchTime();
-        
+
       if (ratio > threshold) {
-        String s = LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_NETSEARCH_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { ratio, threshold });
+        String s =
+            LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_NETSEARCH_0_MS_EXCEEDS_THE_THRESHOLD_1_MS
+                .toLocalizedString(new Object[] {ratio, threshold});
         status.add(okayHealth(s));
       }
     }
   }
 
   /**
-   * Checks to make sure that the average <code>load</code> time
-   * during the previous health check interval is less than the
-   * {@linkplain CacheHealthConfig#getMaxLoadTime threshold}.  If
-   * not, the status is "okay" health.
+   * Checks to make sure that the average <code>load</code> time during the previous health check
+   * interval is less than the {@linkplain CacheHealthConfig#getMaxLoadTime threshold}. If not, the
+   * status is "okay" health.
    *
    * @see CachePerfStats#getLoadTime
    * @see CachePerfStats#getLoadsCompleted
    */
   void checkLoadTime(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
+    if (this.cacheStats == null || isFirstEvaluation() || this.cacheStats.isClosed()) {
       return;
     }
 
     if (!isFirstEvaluation()) {
-      long deltaLoadTime =
-        this.cacheStats.getLoadTime() - this.prevLoadTime;
-      long deltaLoadsCompleted =
-        this.cacheStats.getLoadsCompleted() -
-        this.prevLoadsCompleted;
+      long deltaLoadTime = this.cacheStats.getLoadTime() - this.prevLoadTime;
+      long deltaLoadsCompleted = this.cacheStats.getLoadsCompleted() - this.prevLoadsCompleted;
 
       if (logger.isDebugEnabled()) {
         logger.debug("Completed {} loads in {} ms", deltaLoadsCompleted, (deltaLoadTime / 1000000));
@@ -200,9 +187,11 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
         long ratio = deltaLoadTime / deltaLoadsCompleted;
         ratio /= 1000000;
         long threshold = this.config.getMaxLoadTime();
-        
+
         if (ratio > threshold) {
-          String s = LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_LOAD_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { ratio, threshold });
+          String s =
+              LocalizedStrings.CacheHealthEvaluator_THE_AVERAGE_DURATION_OF_A_CACHE_LOAD_0_MS_EXCEEDS_THE_THRESHOLD_1_MS
+                  .toLocalizedString(new Object[] {ratio, threshold});
           if (logger.isDebugEnabled()) {
             logger.debug(s);
           }
@@ -213,10 +202,9 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
   }
 
   /**
-   * Checks to make sure that the cache hit ratio during the previous
-   * health check interval is less than the {@linkplain
-   * CacheHealthConfig#getMinHitRatio threshold}.  If not, the status
-   * is "okay" health.
+   * Checks to make sure that the cache hit ratio during the previous health check interval is less
+   * than the {@linkplain CacheHealthConfig#getMinHitRatio threshold}. If not, the status is "okay"
+   * health.
    *
    * <P>
    *
@@ -232,48 +220,44 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
    * @see CachePerfStats#getNetsearchesCompleted
    */
   void checkHitRatio(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
+    if (this.cacheStats == null || isFirstEvaluation() || this.cacheStats.isClosed()) {
       return;
     }
 
     long deltaGets = this.cacheStats.getGets() - this.prevGets;
     if (deltaGets != 0) {
-      long deltaLoadsCompleted =
-        this.cacheStats.getLoadsCompleted() - this.prevLoadsCompleted;
+      long deltaLoadsCompleted = this.cacheStats.getLoadsCompleted() - this.prevLoadsCompleted;
       long deltaNetsearchesCompleted =
-        this.cacheStats.getNetsearchesCompleted() -
-        this.prevNetsearchesCompleted;
+          this.cacheStats.getNetsearchesCompleted() - this.prevNetsearchesCompleted;
 
-      double hits =
-        (deltaGets -
-                (deltaLoadsCompleted + deltaNetsearchesCompleted));
+      double hits = (deltaGets - (deltaLoadsCompleted + deltaNetsearchesCompleted));
       double hitRatio = hits / deltaGets;
       double threshold = this.config.getMinHitRatio();
       if (hitRatio < threshold) {
-        String s = "The hit ratio of this Cache (" + hitRatio +
-          ") is below the threshold (" + threshold + ")";
+        String s = "The hit ratio of this Cache (" + hitRatio + ") is below the threshold ("
+            + threshold + ")";
         status.add(okayHealth(s));
       }
     }
   }
 
   /**
-   * Checks to make sure that the {@linkplain
-   * CachePerfStats#getEventQueueSize cache event queue size} does
-   * not exceed the {@linkplain CacheHealthConfig#getMaxEventQueueSize
-   * threshold}.  If it does, the status is "okay" health.
+   * Checks to make sure that the {@linkplain CachePerfStats#getEventQueueSize cache event queue
+   * size} does not exceed the {@linkplain CacheHealthConfig#getMaxEventQueueSize threshold}. If it
+   * does, the status is "okay" health.
    */
   void checkEventQueueSize(List status) {
-    if (this.cacheStats == null || isFirstEvaluation() ||
-        this.cacheStats.isClosed()) {
+    if (this.cacheStats == null || isFirstEvaluation() || this.cacheStats.isClosed()) {
       return;
     }
 
     long eventQueueSize = this.cacheStats.getEventQueueSize();
     long threshold = this.config.getMaxEventQueueSize();
     if (eventQueueSize > threshold) {
-      String s = LocalizedStrings.CacheHealthEvaluator_THE_SIZE_OF_THE_CACHE_EVENT_QUEUE_0_MS_EXCEEDS_THE_THRESHOLD_1_MS.toLocalizedString(new Object[] { Long.valueOf(eventQueueSize), Long.valueOf(threshold) });
+      String s =
+          LocalizedStrings.CacheHealthEvaluator_THE_SIZE_OF_THE_CACHE_EVENT_QUEUE_0_MS_EXCEEDS_THE_THRESHOLD_1_MS
+              .toLocalizedString(
+                  new Object[] {Long.valueOf(eventQueueSize), Long.valueOf(threshold)});
       status.add(okayHealth(s));
     }
   }
@@ -287,8 +271,7 @@ class CacheHealthEvaluator extends AbstractHealthEvaluator
       this.prevLoadTime = this.cacheStats.getLoadTime();
       this.prevLoadsCompleted = this.cacheStats.getLoadsCompleted();
       this.prevNetsearchTime = this.cacheStats.getNetsearchTime();
-      this.prevNetsearchesCompleted =
-        this.cacheStats.getNetsearchesCompleted();
+      this.prevNetsearchesCompleted = this.cacheStats.getNetsearchesCompleted();
       this.prevGets = this.cacheStats.getGets();
 
     } else {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
index e34a476..dbf860f 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerConfigImpl.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.admin.internal;
 
@@ -27,21 +25,21 @@ import static org.apache.geode.distributed.ConfigurationProperties.*;
  *
  * @since GemFire 4.0
  */
-public class CacheServerConfigImpl extends ManagedEntityConfigImpl 
-  implements CacheVmConfig, CacheServerConfig {
+public class CacheServerConfigImpl extends ManagedEntityConfigImpl
+    implements CacheVmConfig, CacheServerConfig {
 
-  /** Declarative caching XML file that is used to initialize the
-   * Cache in the cache server. */
+  /**
+   * Declarative caching XML file that is used to initialize the Cache in the cache server.
+   */
   private String cacheXMLFile;
 
   /** Extra classpath for the cache server */
   private String classpath;
 
-  ///////////////////////  Constructors  ///////////////////////
+  /////////////////////// Constructors ///////////////////////
 
   /**
-   * Creates a new <code>CacheServerConfigImpl</code> with the default
-   * configuration settings.
+   * Creates a new <code>CacheServerConfigImpl</code> with the default configuration settings.
    */
   public CacheServerConfigImpl() {
     this.cacheXMLFile = null;
@@ -49,8 +47,7 @@ public class CacheServerConfigImpl extends ManagedEntityConfigImpl
   }
 
   /**
-   * Creates a new <code>CacheServerConfigImpl</code> for a running
-   * cache server.
+   * Creates a new <code>CacheServerConfigImpl</code> for a running cache server.
    */
   public CacheServerConfigImpl(GemFireVM vm) {
     super(vm);
@@ -78,7 +75,7 @@ public class CacheServerConfigImpl extends ManagedEntityConfigImpl
     this.classpath = other.getClassPath();
   }
 
-  //////////////////////  Instance Methods  //////////////////////
+  ////////////////////// Instance Methods //////////////////////
 
   public String getCacheXMLFile() {
     return this.cacheXMLFile;
@@ -104,7 +101,7 @@ public class CacheServerConfigImpl extends ManagedEntityConfigImpl
   public void validate() {
     super.validate();
 
-    // Nothing to validate really.  Cache.xml file could live on
+    // Nothing to validate really. Cache.xml file could live on
     // different file system.
   }
 
@@ -118,7 +115,7 @@ public class CacheServerConfigImpl extends ManagedEntityConfigImpl
 
   @Override
   public Object clone() throws CloneNotSupportedException {
-    return new CacheServerConfigImpl((CacheVmConfig)this);
+    return new CacheServerConfigImpl((CacheVmConfig) this);
   }
 
   @Override
@@ -130,7 +127,7 @@ public class CacheServerConfigImpl extends ManagedEntityConfigImpl
     sb.append(" classPath=");
     sb.append(this.getClassPath());
 
-    return sb.toString();    
+    return sb.toString();
   }
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
index f13c9ba..c10c6f8 100644
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/CacheServerImpl.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.admin.internal;
 
@@ -29,27 +27,24 @@ import static org.apache.geode.distributed.ConfigurationProperties.*;
  *
  * @since GemFire 3.5
  */
-public class CacheServerImpl extends ManagedSystemMemberImpl
-  implements CacheVm, CacheServer {
+public class CacheServerImpl extends ManagedSystemMemberImpl implements CacheVm, CacheServer {
 
   /** How many new <code>CacheServer</code>s have been created? */
   private static int newCacheServers = 0;
 
-  ///////////////////////  Instance Fields  ///////////////////////
+  /////////////////////// Instance Fields ///////////////////////
 
   /** The configuration object for this cache server */
   private final CacheServerConfigImpl config;
 
-  /////////////////////////  Constructors  ////////////////////////
+  ///////////////////////// Constructors ////////////////////////
 
   /**
-   * Creates a new <code>CacheServerImpl</code> that represents a
-   * non-existsing (unstarted) cache server in a given distributed
-   * system.
+   * Creates a new <code>CacheServerImpl</code> that represents a non-existsing (unstarted) cache
+   * server in a given distributed system.
    */
-  public CacheServerImpl(AdminDistributedSystemImpl system,
-                         CacheVmConfig config) 
-    throws AdminException {
+  public CacheServerImpl(AdminDistributedSystemImpl system, CacheVmConfig config)
+      throws AdminException {
 
     super(system, config);
 
@@ -58,18 +53,16 @@ public class CacheServerImpl extends ManagedSystemMemberImpl
   }
 
   /**
-   * Creates a new <code>CacheServerImpl</code> that represents an
-   * existing dedicated cache server in a given distributed system.
+   * Creates a new <code>CacheServerImpl</code> that represents an existing dedicated cache server
+   * in a given distributed system.
    */
-  public CacheServerImpl(AdminDistributedSystemImpl system,
-                         GemFireVM vm) 
-    throws AdminException {
+  public CacheServerImpl(AdminDistributedSystemImpl system, GemFireVM vm) throws AdminException {
 
     super(system, vm);
     this.config = new CacheServerConfigImpl(vm);
   }
 
-  //////////////////////  Instance Methods  //////////////////////
+  ////////////////////// Instance Methods //////////////////////
 
   @Override
   public SystemMemberType getType() {
@@ -101,18 +94,18 @@ public class CacheServerImpl extends ManagedSystemMemberImpl
     // NOTE: DistributedSystem nodeLeft will then set this.manager to null
     this.config.setManagedEntity(null);
   }
-  
+
   public boolean isRunning() {
-    DM dm = ((AdminDistributedSystemImpl)getDistributedSystem()).getDistributionManager();
-    if(dm == null) {
+    DM dm = ((AdminDistributedSystemImpl) getDistributedSystem()).getDistributionManager();
+    if (dm == null) {
       try {
         return this.controller.isRunning(this);
-      }
-      catch (IllegalStateException e) {
+      } catch (IllegalStateException e) {
         return false;
       }
     }
-    return ((DistributionManager)dm).getDistributionManagerIdsIncludingAdmin().contains(getDistributedMember());
+    return ((DistributionManager) dm).getDistributionManagerIdsIncludingAdmin()
+        .contains(getDistributedMember());
   }
 
   public CacheServerConfig getConfig() {
@@ -123,7 +116,7 @@ public class CacheServerImpl extends ManagedSystemMemberImpl
     return this.config;
   }
 
-  ////////////////////////  Command execution  ////////////////////////
+  //////////////////////// Command execution ////////////////////////
 
   public ManagedEntityConfig getEntityConfig() {
     return this.getConfig();
@@ -180,19 +173,17 @@ public class CacheServerImpl extends ManagedSystemMemberImpl
   /**
    * Find whether this server is primary for given client (durableClientId)
    * 
-   * @param durableClientId -
-   *                durable-id of the client
+   * @param durableClientId - durable-id of the client
    * @return true if the server is primary for given client
    * 
    * @since GemFire 5.6
    */
-  public boolean isPrimaryForDurableClient(String durableClientId)
-  {
-    RemoteApplicationVM vm = (RemoteApplicationVM)this.getGemFireVM();
+  public boolean isPrimaryForDurableClient(String durableClientId) {
+    RemoteApplicationVM vm = (RemoteApplicationVM) this.getGemFireVM();
     boolean isPrimary = false;
     if (vm != null) {
       isPrimary = vm.isPrimaryForDurableClient(durableClientId);
-}
+    }
     return isPrimary;
   }
 

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

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8bf39571/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
index b9102d6..8865429 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/internal/ConfigurationParameterListener.java
@@ -1,31 +1,27 @@
 /*
- * 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.admin.internal;
 
 import org.apache.geode.admin.ConfigurationParameter;
 
 /**
- * Listens to value changes of a 
- * {@link org.apache.geode.admin.ConfigurationParameter}.  This is for 
- * internal use only to allow a {@link SystemMemberImpl} to keep track of 
- * configuration changes made through 
- * {@link ConfigurationParameterImpl#setValue}.
+ * Listens to value changes of a {@link org.apache.geode.admin.ConfigurationParameter}. This is for
+ * internal use only to allow a {@link SystemMemberImpl} to keep track of configuration changes made
+ * through {@link ConfigurationParameterImpl#setValue}.
  *
- * @since GemFire     3.5
+ * @since GemFire 3.5
  *
  */
 public interface ConfigurationParameterListener {

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