You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by pr...@apache.org on 2018/04/16 23:17:21 UTC

[geode] branch develop updated: GEODE-4954, GEODE-4955: Remove trivial javadoc stubs and empty blocks: geode-core:cache (#1783)

This is an automated email from the ASF dual-hosted git repository.

prhomberg pushed a commit to branch develop
in repository https://gitbox.apache.org/repos/asf/geode.git


The following commit(s) were added to refs/heads/develop by this push:
     new 00aa0de  GEODE-4954, GEODE-4955: Remove trivial javadoc stubs and empty blocks:  geode-core:cache (#1783)
00aa0de is described below

commit 00aa0de0f3c2f89fae31a4ac0bc75bd8596cb15b
Author: Patrick Rhomberg <pr...@pivotal.io>
AuthorDate: Mon Apr 16 16:17:17 2018 -0700

    GEODE-4954, GEODE-4955: Remove trivial javadoc stubs and empty blocks:  geode-core:cache (#1783)
---
 .../org/apache/geode/cache/AttributesFactory.java  |   2 -
 .../org/apache/geode/cache/AttributesMutator.java  |   5 -
 .../main/java/org/apache/geode/cache/Cache.java    |   3 -
 .../geode/cache/CacheTransactionManager.java       |   2 -
 .../java/org/apache/geode/cache/DiskStore.java     |   1 -
 .../geode/cache/DiskWriteAttributesFactory.java    |   1 -
 .../org/apache/geode/cache/EvictionAction.java     |   1 -
 .../apache/geode/cache/PartitionAttributes.java    |   2 -
 .../geode/cache/PartitionAttributesFactory.java    |   5 -
 .../main/java/org/apache/geode/cache/Region.java   |   1 -
 .../geode/cache/TransactionWriterException.java    |   3 -
 .../geode/cache/asyncqueue/AsyncEventQueue.java    |   8 -
 .../cache/asyncqueue/AsyncEventQueueFactory.java   |   4 -
 .../geode/cache/client/ClientRegionFactory.java    |   1 -
 .../geode/cache/client/internal/AbstractOp.java    |   1 -
 .../cache/client/internal/AuthenticateUserOp.java  |   4 -
 .../client/internal/AutoConnectionSourceImpl.java  |   1 -
 .../geode/cache/client/internal/ClientUpdater.java |   3 -
 .../cache/client/internal/EndpointManager.java     |   1 -
 .../cache/client/internal/EndpointManagerImpl.java |   3 -
 .../cache/client/internal/ExecutablePool.java      |   1 -
 .../client/internal/ExecuteFunctionNoAckOp.java    |   9 -
 .../geode/cache/client/internal/GetEntryOp.java    |   3 -
 .../geode/cache/client/internal/PoolImpl.java      |   2 -
 .../geode/cache/client/internal/PrimaryAckOp.java  |   1 -
 .../apache/geode/cache/client/internal/PutOp.java  |   2 -
 .../cache/client/internal/QueueStateImpl.java      |   1 -
 .../cache/client/internal/ReadyForEventsOp.java    |   1 -
 .../client/internal/ServerRegionDataAccess.java    |   4 -
 .../cache/client/internal/ServerRegionProxy.java   |   5 -
 .../client/internal/SingleHopClientExecutor.java   |   4 -
 .../internal/SingleHopOperationCallable.java       |   4 -
 .../cache/client/internal/TXSynchronizationOp.java |   5 -
 .../internal/locator/GetAllServersRequest.java     |   5 -
 .../internal/locator/GetAllServersResponse.java    |   4 -
 .../internal/locator/LocatorListRequest.java       |   3 -
 .../internal/locator/LocatorListResponse.java      |   3 -
 .../internal/locator/SerializationHelper.java      |   3 -
 .../internal/locator/ServerLocationRequest.java    |   3 -
 .../internal/locator/ServerLocationResponse.java   |   3 -
 .../locator/wan/LocatorMembershipListener.java     |   1 -
 .../client/internal/pooling/ConnectionManager.java |   1 -
 .../internal/pooling/ConnectionManagerImpl.java    |   1 -
 .../geode/cache/configuration/CacheConfig.java     | 840 +++++++++------------
 .../geode/cache/configuration/CacheLoaderType.java |  10 +-
 .../configuration/CacheTransactionManagerType.java |  30 +-
 .../geode/cache/configuration/CacheWriterType.java |  10 +-
 .../configuration/ClassWithParametersType.java     |  10 +-
 .../geode/cache/configuration/DeclarableType.java  |  10 +-
 .../geode/cache/configuration/DiskDirType.java     |  20 +-
 .../geode/cache/configuration/DiskStoreType.java   | 110 ++-
 .../configuration/DynamicRegionFactoryType.java    |  40 +-
 .../configuration/ExpirationAttributesType.java    |  40 +-
 .../cache/configuration/FunctionServiceType.java   |  10 +-
 .../geode/cache/configuration/InitializerType.java |  10 +-
 .../cache/configuration/JndiBindingsType.java      | 180 ++---
 .../geode/cache/configuration/ParameterType.java   |  30 +-
 .../apache/geode/cache/configuration/PdxType.java  |  60 +-
 .../apache/geode/cache/configuration/PoolType.java | 250 +++---
 .../cache/configuration/RegionAttributesType.java  | 830 ++++++++------------
 .../geode/cache/configuration/RegionConfig.java    | 200 ++---
 .../cache/configuration/ResourceManagerType.java   |  40 +-
 .../SerializationRegistrationType.java             |  30 +-
 .../geode/cache/configuration/ServerType.java      | 180 ++---
 .../geode/cache/configuration/StringType.java      |  10 +-
 .../geode/cache/execute/FunctionContext.java       |   1 -
 .../geode/cache/execute/FunctionException.java     |   5 -
 .../geode/cache/execute/FunctionService.java       |  11 -
 .../geode/cache/execute/ResultCollector.java       |   1 -
 .../apache/geode/cache/execute/ResultSender.java   |   2 -
 .../execute/internal/FunctionServiceManager.java   |   8 -
 .../cache/partition/PartitionRegionHelper.java     |   3 -
 .../org/apache/geode/cache/query/Aggregator.java   |   1 -
 .../geode/cache/query/CqServiceStatistics.java     |   1 -
 .../org/apache/geode/cache/query/QueryService.java |   1 -
 .../internal/AbstractGroupOrRangeJunction.java     |   9 -
 .../cache/query/internal/AllGroupJunction.java     |   9 -
 .../cache/query/internal/AttributeDescriptor.java  |   3 -
 .../org/apache/geode/cache/query/internal/Bag.java |  13 -
 .../query/internal/CompiledAggregateFunction.java  |   4 -
 .../cache/query/internal/CompiledComparison.java   |   1 -
 .../query/internal/CompiledGroupBySelect.java      |   4 -
 .../geode/cache/query/internal/CompiledIn.java     |   1 -
 .../cache/query/internal/CompiledJunction.java     |   5 -
 .../geode/cache/query/internal/CompiledSelect.java |   6 -
 .../cache/query/internal/CompiledUnaryMinus.java   |  23 -
 .../cache/query/internal/CompiledUndefined.java    |   1 -
 .../geode/cache/query/internal/CqStateImpl.java    |   1 -
 .../cache/query/internal/DefaultQueryService.java  |   9 -
 .../apache/geode/cache/query/internal/Filter.java  |  35 -
 .../cache/query/internal/HashingStrategy.java      |   3 -
 .../query/internal/IndexTrackingQueryObserver.java |   1 -
 .../geode/cache/query/internal/Indexable.java      |   3 -
 .../geode/cache/query/internal/PathUtils.java      |   3 -
 .../geode/cache/query/internal/QCompiler.java      |   2 -
 .../geode/cache/query/internal/QueryObserver.java  |  14 -
 .../geode/cache/query/internal/QueryUtils.java     |   1 -
 .../geode/cache/query/internal/RangeJunction.java  |   7 -
 .../geode/cache/query/internal/ResultsBag.java     |   2 -
 .../query/internal/ResultsCollectionWrapper.java   |   4 -
 .../cache/query/internal/SortedResultsBag.java     |  10 -
 .../cache/query/internal/SortedStructBag.java      |  16 -
 .../geode/cache/query/internal/cq/ClientCQ.java    |   1 -
 .../cache/query/internal/cq/CqAttributesImpl.java  |   1 -
 .../geode/cache/query/internal/cq/CqService.java   |  21 -
 .../cache/query/internal/cq/InternalCqQuery.java   |   1 -
 .../geode/cache/query/internal/cq/ServerCQ.java    |   6 -
 .../cache/query/internal/index/HashIndexSet.java   |   5 -
 .../cache/query/internal/index/IMQException.java   |   3 -
 .../internal/index/IndexConcurrentHashSet.java     |   3 -
 .../cache/query/internal/index/IndexElemArray.java |   3 -
 .../cache/query/internal/index/IndexManager.java   |   1 -
 .../cache/query/internal/index/IndexProtocol.java  |  22 -
 .../cache/query/internal/index/IndexStore.java     |   7 -
 .../internal/index/IndexedExpressionEvaluator.java |   3 -
 .../query/internal/index/MemoryIndexStore.java     |   1 -
 .../query/internal/index/PartitionedIndex.java     |   1 -
 .../query/internal/parse/ASTAggregateFunc.java     |   4 -
 .../cache/query/internal/parse/ASTCombination.java |   3 -
 .../cache/query/internal/parse/ASTGroupBy.java     |   4 -
 .../geode/cache/query/internal/parse/ASTHint.java  |   3 -
 .../query/internal/parse/ASTHintIdentifier.java    |   3 -
 .../cache/query/internal/parse/ASTIteratorDef.java |   3 -
 .../geode/cache/query/internal/parse/ASTLike.java  |   6 -
 .../geode/cache/query/internal/parse/ASTLimit.java |   3 -
 .../cache/query/internal/parse/ASTOrderBy.java     |   4 -
 .../query/internal/parse/ASTSortCriterion.java     |   3 -
 .../geode/cache/query/internal/parse/ASTTrace.java |   3 -
 .../geode/cache/query/internal/parse/ASTUnary.java |  12 -
 .../cache/query/internal/parse/GemFireAST.java     |   3 -
 .../cache/query/internal/parse/UtilParser.java     |   3 -
 .../cache/query/internal/types/TypeUtils.java      |  32 -
 .../org/apache/geode/cache/server/CacheServer.java |   1 -
 .../cache/server/ClientSubscriptionConfig.java     |   1 -
 .../geode/cache/snapshot/SnapshotOptions.java      |   1 -
 .../apache/geode/cache/wan/GatewayEventFilter.java |   3 -
 .../geode/cache/wan/GatewayReceiverFactory.java    |   2 -
 .../org/apache/geode/cache/wan/GatewaySender.java  |   2 -
 .../geode/cache/wan/GatewaySenderFactory.java      |   5 -
 139 files changed, 1180 insertions(+), 2298 deletions(-)

diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
index 64e427a..2017cf2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesFactory.java
@@ -876,7 +876,6 @@ public class AttributesFactory<K, V> {
   /**
    * adds a gateway sender to the end of list of gateway senders on this factory
    *
-   * @param gatewaySenderId
    * @throws IllegalArgumentException if {@code gatewaySender} is null
    * @since GemFire 7.0
    */
@@ -893,7 +892,6 @@ public class AttributesFactory<K, V> {
   /**
    * Adds a AsyncEventQueue to the end of list of async event queues on this factory
    *
-   * @param asyncEventQueueId
    * @throws IllegalArgumentException if {@code gatewaySender} is null
    * @since GemFire 7.0
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
index 46f479c..cd45158 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/AttributesMutator.java
@@ -167,7 +167,6 @@ public interface AttributesMutator<K, V> {
   /**
    * Sets cloning on region Note: off-heap regions always behave as if cloning is enabled.
    *
-   * @param cloningEnable
    * @since GemFire 6.1
    */
   void setCloningEnabled(boolean cloningEnable);
@@ -185,28 +184,24 @@ public interface AttributesMutator<K, V> {
    * Adds GatewaySenderId to the list of GatewaySenderIds of the region. If the GatewaySenderId is
    * not present on this VM then it will try to send it to other VM's
    *
-   * @param gatewaySenderId
    */
   void addGatewaySenderId(String gatewaySenderId);
 
   /**
    * Removes GatewaySenderId from the list of GatewaySenderIds of the region.
    *
-   * @param gatewaySenderId
    */
   void removeGatewaySenderId(String gatewaySenderId);
 
   /**
    * Adds AsyncEventQueueId to the list of AsyncEventQueueId of the region.
    *
-   * @param asyncEventQueueId
    */
   void addAsyncEventQueueId(String asyncEventQueueId);
 
   /**
    * Removes AsyncEventQueueId from the list of AsyncEventQueuesId of the region.
    *
-   * @param asyncEventQueueId
    */
   void removeAsyncEventQueueId(String asyncEventQueueId);
 }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Cache.java b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
index c67bdf7..91a2fc2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Cache.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Cache.java
@@ -310,7 +310,6 @@ public interface Cache extends GemFireCache {
   /**
    * Creates {@link GatewaySenderFactory} for creating a SerialGatewaySender
    *
-   * @return SerialGatewaySenderFactory
    * @since GemFire 7.0
    */
   @Override
@@ -319,7 +318,6 @@ public interface Cache extends GemFireCache {
   /**
    * Creates {@link AsyncEventQueueFactory} for creating a AsyncEventQueue
    *
-   * @return AsyncEventQueueFactory
    * @since GemFire 7.0
    */
   AsyncEventQueueFactory createAsyncEventQueueFactory();
@@ -327,7 +325,6 @@ public interface Cache extends GemFireCache {
   /**
    * Creates {@link GatewayReceiverFactory} for creating a GatewayReceiver
    *
-   * @return GatewayReceiverFactory
    * @since GemFire 7.0
    */
   GatewayReceiverFactory createGatewayReceiverFactory();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java b/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
index fc5527f..630ad49 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/CacheTransactionManager.java
@@ -175,7 +175,6 @@ public interface CacheTransactionManager {
    * This method can be used to determine if a transaction with the given transaction identifier is
    * currently suspended locally. This method does not check other members for transaction status.
    *
-   * @param transactionId
    * @return true if the transaction is in suspended state, false otherwise
    * @since GemFire 6.6.2
    * @see #exists(TransactionId)
@@ -317,7 +316,6 @@ public interface CacheTransactionManager {
   /**
    * Set the TransactionWriter for the cache
    *
-   * @param writer
    * @see TransactionWriter
    * @since GemFire 6.5
    */
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 d1285b0..54b6f25 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
@@ -144,7 +144,6 @@ public interface DiskStore {
    * 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
    */
   void forceRoll();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
index d5c5445..97d3d51 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/DiskWriteAttributesFactory.java
@@ -177,7 +177,6 @@ public class DiskWriteAttributesFactory implements java.io.Serializable {
    * Takes an int which is supposed to be in megabytes and converts it to a long. This conversion
    * takes into account that multiplication can lead to Integer.MAX_VALUE being exceeded
    *
-   * @param megaBytes
    * @return the converted value
    */
   private long convertToBytes(int megaBytes) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
index 1f05c31..c1fbac8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/EvictionAction.java
@@ -96,7 +96,6 @@ public final class EvictionAction extends EnumSyntax {
 
   /**
    *
-   * @param s
    * @return the action parsed from the provided string. If there are problems with parsing NONE is
    *         returned.
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
index 5027543..d137fa3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributes.java
@@ -96,7 +96,6 @@ public interface PartitionAttributes<K, V> {
    * not also deprecated.
    *
    * @deprecated use {@link #getLocalMaxMemory()} in GemFire 5.1 and later releases
-   * @return localProperties
    */
   @Deprecated
   Properties getLocalProperties();
@@ -107,7 +106,6 @@ public interface PartitionAttributes<K, V> {
    *
    * @deprecated use {@link #getTotalMaxMemory()} and {@link #getTotalNumBuckets()} in GemFire 5.1
    *             and later releases
-   * @return globalProperties
    */
   @Deprecated
   Properties getGlobalProperties();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
index 1083b83..d7d74b3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/PartitionAttributesFactory.java
@@ -163,7 +163,6 @@ public class PartitionAttributesFactory<K, V> {
    *
    * @param redundantCopies the number of redundant bucket copies, limited to values 0, 1, 2 and 3.
    *
-   * @return this
    */
   public PartitionAttributesFactory<K, V> setRedundantCopies(int redundantCopies) {
     this.partitionAttributes.setRedundantCopies(redundantCopies);
@@ -269,8 +268,6 @@ public class PartitionAttributesFactory<K, V> {
   /**
    * adds a PartitionListener for the partitioned region.
    *
-   * @param listener
-   * @return PartitionAttributeFactory
    * @since GemFire 6.5
    */
   public PartitionAttributesFactory<K, V> addPartitionListener(PartitionListener listener) {
@@ -291,7 +288,6 @@ public class PartitionAttributesFactory<K, V> {
    * provide, behaves. There are currently no non-deprecated local properties.
    *
    * @deprecated use {@link #setLocalMaxMemory(int)} in GemFire 5.1 and later releases
-   * @param localProps
    * @return PartitionAttributeFactory.
    *
    */
@@ -313,7 +309,6 @@ public class PartitionAttributesFactory<K, V> {
    *
    * @deprecated use {@link #setTotalMaxMemory(long)} and {@link #setTotalNumBuckets(int)} in
    *             GemFire 5.1 and later releases
-   * @param globalProps
    * @return PartitionAttributeFactory.
    *
    * @see #GLOBAL_MAX_MEMORY_PROPERTY
diff --git a/geode-core/src/main/java/org/apache/geode/cache/Region.java b/geode-core/src/main/java/org/apache/geode/cache/Region.java
index b7d55cc..a0e78ee 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/Region.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/Region.java
@@ -1244,7 +1244,6 @@ public interface Region<K, V> extends ConcurrentMap<K, V> {
    * oplogs to be compressed and more space to be created.
    *
    * @since GemFire 5.1
-   * @throws DiskAccessException
    * @deprecated use {@link DiskStore#forceRoll} instead.
    */
   @Deprecated
diff --git a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
index e727df1..accc091 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/TransactionWriterException.java
@@ -27,9 +27,6 @@ package org.apache.geode.cache;
  */
 public class TransactionWriterException extends Exception {
 
-  /**
-   *
-   */
   private static final long serialVersionUID = -5557392877576634835L;
 
   public TransactionWriterException(String s) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
index 1946b96..a1097ff 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueue.java
@@ -36,14 +36,12 @@ public interface AsyncEventQueue {
   /**
    * The Disk store that is required for overflow and persistence
    *
-   * @return String
    */
   String getDiskStoreName();// for overflow and persistence
 
   /**
    * The maximum memory after which the data needs to be overflowed to disk. Default is 100 MB.
    *
-   * @return int
    */
   int getMaximumQueueMemory();// for overflow
 
@@ -51,7 +49,6 @@ public interface AsyncEventQueue {
    * Represents the size of a batch that gets delivered over the AsyncEventQueue. Default batchSize
    * is 100.
    *
-   * @return int
    */
   int getBatchSize();
 
@@ -59,7 +56,6 @@ public interface AsyncEventQueue {
    * Represents the maximum time interval that can elapse before a batch is sent from
    * <code>AsyncEventQueue</code>. Default batchTimeInterval is 5 ms.
    *
-   * @return int
    */
   int getBatchTimeInterval();
 
@@ -67,7 +63,6 @@ public interface AsyncEventQueue {
    * Represents whether batch conflation is enabled for batches sent from
    * <code>AsyncEventQueue</code>. Default is false.
    *
-   * @return boolean
    */
   boolean isBatchConflationEnabled();
 
@@ -75,14 +70,12 @@ public interface AsyncEventQueue {
    * Represents whether the AsyncEventQueue is configured to be persistent or non-persistent.
    * Default is false.
    *
-   * @return boolean
    */
   boolean isPersistent();
 
   /**
    * Represents whether writing to disk is synchronous or not. Default is true.
    *
-   * @return boolean
    */
   boolean isDiskSynchronous();
 
@@ -91,7 +84,6 @@ public interface AsyncEventQueue {
    * queue. If the primary queue goes down then the secondary queue first becomes primary and then
    * starts delivering the events.
    *
-   * @return boolean
    */
   boolean isPrimary();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
index e67afdb..e0329a2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/asyncqueue/AsyncEventQueueFactory.java
@@ -47,7 +47,6 @@ public interface AsyncEventQueueFactory {
   /**
    * Sets the disk store name for overflow or persistence.
    *
-   * @param name
    */
   AsyncEventQueueFactory setDiskStoreName(String name);
 
@@ -110,7 +109,6 @@ public interface AsyncEventQueueFactory {
   /**
    * Sets the number of dispatcher thread. Default is 5.
    *
-   * @param numThreads
    */
   AsyncEventQueueFactory setDispatcherThreads(int numThreads);
 
@@ -126,14 +124,12 @@ public interface AsyncEventQueueFactory {
    * Removes the provided <code>GatewayEventFilter</code> from the attributes of AsyncEventQueue
    * being created by factory.
    *
-   * @param filter
    */
   AsyncEventQueueFactory removeGatewayEventFilter(GatewayEventFilter filter);
 
   /**
    * Sets the order policy for multiple dispatchers. Default is KEY.
    *
-   * @param policy
    */
   AsyncEventQueueFactory setOrderPolicy(OrderPolicy policy);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
index bd5badd..add35f0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/ClientRegionFactory.java
@@ -248,7 +248,6 @@ public interface ClientRegionFactory<K, V> {
   /**
    * Sets cloning on region Note: off-heap regions always behave as if cloning is enabled.
    *
-   * @param cloningEnable
    * @return a reference to this ClientRegionFactory object
    * @see AttributesFactory#setCloningEnabled
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
index e0ea42c..3c24f83 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AbstractOp.java
@@ -173,7 +173,6 @@ public abstract class AbstractOp implements Op {
    * Also, such an operation's <code>MessageType</code> must be added in the 'if' condition in
    * {@link ServerConnection#updateAndGetSecurityPart()}
    *
-   * @return boolean
    * @see AbstractOp#sendMessage(Connection)
    * @see ServerConnection#updateAndGetSecurityPart()
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
index 2bc4d58..35ef898 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AuthenticateUserOp.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.client.internal;
 
 import static org.apache.geode.distributed.ConfigurationProperties.SECURITY_CLIENT_AUTH_INIT;
@@ -79,7 +76,6 @@ public class AuthenticateUserOp {
    * @param location The ServerLocation instance whose connection instance will be used to perform
    *        the operation.
    * @param pool The connection pool to use for this operation.
-   * @param securityProps
    * @return Object unique user-id.
    */
   public static Object executeOn(ServerLocation location, ExecutablePool pool,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
index dd40b2f..efb39d6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/AutoConnectionSourceImpl.java
@@ -223,7 +223,6 @@ public class AutoConnectionSourceImpl implements ConnectionSource {
    * has changed. Add the locator back to the list of locators using host address rather than IP.
    * This will cause another DNS lookup, hopefully finding the locator.
    *
-   * @param locator
    */
   protected void updateLocatorInLocatorList(HostAddress locator) {
     if (locator.getSocketInetAddressNoLookup().getHostName() != null && !locator.isIpString()) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
index 38159b5..7184baa 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ClientUpdater.java
@@ -14,9 +14,6 @@
  */
 package org.apache.geode.cache.client.internal;
 
-/**
- *
- */
 public interface ClientUpdater {
 
   void close();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
index 6a8758d..8432be0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManager.java
@@ -38,7 +38,6 @@ public interface EndpointManager {
    * Indicate that a particular server has crashed. All of the listeners will be notified that the
    * server has crashed.
    *
-   * @param endpoint
    */
   void serverCrashed(Endpoint endpoint);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
index 8e3236a..663d99f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/EndpointManagerImpl.java
@@ -35,9 +35,6 @@ import org.apache.geode.internal.cache.tier.InternalClientMembership;
 import org.apache.geode.internal.logging.LogService;
 import org.apache.geode.internal.statistics.DummyStatisticsFactory;
 
-/**
- *
- */
 public class EndpointManagerImpl implements EndpointManager {
   private static final Logger logger = LogService.getLogger();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
index d86d9e8..bad731b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecutablePool.java
@@ -154,7 +154,6 @@ public interface ExecutablePool {
    * All subsequent operations by this thread will be performed on the given ServerLocation. Used
    * for resuming suspended transactions.
    *
-   * @param serverLocation
    * @since GemFire 6.6
    */
   void setServerAffinityLocation(ServerLocation serverLocation);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
index c35eb1d..72a6d93 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionNoAckOp.java
@@ -166,15 +166,6 @@ public class ExecuteFunctionNoAckOp {
       getMessage().addBytesPart(ExecuteFunctionOp.getByteArrayForFlags(allMembers));
     }
 
-    /**
-     * @param functionId
-     * @param args
-     * @param memberMappedArg
-     * @param hasResult
-     * @param isFnSerializationReqd
-     * @param isHA
-     * @param optimizeForWrite
-     */
     public ExecuteFunctionNoAckOpImpl(String functionId, Object args,
         MemberMappedArgument memberMappedArg, byte hasResult, boolean isFnSerializationReqd,
         boolean isHA, boolean optimizeForWrite, String[] groups, boolean allMembers) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
index 337b217..75a69e4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/GetEntryOp.java
@@ -27,9 +27,6 @@ public class GetEntryOp {
   /**
    * Does a region.getEntry on the server using the given pool
    *
-   * @param pool
-   * @param region
-   * @param key
    * @return an {@link EntrySnapshot} for the given key
    */
   public static Object execute(ExecutablePool pool, LocalRegion region, Object key) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
index 6edd7b4..29b288b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PoolImpl.java
@@ -1537,8 +1537,6 @@ public class PoolImpl implements InternalPool {
    * If serverLocation is non-null, check if the the user is authenticated on that server. If not,
    * authenticate it and return.
    *
-   * @param serverLocation
-   * @param op
    */
   private void authenticateIfRequired(ServerLocation serverLocation, Op op) {
     if (this.multiuserSecureModeEnabled && op instanceof AbstractOp
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
index 8c7de27..2e54586 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PrimaryAckOp.java
@@ -31,7 +31,6 @@ public class PrimaryAckOp {
    * Send the primary server acknowledgement on the events this client has received and processed
    * from it using connections from the given pool to communicate with the server.
    *
-   * @param connection
    * @param pool the pool to use to communicate with the server.
    * @param events list of events to acknowledge
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
index fa9015f..8b0f0c4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/PutOp.java
@@ -56,8 +56,6 @@ public class PutOp {
    * @param key the entry key to do the put on
    * @param value the entry value to put
    * @param event the event for this put
-   * @param requireOldValue
-   * @param expectedOldValue
    * @param callbackArg an optional callback arg to pass to any cache callbacks
    */
   public static Object execute(ExecutablePool pool, LocalRegion region, Object key, Object value,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
index 39664f8..e9715a5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/QueueStateImpl.java
@@ -388,7 +388,6 @@ public class QueueStateImpl implements QueueState {
     /**
      * Sets the ackSend
      *
-     * @param ackSend
      */
     public void setAckSend(boolean ackSend) {
       this.ackSend = ackSend;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
index 5a77c17..45bb4c4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ReadyForEventsOp.java
@@ -28,7 +28,6 @@ public class ReadyForEventsOp {
    * subscriptions.
    *
    * @param pool the pool to use to communicate with the server.
-   * @param primary
    */
   public static void execute(ExecutablePool pool, QueueConnectionImpl primary) {
     AbstractOp op = new ReadyForEventsOpImpl();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
index 17b3b5c..779de96 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionDataAccess.java
@@ -46,10 +46,7 @@ public interface ServerRegionDataAccess {
    * @param value the entry value to put
    * @param clientEvent the client event, if any, for eventID and version tag propagation
    * @param op the operation type of this event
-   * @param requireOldValue
-   * @param expectedOldValue
    * @param callbackArg an optional callback arg to pass to any cache callbacks
-   * @param isCreateFwd
    */
   Object put(Object key, Object value, byte[] deltaBytes, EntryEventImpl clientEvent, Operation op,
       boolean requireOldValue, Object expectedOldValue, Object callbackArg, boolean isCreateFwd);
@@ -124,7 +121,6 @@ public interface ServerRegionDataAccess {
   /**
    * gets an entry from the server, does not invoke loaders
    *
-   * @param key
    * @return an {@link EntrySnapshot} for the given key
    */
   Entry getEntry(Object key);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
index 69bcd91..a552a08 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ServerRegionProxy.java
@@ -125,10 +125,6 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
    * <code>Operation.CREATE</code> to the <code>PutOp.execute()</code> method as the caller of this
    * method does not put Delta instances as value.
    *
-   * @param key
-   * @param value
-   * @param event
-   * @param callbackArg
    */
   public Object putForMetaRegion(Object key, Object value, byte[] deltaBytes, EntryEventImpl event,
       Object callbackArg, boolean isMetaRegionPutOp) {
@@ -805,7 +801,6 @@ public class ServerRegionProxy extends ServerProxy implements ServerRegionDataAc
   /**
    * Transaction synchronization notification to the servers
    *
-   * @param status
    * @return the server's TXCommitMessage
    * @see org.apache.geode.internal.cache.tx.ClientTXStateStub#afterCompletion(int)
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
index 1f3f05d..a6e7c68 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopClientExecutor.java
@@ -218,10 +218,6 @@ public class SingleHopClientExecutor {
    * execute bulk op (putAll or removeAll) on multiple PR servers, returning a map of the results.
    * Results are either a VersionedObjectList or a BulkOpPartialResultsException
    *
-   * @param callableTasks
-   * @param cms
-   * @param region
-   * @param failedServers
    * @return the per-server results
    */
   static Map<ServerLocation, Object> submitBulkOp(List callableTasks, ClientMetadataService cms,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
index 73e4c5a..c79990f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/SingleHopOperationCallable.java
@@ -21,10 +21,6 @@ import org.apache.geode.cache.client.internal.ExecuteRegionFunctionOp.ExecuteReg
 import org.apache.geode.cache.client.internal.ExecuteRegionFunctionSingleHopOp.ExecuteRegionFunctionSingleHopOpImpl;
 import org.apache.geode.distributed.internal.ServerLocation;
 
-/**
- *
- *
- */
 public class SingleHopOperationCallable implements Callable {
 
   private final ServerLocation server;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
index 8f5a702..4a894e7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/TXSynchronizationOp.java
@@ -37,7 +37,6 @@ public class TXSynchronizationOp {
   }
 
   /**
-   * @param pool
    * @param status - the status of an afterCompletion notification
    * @param txId - the transaction identifier
    * @param type - BEFORE_COMPLETION or AFTER_COMPLETION
@@ -56,10 +55,6 @@ public class TXSynchronizationOp {
     private CompletionType type;
     TXCommitMessage tXCommitMessageResponse;
 
-    /**
-     * @param status
-     * @param type
-     */
     public Impl(int status, int txId, CompletionType type) {
       super(MessageType.TX_SYNCHRONIZATION, (type == CompletionType.AFTER_COMPLETION) ? 3 : 2);
       this.status = status;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
index 36592fd..921aba2 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersRequest.java
@@ -20,11 +20,6 @@ import java.io.IOException;
 
 import org.apache.geode.internal.DataSerializableFixedID;
 
-/**
- *
- *
- */
-
 public class GetAllServersRequest extends ServerLocationRequest {
 
   public GetAllServersRequest() {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
index 7e8e115..c20a23d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/GetAllServersResponse.java
@@ -21,10 +21,6 @@ import java.util.ArrayList;
 
 import org.apache.geode.internal.DataSerializableFixedID;
 
-/**
- *
- *
- */
 public class GetAllServersResponse extends ServerLocationResponse {
 
   private ArrayList servers;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
index 3da8b07..b4649e7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListRequest.java
@@ -17,9 +17,6 @@ package org.apache.geode.cache.client.internal.locator;
 import org.apache.geode.internal.DataSerializableFixedID;
 
 
-/**
- *
- */
 public class LocatorListRequest extends ServerLocationRequest {
 
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
index ed88f75..80761a9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/LocatorListResponse.java
@@ -22,9 +22,6 @@ import java.util.List;
 import org.apache.geode.distributed.internal.ServerLocation;
 import org.apache.geode.internal.DataSerializableFixedID;
 
-/**
- *
- */
 public class LocatorListResponse extends ServerLocationResponse {
   /** ArrayList of ServerLocations for controllers */
   private List<ServerLocation> controllers;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
index 4807c89..d8d523d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/SerializationHelper.java
@@ -28,9 +28,6 @@ import org.apache.geode.distributed.internal.ServerLocation;
 import org.apache.geode.internal.InternalDataSerializer;
 import org.apache.geode.internal.cache.BucketServerLocation66;
 
-/**
- *
- */
 public class SerializationHelper {
 
   private static void writeServerLocations(Collection/* <ServerLocation> */ serverLocations,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
index a73fea4..9130541 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationRequest.java
@@ -22,9 +22,6 @@ import org.apache.geode.DataSerializer;
 import org.apache.geode.internal.DataSerializableFixedID;
 import org.apache.geode.internal.Version;
 
-/**
- *
- */
 public abstract class ServerLocationRequest implements DataSerializableFixedID {
 
   private String serverGroup;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
index eef1f86..f7ac45b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/ServerLocationResponse.java
@@ -17,9 +17,6 @@ package org.apache.geode.cache.client.internal.locator;
 import org.apache.geode.internal.DataSerializableFixedID;
 import org.apache.geode.internal.Version;
 
-/**
- *
- */
 public abstract class ServerLocationResponse implements DataSerializableFixedID {
   public abstract boolean hasResult();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
index f1b34e4..e3494b3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/locator/wan/LocatorMembershipListener.java
@@ -39,7 +39,6 @@ public interface LocatorMembershipListener {
    * When the new locator is added to remote locator metadata, inform all other locators in remote
    * locator metadata about the new locator so that they can update their remote locator metadata.
    *
-   * @param locator
    */
   void locatorJoined(int distributedSystemId, DistributionLocatorId locator,
       DistributionLocatorId sourceLocator);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
index 1dd57cb..55ddac0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManager.java
@@ -91,7 +91,6 @@ public interface ConnectionManager {
    *        been invalidated).
    * @param excludedServers servers to exclude when looking for a new connection
    * @return a new connection to the pool to a server that is not in the list of excluded servers
-   * @throws AllConnectionsInUseException
    */
   Connection exchangeConnection(Connection conn, Set/* <ServerLocation> */ excludedServers,
       long aquireTimeout) throws AllConnectionsInUseException;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
index 4bd8e0a..b381a0d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/pooling/ConnectionManagerImpl.java
@@ -134,7 +134,6 @@ public class ConnectionManagerImpl implements ConnectionManager {
    * @param idleTimeout The amount of time to wait to expire idle connections. -1 means that idle
    *        connections are never expired.
    * @param lifetimeTimeout the lifetimeTimeout in ms.
-   * @param securityLogger
    */
   public ConnectionManagerImpl(String poolName, ConnectionFactory factory,
       EndpointManager endpointManager, int maxConnections, int minConnections, long idleTimeout,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheConfig.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheConfig.java
index e2b919a..eb4d58a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheConfig.java
@@ -336,9 +336,8 @@ public class CacheConfig {
   /**
    * Gets the value of the cacheTransactionManager property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheTransactionManagerType }
+   * possible object is
+   * {@link CacheTransactionManagerType }
    *
    */
   public CacheTransactionManagerType getCacheTransactionManager() {
@@ -348,9 +347,8 @@ public class CacheConfig {
   /**
    * Sets the value of the cacheTransactionManager property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheTransactionManagerType }
+   * allowed object is
+   * {@link CacheTransactionManagerType }
    *
    */
   public void setCacheTransactionManager(CacheTransactionManagerType value) {
@@ -360,9 +358,8 @@ public class CacheConfig {
   /**
    * Gets the value of the dynamicRegionFactory property.
    *
-   * @return
-   *         possible object is
-   *         {@link DynamicRegionFactoryType }
+   * possible object is
+   * {@link DynamicRegionFactoryType }
    *
    */
   public DynamicRegionFactoryType getDynamicRegionFactory() {
@@ -372,9 +369,8 @@ public class CacheConfig {
   /**
    * Sets the value of the dynamicRegionFactory property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link DynamicRegionFactoryType }
+   * allowed object is
+   * {@link DynamicRegionFactoryType }
    *
    */
   public void setDynamicRegionFactory(DynamicRegionFactoryType value) {
@@ -444,9 +440,8 @@ public class CacheConfig {
   /**
    * Gets the value of the gatewayReceiver property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheConfig.GatewayReceiver }
+   * possible object is
+   * {@link CacheConfig.GatewayReceiver }
    *
    */
   public CacheConfig.GatewayReceiver getGatewayReceiver() {
@@ -456,9 +451,8 @@ public class CacheConfig {
   /**
    * Sets the value of the gatewayReceiver property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheConfig.GatewayReceiver }
+   * allowed object is
+   * {@link CacheConfig.GatewayReceiver }
    *
    */
   public void setGatewayReceiver(CacheConfig.GatewayReceiver value) {
@@ -468,9 +462,8 @@ public class CacheConfig {
   /**
    * Gets the value of the gatewayConflictResolver property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheConfig.GatewayConflictResolver }
+   * possible object is
+   * {@link CacheConfig.GatewayConflictResolver }
    *
    */
   public CacheConfig.GatewayConflictResolver getGatewayConflictResolver() {
@@ -480,9 +473,8 @@ public class CacheConfig {
   /**
    * Sets the value of the gatewayConflictResolver property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheConfig.GatewayConflictResolver }
+   * allowed object is
+   * {@link CacheConfig.GatewayConflictResolver }
    *
    */
   public void setGatewayConflictResolver(CacheConfig.GatewayConflictResolver value) {
@@ -612,9 +604,8 @@ public class CacheConfig {
   /**
    * Gets the value of the pdx property.
    *
-   * @return
-   *         possible object is
-   *         {@link PdxType }
+   * possible object is
+   * {@link PdxType }
    *
    */
   public PdxType getPdx() {
@@ -624,9 +615,8 @@ public class CacheConfig {
   /**
    * Sets the value of the pdx property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link PdxType }
+   * allowed object is
+   * {@link PdxType }
    *
    */
   public void setPdx(PdxType value) {
@@ -727,9 +717,8 @@ public class CacheConfig {
   /**
    * Gets the value of the functionService property.
    *
-   * @return
-   *         possible object is
-   *         {@link FunctionServiceType }
+   * possible object is
+   * {@link FunctionServiceType }
    *
    */
   public FunctionServiceType getFunctionService() {
@@ -739,9 +728,8 @@ public class CacheConfig {
   /**
    * Sets the value of the functionService property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link FunctionServiceType }
+   * allowed object is
+   * {@link FunctionServiceType }
    *
    */
   public void setFunctionService(FunctionServiceType value) {
@@ -751,9 +739,8 @@ public class CacheConfig {
   /**
    * Gets the value of the resourceManager property.
    *
-   * @return
-   *         possible object is
-   *         {@link ResourceManagerType }
+   * possible object is
+   * {@link ResourceManagerType }
    *
    */
   public ResourceManagerType getResourceManager() {
@@ -763,9 +750,8 @@ public class CacheConfig {
   /**
    * Sets the value of the resourceManager property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link ResourceManagerType }
+   * allowed object is
+   * {@link ResourceManagerType }
    *
    */
   public void setResourceManager(ResourceManagerType value) {
@@ -775,9 +761,8 @@ public class CacheConfig {
   /**
    * Gets the value of the serializationRegistration property.
    *
-   * @return
-   *         possible object is
-   *         {@link SerializationRegistrationType }
+   * possible object is
+   * {@link SerializationRegistrationType }
    *
    */
   public SerializationRegistrationType getSerializationRegistration() {
@@ -787,9 +772,8 @@ public class CacheConfig {
   /**
    * Sets the value of the serializationRegistration property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link SerializationRegistrationType }
+   * allowed object is
+   * {@link SerializationRegistrationType }
    *
    */
   public void setSerializationRegistration(SerializationRegistrationType value) {
@@ -829,9 +813,8 @@ public class CacheConfig {
   /**
    * Gets the value of the initializer property.
    *
-   * @return
-   *         possible object is
-   *         {@link InitializerType }
+   * possible object is
+   * {@link InitializerType }
    *
    */
   public InitializerType getInitializer() {
@@ -841,9 +824,8 @@ public class CacheConfig {
   /**
    * Sets the value of the initializer property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link InitializerType }
+   * allowed object is
+   * {@link InitializerType }
    *
    */
   public void setInitializer(InitializerType value) {
@@ -884,9 +866,8 @@ public class CacheConfig {
   /**
    * Gets the value of the copyOnRead property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isCopyOnRead() {
@@ -896,9 +877,8 @@ public class CacheConfig {
   /**
    * Sets the value of the copyOnRead property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setCopyOnRead(Boolean value) {
@@ -908,9 +888,8 @@ public class CacheConfig {
   /**
    * Gets the value of the isServer property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isIsServer() {
@@ -920,9 +899,8 @@ public class CacheConfig {
   /**
    * Sets the value of the isServer property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setIsServer(Boolean value) {
@@ -932,9 +910,8 @@ public class CacheConfig {
   /**
    * Gets the value of the lockTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getLockTimeout() {
@@ -944,9 +921,8 @@ public class CacheConfig {
   /**
    * Sets the value of the lockTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setLockTimeout(String value) {
@@ -956,9 +932,8 @@ public class CacheConfig {
   /**
    * Gets the value of the lockLease property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getLockLease() {
@@ -968,9 +943,8 @@ public class CacheConfig {
   /**
    * Sets the value of the lockLease property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setLockLease(String value) {
@@ -980,9 +954,8 @@ public class CacheConfig {
   /**
    * Gets the value of the messageSyncInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMessageSyncInterval() {
@@ -992,9 +965,8 @@ public class CacheConfig {
   /**
    * Sets the value of the messageSyncInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMessageSyncInterval(String value) {
@@ -1004,9 +976,8 @@ public class CacheConfig {
   /**
    * Gets the value of the searchTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSearchTimeout() {
@@ -1016,9 +987,8 @@ public class CacheConfig {
   /**
    * Sets the value of the searchTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSearchTimeout(String value) {
@@ -1028,9 +998,8 @@ public class CacheConfig {
   /**
    * Gets the value of the version property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getVersion() {
@@ -1044,9 +1013,8 @@ public class CacheConfig {
   /**
    * Sets the value of the version property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setVersion(String value) {
@@ -1160,9 +1128,8 @@ public class CacheConfig {
     /**
      * Gets the value of the gatewayEventSubstitutionFilter property.
      *
-     * @return
-     *         possible object is
-     *         {@link ClassWithParametersType }
+     * possible object is
+     * {@link ClassWithParametersType }
      *
      */
     public ClassWithParametersType getGatewayEventSubstitutionFilter() {
@@ -1172,9 +1139,8 @@ public class CacheConfig {
     /**
      * Sets the value of the gatewayEventSubstitutionFilter property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ClassWithParametersType }
+     * allowed object is
+     * {@link ClassWithParametersType }
      *
      */
     public void setGatewayEventSubstitutionFilter(ClassWithParametersType value) {
@@ -1184,9 +1150,8 @@ public class CacheConfig {
     /**
      * Gets the value of the asyncEventListener property.
      *
-     * @return
-     *         possible object is
-     *         {@link ClassWithParametersType }
+     * possible object is
+     * {@link ClassWithParametersType }
      *
      */
     public ClassWithParametersType getAsyncEventListener() {
@@ -1196,9 +1161,8 @@ public class CacheConfig {
     /**
      * Sets the value of the asyncEventListener property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ClassWithParametersType }
+     * allowed object is
+     * {@link ClassWithParametersType }
      *
      */
     public void setAsyncEventListener(ClassWithParametersType value) {
@@ -1208,9 +1172,8 @@ public class CacheConfig {
     /**
      * Gets the value of the id property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getId() {
@@ -1220,9 +1183,8 @@ public class CacheConfig {
     /**
      * Sets the value of the id property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setId(String value) {
@@ -1232,9 +1194,8 @@ public class CacheConfig {
     /**
      * Gets the value of the parallel property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isParallel() {
@@ -1244,9 +1205,8 @@ public class CacheConfig {
     /**
      * Sets the value of the parallel property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setParallel(Boolean value) {
@@ -1256,9 +1216,8 @@ public class CacheConfig {
     /**
      * Gets the value of the batchSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBatchSize() {
@@ -1268,9 +1227,8 @@ public class CacheConfig {
     /**
      * Sets the value of the batchSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBatchSize(String value) {
@@ -1280,9 +1238,8 @@ public class CacheConfig {
     /**
      * Gets the value of the batchTimeInterval property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBatchTimeInterval() {
@@ -1292,9 +1249,8 @@ public class CacheConfig {
     /**
      * Sets the value of the batchTimeInterval property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBatchTimeInterval(String value) {
@@ -1304,9 +1260,8 @@ public class CacheConfig {
     /**
      * Gets the value of the enableBatchConflation property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isEnableBatchConflation() {
@@ -1316,9 +1271,8 @@ public class CacheConfig {
     /**
      * Sets the value of the enableBatchConflation property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setEnableBatchConflation(Boolean value) {
@@ -1328,9 +1282,8 @@ public class CacheConfig {
     /**
      * Gets the value of the maximumQueueMemory property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaximumQueueMemory() {
@@ -1340,9 +1293,8 @@ public class CacheConfig {
     /**
      * Sets the value of the maximumQueueMemory property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaximumQueueMemory(String value) {
@@ -1352,9 +1304,8 @@ public class CacheConfig {
     /**
      * Gets the value of the persistent property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isPersistent() {
@@ -1364,9 +1315,8 @@ public class CacheConfig {
     /**
      * Sets the value of the persistent property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setPersistent(Boolean value) {
@@ -1376,9 +1326,8 @@ public class CacheConfig {
     /**
      * Gets the value of the diskStoreName property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getDiskStoreName() {
@@ -1388,9 +1337,8 @@ public class CacheConfig {
     /**
      * Sets the value of the diskStoreName property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setDiskStoreName(String value) {
@@ -1400,9 +1348,8 @@ public class CacheConfig {
     /**
      * Gets the value of the diskSynchronous property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isDiskSynchronous() {
@@ -1412,9 +1359,8 @@ public class CacheConfig {
     /**
      * Sets the value of the diskSynchronous property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setDiskSynchronous(Boolean value) {
@@ -1424,9 +1370,8 @@ public class CacheConfig {
     /**
      * Gets the value of the dispatcherThreads property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getDispatcherThreads() {
@@ -1436,9 +1381,8 @@ public class CacheConfig {
     /**
      * Sets the value of the dispatcherThreads property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setDispatcherThreads(String value) {
@@ -1448,9 +1392,8 @@ public class CacheConfig {
     /**
      * Gets the value of the orderPolicy property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getOrderPolicy() {
@@ -1460,9 +1403,8 @@ public class CacheConfig {
     /**
      * Sets the value of the orderPolicy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setOrderPolicy(String value) {
@@ -1472,9 +1414,8 @@ public class CacheConfig {
     /**
      * Gets the value of the forwardExpirationDestroy property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public boolean isForwardExpirationDestroy() {
@@ -1488,9 +1429,8 @@ public class CacheConfig {
     /**
      * Sets the value of the forwardExpirationDestroy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setForwardExpirationDestroy(Boolean value) {
@@ -1529,9 +1469,8 @@ public class CacheConfig {
     /**
      * Gets the value of the tcpNoDelay property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isTcpNoDelay() {
@@ -1541,9 +1480,8 @@ public class CacheConfig {
     /**
      * Sets the value of the tcpNoDelay property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setTcpNoDelay(Boolean value) {
@@ -1588,9 +1526,8 @@ public class CacheConfig {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -1600,9 +1537,8 @@ public class CacheConfig {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
@@ -1792,9 +1728,8 @@ public class CacheConfig {
     /**
      * Gets the value of the id property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getId() {
@@ -1804,9 +1739,8 @@ public class CacheConfig {
     /**
      * Sets the value of the id property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setId(String value) {
@@ -1816,9 +1750,8 @@ public class CacheConfig {
     /**
      * Gets the value of the bindAddress property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBindAddress() {
@@ -1828,9 +1761,8 @@ public class CacheConfig {
     /**
      * Sets the value of the bindAddress property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBindAddress(String value) {
@@ -1840,9 +1772,8 @@ public class CacheConfig {
     /**
      * Gets the value of the maximumTimeBetweenPings property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaximumTimeBetweenPings() {
@@ -1852,9 +1783,8 @@ public class CacheConfig {
     /**
      * Sets the value of the maximumTimeBetweenPings property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaximumTimeBetweenPings(String value) {
@@ -1864,9 +1794,8 @@ public class CacheConfig {
     /**
      * Gets the value of the port property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getPort() {
@@ -1876,9 +1805,8 @@ public class CacheConfig {
     /**
      * Sets the value of the port property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setPort(String value) {
@@ -1888,9 +1816,8 @@ public class CacheConfig {
     /**
      * Gets the value of the socketBufferSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getSocketBufferSize() {
@@ -1900,9 +1827,8 @@ public class CacheConfig {
     /**
      * Sets the value of the socketBufferSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setSocketBufferSize(String value) {
@@ -1912,9 +1838,8 @@ public class CacheConfig {
     /**
      * Gets the value of the startupPolicy property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getStartupPolicy() {
@@ -1924,9 +1849,8 @@ public class CacheConfig {
     /**
      * Sets the value of the startupPolicy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setStartupPolicy(String value) {
@@ -1936,9 +1860,8 @@ public class CacheConfig {
     /**
      * Gets the value of the manualStart property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isManualStart() {
@@ -1948,9 +1871,8 @@ public class CacheConfig {
     /**
      * Sets the value of the manualStart property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setManualStart(Boolean value) {
@@ -1960,9 +1882,8 @@ public class CacheConfig {
     /**
      * Gets the value of the maxConnections property.
      *
-     * @return
-     *         possible object is
-     *         {@link BigInteger }
+     * possible object is
+     * {@link BigInteger }
      *
      */
     public BigInteger getMaxConnections() {
@@ -1972,9 +1893,8 @@ public class CacheConfig {
     /**
      * Sets the value of the maxConnections property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link BigInteger }
+     * allowed object is
+     * {@link BigInteger }
      *
      */
     public void setMaxConnections(BigInteger value) {
@@ -2136,9 +2056,8 @@ public class CacheConfig {
       /**
        * Gets the value of the gatewayQueue property.
        *
-       * @return
-       *         possible object is
-       *         {@link CacheConfig.GatewayHub.Gateway.GatewayQueue }
+       * possible object is
+       * {@link CacheConfig.GatewayHub.Gateway.GatewayQueue }
        *
        */
       public CacheConfig.GatewayHub.Gateway.GatewayQueue getGatewayQueue() {
@@ -2148,9 +2067,8 @@ public class CacheConfig {
       /**
        * Sets the value of the gatewayQueue property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link CacheConfig.GatewayHub.Gateway.GatewayQueue }
+       * allowed object is
+       * {@link CacheConfig.GatewayHub.Gateway.GatewayQueue }
        *
        */
       public void setGatewayQueue(CacheConfig.GatewayHub.Gateway.GatewayQueue value) {
@@ -2160,9 +2078,8 @@ public class CacheConfig {
       /**
        * Gets the value of the earlyAck property.
        *
-       * @return
-       *         possible object is
-       *         {@link Boolean }
+       * possible object is
+       * {@link Boolean }
        *
        */
       public Boolean isEarlyAck() {
@@ -2172,9 +2089,8 @@ public class CacheConfig {
       /**
        * Sets the value of the earlyAck property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link Boolean }
+       * allowed object is
+       * {@link Boolean }
        *
        */
       public void setEarlyAck(Boolean value) {
@@ -2184,9 +2100,8 @@ public class CacheConfig {
       /**
        * Gets the value of the id property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getId() {
@@ -2196,9 +2111,8 @@ public class CacheConfig {
       /**
        * Sets the value of the id property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setId(String value) {
@@ -2208,9 +2122,8 @@ public class CacheConfig {
       /**
        * Gets the value of the socketBufferSize property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getSocketBufferSize() {
@@ -2220,9 +2133,8 @@ public class CacheConfig {
       /**
        * Sets the value of the socketBufferSize property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setSocketBufferSize(String value) {
@@ -2232,9 +2144,8 @@ public class CacheConfig {
       /**
        * Gets the value of the socketReadTimeout property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getSocketReadTimeout() {
@@ -2244,9 +2155,8 @@ public class CacheConfig {
       /**
        * Sets the value of the socketReadTimeout property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setSocketReadTimeout(String value) {
@@ -2256,9 +2166,8 @@ public class CacheConfig {
       /**
        * Gets the value of the concurrencyLevel property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getConcurrencyLevel() {
@@ -2268,9 +2177,8 @@ public class CacheConfig {
       /**
        * Sets the value of the concurrencyLevel property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setConcurrencyLevel(String value) {
@@ -2280,9 +2188,8 @@ public class CacheConfig {
       /**
        * Gets the value of the orderPolicy property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getOrderPolicy() {
@@ -2292,9 +2199,8 @@ public class CacheConfig {
       /**
        * Sets the value of the orderPolicy property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setOrderPolicy(String value) {
@@ -2337,9 +2243,8 @@ public class CacheConfig {
         /**
          * Gets the value of the host property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getHost() {
@@ -2349,9 +2254,8 @@ public class CacheConfig {
         /**
          * Sets the value of the host property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setHost(String value) {
@@ -2361,9 +2265,8 @@ public class CacheConfig {
         /**
          * Gets the value of the id property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getId() {
@@ -2373,9 +2276,8 @@ public class CacheConfig {
         /**
          * Sets the value of the id property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setId(String value) {
@@ -2385,9 +2287,8 @@ public class CacheConfig {
         /**
          * Gets the value of the port property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getPort() {
@@ -2397,9 +2298,8 @@ public class CacheConfig {
         /**
          * Sets the value of the port property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setPort(String value) {
@@ -2444,9 +2344,8 @@ public class CacheConfig {
         /**
          * Gets the value of the className property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getClassName() {
@@ -2456,9 +2355,8 @@ public class CacheConfig {
         /**
          * Sets the value of the className property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setClassName(String value) {
@@ -2551,9 +2449,8 @@ public class CacheConfig {
         /**
          * Gets the value of the alertThreshold property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getAlertThreshold() {
@@ -2563,9 +2460,8 @@ public class CacheConfig {
         /**
          * Sets the value of the alertThreshold property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setAlertThreshold(String value) {
@@ -2575,9 +2471,8 @@ public class CacheConfig {
         /**
          * Gets the value of the batchConflation property.
          *
-         * @return
-         *         possible object is
-         *         {@link Boolean }
+         * possible object is
+         * {@link Boolean }
          *
          */
         public Boolean isBatchConflation() {
@@ -2587,9 +2482,8 @@ public class CacheConfig {
         /**
          * Sets the value of the batchConflation property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link Boolean }
+         * allowed object is
+         * {@link Boolean }
          *
          */
         public void setBatchConflation(Boolean value) {
@@ -2599,9 +2493,8 @@ public class CacheConfig {
         /**
          * Gets the value of the batchSize property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getBatchSize() {
@@ -2611,9 +2504,8 @@ public class CacheConfig {
         /**
          * Sets the value of the batchSize property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setBatchSize(String value) {
@@ -2623,9 +2515,8 @@ public class CacheConfig {
         /**
          * Gets the value of the batchTimeInterval property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getBatchTimeInterval() {
@@ -2635,9 +2526,8 @@ public class CacheConfig {
         /**
          * Sets the value of the batchTimeInterval property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setBatchTimeInterval(String value) {
@@ -2647,9 +2537,8 @@ public class CacheConfig {
         /**
          * Gets the value of the enablePersistence property.
          *
-         * @return
-         *         possible object is
-         *         {@link Boolean }
+         * possible object is
+         * {@link Boolean }
          *
          */
         public Boolean isEnablePersistence() {
@@ -2659,9 +2548,8 @@ public class CacheConfig {
         /**
          * Sets the value of the enablePersistence property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link Boolean }
+         * allowed object is
+         * {@link Boolean }
          *
          */
         public void setEnablePersistence(Boolean value) {
@@ -2671,9 +2559,8 @@ public class CacheConfig {
         /**
          * Gets the value of the diskStoreName property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getDiskStoreName() {
@@ -2683,9 +2570,8 @@ public class CacheConfig {
         /**
          * Sets the value of the diskStoreName property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setDiskStoreName(String value) {
@@ -2695,9 +2581,8 @@ public class CacheConfig {
         /**
          * Gets the value of the rollOplogs property.
          *
-         * @return
-         *         possible object is
-         *         {@link Boolean }
+         * possible object is
+         * {@link Boolean }
          *
          */
         public Boolean isRollOplogs() {
@@ -2707,9 +2592,8 @@ public class CacheConfig {
         /**
          * Sets the value of the rollOplogs property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link Boolean }
+         * allowed object is
+         * {@link Boolean }
          *
          */
         public void setRollOplogs(Boolean value) {
@@ -2719,9 +2603,8 @@ public class CacheConfig {
         /**
          * Gets the value of the maximumQueueMemory property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getMaximumQueueMemory() {
@@ -2731,9 +2614,8 @@ public class CacheConfig {
         /**
          * Sets the value of the maximumQueueMemory property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setMaximumQueueMemory(String value) {
@@ -2743,9 +2625,8 @@ public class CacheConfig {
         /**
          * Gets the value of the overflowDirectory property.
          *
-         * @return
-         *         possible object is
-         *         {@link String }
+         * possible object is
+         * {@link String }
          *
          */
         public String getOverflowDirectory() {
@@ -2755,9 +2636,8 @@ public class CacheConfig {
         /**
          * Sets the value of the overflowDirectory property.
          *
-         * @param value
-         *        allowed object is
-         *        {@link String }
+         * allowed object is
+         * {@link String }
          *
          */
         public void setOverflowDirectory(String value) {
@@ -2854,9 +2734,8 @@ public class CacheConfig {
     /**
      * Gets the value of the startPort property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getStartPort() {
@@ -2866,9 +2745,8 @@ public class CacheConfig {
     /**
      * Sets the value of the startPort property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setStartPort(String value) {
@@ -2878,9 +2756,8 @@ public class CacheConfig {
     /**
      * Gets the value of the endPort property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getEndPort() {
@@ -2890,9 +2767,8 @@ public class CacheConfig {
     /**
      * Sets the value of the endPort property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setEndPort(String value) {
@@ -2902,9 +2778,8 @@ public class CacheConfig {
     /**
      * Gets the value of the bindAddress property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBindAddress() {
@@ -2914,9 +2789,8 @@ public class CacheConfig {
     /**
      * Sets the value of the bindAddress property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBindAddress(String value) {
@@ -2926,9 +2800,8 @@ public class CacheConfig {
     /**
      * Gets the value of the maximumTimeBetweenPings property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaximumTimeBetweenPings() {
@@ -2938,9 +2811,8 @@ public class CacheConfig {
     /**
      * Sets the value of the maximumTimeBetweenPings property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaximumTimeBetweenPings(String value) {
@@ -2950,9 +2822,8 @@ public class CacheConfig {
     /**
      * Gets the value of the socketBufferSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getSocketBufferSize() {
@@ -2962,9 +2833,8 @@ public class CacheConfig {
     /**
      * Sets the value of the socketBufferSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setSocketBufferSize(String value) {
@@ -2974,9 +2844,8 @@ public class CacheConfig {
     /**
      * Gets the value of the hostnameForSenders property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getHostnameForSenders() {
@@ -2986,9 +2855,8 @@ public class CacheConfig {
     /**
      * Sets the value of the hostnameForSenders property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setHostnameForSenders(String value) {
@@ -2998,9 +2866,8 @@ public class CacheConfig {
     /**
      * Gets the value of the manualStart property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isManualStart() {
@@ -3010,9 +2877,8 @@ public class CacheConfig {
     /**
      * Sets the value of the manualStart property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setManualStart(Boolean value) {
@@ -3140,9 +3006,8 @@ public class CacheConfig {
     /**
      * Gets the value of the gatewayEventSubstitutionFilter property.
      *
-     * @return
-     *         possible object is
-     *         {@link ClassWithParametersType }
+     * possible object is
+     * {@link ClassWithParametersType }
      *
      */
     public ClassWithParametersType getGatewayEventSubstitutionFilter() {
@@ -3152,9 +3017,8 @@ public class CacheConfig {
     /**
      * Sets the value of the gatewayEventSubstitutionFilter property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ClassWithParametersType }
+     * allowed object is
+     * {@link ClassWithParametersType }
      *
      */
     public void setGatewayEventSubstitutionFilter(ClassWithParametersType value) {
@@ -3194,9 +3058,8 @@ public class CacheConfig {
     /**
      * Gets the value of the id property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getId() {
@@ -3206,9 +3069,8 @@ public class CacheConfig {
     /**
      * Sets the value of the id property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setId(String value) {
@@ -3218,9 +3080,8 @@ public class CacheConfig {
     /**
      * Gets the value of the remoteDistributedSystemId property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getRemoteDistributedSystemId() {
@@ -3230,9 +3091,8 @@ public class CacheConfig {
     /**
      * Sets the value of the remoteDistributedSystemId property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setRemoteDistributedSystemId(String value) {
@@ -3242,9 +3102,8 @@ public class CacheConfig {
     /**
      * Gets the value of the parallel property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isParallel() {
@@ -3254,9 +3113,8 @@ public class CacheConfig {
     /**
      * Sets the value of the parallel property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setParallel(Boolean value) {
@@ -3266,9 +3124,8 @@ public class CacheConfig {
     /**
      * Gets the value of the manualStart property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isManualStart() {
@@ -3278,9 +3135,8 @@ public class CacheConfig {
     /**
      * Sets the value of the manualStart property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setManualStart(Boolean value) {
@@ -3290,9 +3146,8 @@ public class CacheConfig {
     /**
      * Gets the value of the socketBufferSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getSocketBufferSize() {
@@ -3302,9 +3157,8 @@ public class CacheConfig {
     /**
      * Sets the value of the socketBufferSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setSocketBufferSize(String value) {
@@ -3314,9 +3168,8 @@ public class CacheConfig {
     /**
      * Gets the value of the socketReadTimeout property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getSocketReadTimeout() {
@@ -3326,9 +3179,8 @@ public class CacheConfig {
     /**
      * Sets the value of the socketReadTimeout property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setSocketReadTimeout(String value) {
@@ -3338,9 +3190,8 @@ public class CacheConfig {
     /**
      * Gets the value of the enableBatchConflation property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isEnableBatchConflation() {
@@ -3350,9 +3201,8 @@ public class CacheConfig {
     /**
      * Sets the value of the enableBatchConflation property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setEnableBatchConflation(Boolean value) {
@@ -3362,9 +3212,8 @@ public class CacheConfig {
     /**
      * Gets the value of the batchSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBatchSize() {
@@ -3374,9 +3223,8 @@ public class CacheConfig {
     /**
      * Sets the value of the batchSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBatchSize(String value) {
@@ -3386,9 +3234,8 @@ public class CacheConfig {
     /**
      * Gets the value of the batchTimeInterval property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBatchTimeInterval() {
@@ -3398,9 +3245,8 @@ public class CacheConfig {
     /**
      * Sets the value of the batchTimeInterval property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBatchTimeInterval(String value) {
@@ -3410,9 +3256,8 @@ public class CacheConfig {
     /**
      * Gets the value of the enablePersistence property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isEnablePersistence() {
@@ -3422,9 +3267,8 @@ public class CacheConfig {
     /**
      * Sets the value of the enablePersistence property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setEnablePersistence(Boolean value) {
@@ -3434,9 +3278,8 @@ public class CacheConfig {
     /**
      * Gets the value of the diskStoreName property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getDiskStoreName() {
@@ -3446,9 +3289,8 @@ public class CacheConfig {
     /**
      * Sets the value of the diskStoreName property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setDiskStoreName(String value) {
@@ -3458,9 +3300,8 @@ public class CacheConfig {
     /**
      * Gets the value of the diskSynchronous property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isDiskSynchronous() {
@@ -3470,9 +3311,8 @@ public class CacheConfig {
     /**
      * Sets the value of the diskSynchronous property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setDiskSynchronous(Boolean value) {
@@ -3482,9 +3322,8 @@ public class CacheConfig {
     /**
      * Gets the value of the maximumQueueMemory property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaximumQueueMemory() {
@@ -3494,9 +3333,8 @@ public class CacheConfig {
     /**
      * Sets the value of the maximumQueueMemory property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaximumQueueMemory(String value) {
@@ -3506,9 +3344,8 @@ public class CacheConfig {
     /**
      * Gets the value of the alertThreshold property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getAlertThreshold() {
@@ -3518,9 +3355,8 @@ public class CacheConfig {
     /**
      * Sets the value of the alertThreshold property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setAlertThreshold(String value) {
@@ -3530,9 +3366,8 @@ public class CacheConfig {
     /**
      * Gets the value of the dispatcherThreads property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getDispatcherThreads() {
@@ -3542,9 +3377,8 @@ public class CacheConfig {
     /**
      * Sets the value of the dispatcherThreads property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setDispatcherThreads(String value) {
@@ -3554,9 +3388,8 @@ public class CacheConfig {
     /**
      * Gets the value of the orderPolicy property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getOrderPolicy() {
@@ -3566,9 +3399,8 @@ public class CacheConfig {
     /**
      * Sets the value of the orderPolicy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setOrderPolicy(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheLoaderType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheLoaderType.java
index a0bd7b7..8789573 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheLoaderType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheLoaderType.java
@@ -70,9 +70,8 @@ public class CacheLoaderType {
   /**
    * Gets the value of the className property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getClassName() {
@@ -82,9 +81,8 @@ public class CacheLoaderType {
   /**
    * Sets the value of the className property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheTransactionManagerType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheTransactionManagerType.java
index 4c8dd4c..5956983 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheTransactionManagerType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheTransactionManagerType.java
@@ -122,9 +122,8 @@ public class CacheTransactionManagerType {
   /**
    * Gets the value of the transactionWriter property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheTransactionManagerType.TransactionWriter }
+   * possible object is
+   * {@link CacheTransactionManagerType.TransactionWriter }
    *
    */
   public CacheTransactionManagerType.TransactionWriter getTransactionWriter() {
@@ -134,9 +133,8 @@ public class CacheTransactionManagerType {
   /**
    * Sets the value of the transactionWriter property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheTransactionManagerType.TransactionWriter }
+   * allowed object is
+   * {@link CacheTransactionManagerType.TransactionWriter }
    *
    */
   public void setTransactionWriter(CacheTransactionManagerType.TransactionWriter value) {
@@ -179,9 +177,8 @@ public class CacheTransactionManagerType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -191,9 +188,8 @@ public class CacheTransactionManagerType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
@@ -268,9 +264,8 @@ public class CacheTransactionManagerType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -280,9 +275,8 @@ public class CacheTransactionManagerType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheWriterType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheWriterType.java
index bfeec61..e5d3cc4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheWriterType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/CacheWriterType.java
@@ -70,9 +70,8 @@ public class CacheWriterType {
   /**
    * Gets the value of the className property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getClassName() {
@@ -82,9 +81,8 @@ public class CacheWriterType {
   /**
    * Sets the value of the className property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/ClassWithParametersType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/ClassWithParametersType.java
index 33610bf..121a2c7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/ClassWithParametersType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/ClassWithParametersType.java
@@ -66,9 +66,8 @@ public class ClassWithParametersType {
   /**
    * Gets the value of the className property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getClassName() {
@@ -78,9 +77,8 @@ public class ClassWithParametersType {
   /**
    * Sets the value of the className property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/DeclarableType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/DeclarableType.java
index dfc4df3..f06b9ac 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/DeclarableType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/DeclarableType.java
@@ -70,9 +70,8 @@ public class DeclarableType {
   /**
    * Gets the value of the className property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getClassName() {
@@ -82,9 +81,8 @@ public class DeclarableType {
   /**
    * Sets the value of the className property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskDirType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskDirType.java
index 4b762f6..7239839 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskDirType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskDirType.java
@@ -66,9 +66,8 @@ public class DiskDirType {
    * A "disk-dir" element specifies one of a region or diskstore's disk directories.
    *
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getContent() {
@@ -78,9 +77,8 @@ public class DiskDirType {
   /**
    * Sets the value of the content property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setContent(String value) {
@@ -90,9 +88,8 @@ public class DiskDirType {
   /**
    * Gets the value of the dirSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getDirSize() {
@@ -102,9 +99,8 @@ public class DiskDirType {
   /**
    * Sets the value of the dirSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setDirSize(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskStoreType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskStoreType.java
index 9467044..0ecb168 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskStoreType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/DiskStoreType.java
@@ -94,9 +94,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the diskDirs property.
    *
-   * @return
-   *         possible object is
-   *         {@link DiskDirsType }
+   * possible object is
+   * {@link DiskDirsType }
    *
    */
   public DiskDirsType getDiskDirs() {
@@ -106,9 +105,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the diskDirs property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link DiskDirsType }
+   * allowed object is
+   * {@link DiskDirsType }
    *
    */
   public void setDiskDirs(DiskDirsType value) {
@@ -118,9 +116,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the name property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getName() {
@@ -130,9 +127,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the name property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setName(String value) {
@@ -142,9 +138,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the autoCompact property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isAutoCompact() {
@@ -154,9 +149,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the autoCompact property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setAutoCompact(Boolean value) {
@@ -166,9 +160,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the compactionThreshold property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getCompactionThreshold() {
@@ -178,9 +171,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the compactionThreshold property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setCompactionThreshold(String value) {
@@ -190,9 +182,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the allowForceCompaction property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isAllowForceCompaction() {
@@ -202,9 +193,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the allowForceCompaction property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setAllowForceCompaction(Boolean value) {
@@ -214,9 +204,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the maxOplogSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaxOplogSize() {
@@ -226,9 +215,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the maxOplogSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaxOplogSize(String value) {
@@ -238,9 +226,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the timeInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getTimeInterval() {
@@ -250,9 +237,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the timeInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setTimeInterval(String value) {
@@ -262,9 +248,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the writeBufferSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getWriteBufferSize() {
@@ -274,9 +259,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the writeBufferSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setWriteBufferSize(String value) {
@@ -286,9 +270,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the queueSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getQueueSize() {
@@ -298,9 +281,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the queueSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setQueueSize(String value) {
@@ -310,9 +292,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the diskUsageWarningPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getDiskUsageWarningPercentage() {
@@ -322,9 +303,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the diskUsageWarningPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setDiskUsageWarningPercentage(String value) {
@@ -334,9 +314,8 @@ public class DiskStoreType {
   /**
    * Gets the value of the diskUsageCriticalPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getDiskUsageCriticalPercentage() {
@@ -346,9 +325,8 @@ public class DiskStoreType {
   /**
    * Sets the value of the diskUsageCriticalPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setDiskUsageCriticalPercentage(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/DynamicRegionFactoryType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/DynamicRegionFactoryType.java
index 37f55c5..b1a4e64 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/DynamicRegionFactoryType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/DynamicRegionFactoryType.java
@@ -86,9 +86,8 @@ public class DynamicRegionFactoryType {
   /**
    * Gets the value of the diskDir property.
    *
-   * @return
-   *         possible object is
-   *         {@link DiskDirType }
+   * possible object is
+   * {@link DiskDirType }
    *
    */
   public DiskDirType getDiskDir() {
@@ -98,9 +97,8 @@ public class DynamicRegionFactoryType {
   /**
    * Sets the value of the diskDir property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link DiskDirType }
+   * allowed object is
+   * {@link DiskDirType }
    *
    */
   public void setDiskDir(DiskDirType value) {
@@ -110,9 +108,8 @@ public class DynamicRegionFactoryType {
   /**
    * Gets the value of the disablePersistBackup property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isDisablePersistBackup() {
@@ -122,9 +119,8 @@ public class DynamicRegionFactoryType {
   /**
    * Sets the value of the disablePersistBackup property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setDisablePersistBackup(Boolean value) {
@@ -134,9 +130,8 @@ public class DynamicRegionFactoryType {
   /**
    * Gets the value of the disableRegisterInterest property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isDisableRegisterInterest() {
@@ -146,9 +141,8 @@ public class DynamicRegionFactoryType {
   /**
    * Sets the value of the disableRegisterInterest property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setDisableRegisterInterest(Boolean value) {
@@ -158,9 +152,8 @@ public class DynamicRegionFactoryType {
   /**
    * Gets the value of the poolName property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getPoolName() {
@@ -170,9 +163,8 @@ public class DynamicRegionFactoryType {
   /**
    * Sets the value of the poolName property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setPoolName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/ExpirationAttributesType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/ExpirationAttributesType.java
index fb6dd34..87eec06 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/ExpirationAttributesType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/ExpirationAttributesType.java
@@ -93,9 +93,8 @@ public class ExpirationAttributesType {
   /**
    * Gets the value of the customExpiry property.
    *
-   * @return
-   *         possible object is
-   *         {@link ExpirationAttributesType.CustomExpiry }
+   * possible object is
+   * {@link ExpirationAttributesType.CustomExpiry }
    *
    */
   public ExpirationAttributesType.CustomExpiry getCustomExpiry() {
@@ -105,9 +104,8 @@ public class ExpirationAttributesType {
   /**
    * Sets the value of the customExpiry property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link ExpirationAttributesType.CustomExpiry }
+   * allowed object is
+   * {@link ExpirationAttributesType.CustomExpiry }
    *
    */
   public void setCustomExpiry(ExpirationAttributesType.CustomExpiry value) {
@@ -117,9 +115,8 @@ public class ExpirationAttributesType {
   /**
    * Gets the value of the action property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getAction() {
@@ -129,9 +126,8 @@ public class ExpirationAttributesType {
   /**
    * Sets the value of the action property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setAction(String value) {
@@ -141,9 +137,8 @@ public class ExpirationAttributesType {
   /**
    * Gets the value of the timeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getTimeout() {
@@ -153,9 +148,8 @@ public class ExpirationAttributesType {
   /**
    * Sets the value of the timeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setTimeout(String value) {
@@ -198,9 +192,8 @@ public class ExpirationAttributesType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -210,9 +203,8 @@ public class ExpirationAttributesType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/FunctionServiceType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/FunctionServiceType.java
index 78e69d4..3875ba9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/FunctionServiceType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/FunctionServiceType.java
@@ -141,9 +141,8 @@ public class FunctionServiceType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -153,9 +152,8 @@ public class FunctionServiceType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/InitializerType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/InitializerType.java
index e3bf557..d655904 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/InitializerType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/InitializerType.java
@@ -72,9 +72,8 @@ public class InitializerType {
   /**
    * Gets the value of the className property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getClassName() {
@@ -84,9 +83,8 @@ public class InitializerType {
   /**
    * Sets the value of the className property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/JndiBindingsType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/JndiBindingsType.java
index e677d57..9a4930f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/JndiBindingsType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/JndiBindingsType.java
@@ -270,9 +270,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the blockingTimeoutSeconds property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getBlockingTimeoutSeconds() {
@@ -282,9 +281,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the blockingTimeoutSeconds property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setBlockingTimeoutSeconds(String value) {
@@ -294,9 +292,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the connPooledDatasourceClass property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getConnPooledDatasourceClass() {
@@ -306,9 +303,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the connPooledDatasourceClass property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setConnPooledDatasourceClass(String value) {
@@ -318,9 +314,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the connectionUrl property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getConnectionUrl() {
@@ -330,9 +325,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the connectionUrl property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setConnectionUrl(String value) {
@@ -342,9 +336,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the idleTimeoutSeconds property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getIdleTimeoutSeconds() {
@@ -354,9 +347,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the idleTimeoutSeconds property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setIdleTimeoutSeconds(String value) {
@@ -366,9 +358,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the initPoolSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getInitPoolSize() {
@@ -378,9 +369,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the initPoolSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setInitPoolSize(String value) {
@@ -390,9 +380,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the jdbcDriverClass property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getJdbcDriverClass() {
@@ -402,9 +391,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the jdbcDriverClass property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setJdbcDriverClass(String value) {
@@ -414,9 +402,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the jndiName property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getJndiName() {
@@ -426,9 +413,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the jndiName property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setJndiName(String value) {
@@ -438,9 +424,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the loginTimeoutSeconds property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getLoginTimeoutSeconds() {
@@ -450,9 +435,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the loginTimeoutSeconds property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setLoginTimeoutSeconds(String value) {
@@ -462,9 +446,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the managedConnFactoryClass property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getManagedConnFactoryClass() {
@@ -474,9 +457,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the managedConnFactoryClass property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setManagedConnFactoryClass(String value) {
@@ -486,9 +468,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the maxPoolSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaxPoolSize() {
@@ -498,9 +479,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the maxPoolSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaxPoolSize(String value) {
@@ -510,9 +490,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the password property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getPassword() {
@@ -522,9 +501,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the password property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setPassword(String value) {
@@ -534,9 +512,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the transactionType property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getTransactionType() {
@@ -546,9 +523,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the transactionType property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setTransactionType(String value) {
@@ -558,9 +534,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the type property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getType() {
@@ -570,9 +545,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the type property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setType(String value) {
@@ -582,9 +556,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the userName property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getUserName() {
@@ -594,9 +567,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the userName property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setUserName(String value) {
@@ -606,9 +578,8 @@ public class JndiBindingsType {
     /**
      * Gets the value of the xaDatasourceClass property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getXaDatasourceClass() {
@@ -618,9 +589,8 @@ public class JndiBindingsType {
     /**
      * Sets the value of the xaDatasourceClass property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setXaDatasourceClass(String value) {
@@ -692,9 +662,8 @@ public class JndiBindingsType {
       /**
        * Gets the value of the configPropertyName property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getName() {
@@ -704,9 +673,8 @@ public class JndiBindingsType {
       /**
        * Sets the value of the configPropertyName property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setName(String value) {
@@ -716,9 +684,8 @@ public class JndiBindingsType {
       /**
        * Gets the value of the configPropertyType property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getType() {
@@ -728,9 +695,8 @@ public class JndiBindingsType {
       /**
        * Sets the value of the configPropertyType property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setType(String value) {
@@ -740,9 +706,8 @@ public class JndiBindingsType {
       /**
        * Gets the value of the configPropertyValue property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getValue() {
@@ -752,9 +717,8 @@ public class JndiBindingsType {
       /**
        * Sets the value of the configPropertyValue property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setValue(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/ParameterType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/ParameterType.java
index 2518c5e..08c3586 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/ParameterType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/ParameterType.java
@@ -70,9 +70,8 @@ public class ParameterType {
   /**
    * Gets the value of the string property.
    *
-   * @return
-   *         possible object is
-   *         {@link StringType }
+   * possible object is
+   * {@link StringType }
    *
    */
   public StringType getString() {
@@ -82,9 +81,8 @@ public class ParameterType {
   /**
    * Sets the value of the string property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link StringType }
+   * allowed object is
+   * {@link StringType }
    *
    */
   public void setString(StringType value) {
@@ -94,9 +92,8 @@ public class ParameterType {
   /**
    * Gets the value of the declarable property.
    *
-   * @return
-   *         possible object is
-   *         {@link DeclarableType }
+   * possible object is
+   * {@link DeclarableType }
    *
    */
   public DeclarableType getDeclarable() {
@@ -106,9 +103,8 @@ public class ParameterType {
   /**
    * Sets the value of the declarable property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link DeclarableType }
+   * allowed object is
+   * {@link DeclarableType }
    *
    */
   public void setDeclarable(DeclarableType value) {
@@ -118,9 +114,8 @@ public class ParameterType {
   /**
    * Gets the value of the name property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getName() {
@@ -130,9 +125,8 @@ public class ParameterType {
   /**
    * Sets the value of the name property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/PdxType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/PdxType.java
index 459276b..ffcdabe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/PdxType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/PdxType.java
@@ -91,9 +91,8 @@ public class PdxType {
   /**
    * Gets the value of the pdxSerializer property.
    *
-   * @return
-   *         possible object is
-   *         {@link PdxType.PdxSerializer }
+   * possible object is
+   * {@link PdxType.PdxSerializer }
    *
    */
   public PdxType.PdxSerializer getPdxSerializer() {
@@ -103,9 +102,8 @@ public class PdxType {
   /**
    * Sets the value of the pdxSerializer property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link PdxType.PdxSerializer }
+   * allowed object is
+   * {@link PdxType.PdxSerializer }
    *
    */
   public void setPdxSerializer(PdxType.PdxSerializer value) {
@@ -115,9 +113,8 @@ public class PdxType {
   /**
    * Gets the value of the readSerialized property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isReadSerialized() {
@@ -127,9 +124,8 @@ public class PdxType {
   /**
    * Sets the value of the readSerialized property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setReadSerialized(Boolean value) {
@@ -139,9 +135,8 @@ public class PdxType {
   /**
    * Gets the value of the ignoreUnreadFields property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isIgnoreUnreadFields() {
@@ -151,9 +146,8 @@ public class PdxType {
   /**
    * Sets the value of the ignoreUnreadFields property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setIgnoreUnreadFields(Boolean value) {
@@ -163,9 +157,8 @@ public class PdxType {
   /**
    * Gets the value of the persistent property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isPersistent() {
@@ -175,9 +168,8 @@ public class PdxType {
   /**
    * Sets the value of the persistent property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setPersistent(Boolean value) {
@@ -187,9 +179,8 @@ public class PdxType {
   /**
    * Gets the value of the diskStoreName property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getDiskStoreName() {
@@ -199,9 +190,8 @@ public class PdxType {
   /**
    * Sets the value of the diskStoreName property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setDiskStoreName(String value) {
@@ -244,9 +234,8 @@ public class PdxType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -256,9 +245,8 @@ public class PdxType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/PoolType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/PoolType.java
index 092d318..c7df922 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/PoolType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/PoolType.java
@@ -211,9 +211,8 @@ public class PoolType {
   /**
    * Gets the value of the subscriptionTimeoutMultiplier property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSubscriptionTimeoutMultiplier() {
@@ -223,9 +222,8 @@ public class PoolType {
   /**
    * Sets the value of the subscriptionTimeoutMultiplier property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSubscriptionTimeoutMultiplier(String value) {
@@ -235,9 +233,8 @@ public class PoolType {
   /**
    * Gets the value of the socketConnectTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSocketConnectTimeout() {
@@ -247,9 +244,8 @@ public class PoolType {
   /**
    * Sets the value of the socketConnectTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSocketConnectTimeout(String value) {
@@ -259,9 +255,8 @@ public class PoolType {
   /**
    * Gets the value of the freeConnectionTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getFreeConnectionTimeout() {
@@ -271,9 +266,8 @@ public class PoolType {
   /**
    * Sets the value of the freeConnectionTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setFreeConnectionTimeout(String value) {
@@ -283,9 +277,8 @@ public class PoolType {
   /**
    * Gets the value of the loadConditioningInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getLoadConditioningInterval() {
@@ -295,9 +288,8 @@ public class PoolType {
   /**
    * Sets the value of the loadConditioningInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setLoadConditioningInterval(String value) {
@@ -307,9 +299,8 @@ public class PoolType {
   /**
    * Gets the value of the minConnections property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMinConnections() {
@@ -319,9 +310,8 @@ public class PoolType {
   /**
    * Sets the value of the minConnections property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMinConnections(String value) {
@@ -331,9 +321,8 @@ public class PoolType {
   /**
    * Gets the value of the maxConnections property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaxConnections() {
@@ -343,9 +332,8 @@ public class PoolType {
   /**
    * Sets the value of the maxConnections property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaxConnections(String value) {
@@ -355,9 +343,8 @@ public class PoolType {
   /**
    * Gets the value of the retryAttempts property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getRetryAttempts() {
@@ -367,9 +354,8 @@ public class PoolType {
   /**
    * Sets the value of the retryAttempts property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setRetryAttempts(String value) {
@@ -379,9 +365,8 @@ public class PoolType {
   /**
    * Gets the value of the idleTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getIdleTimeout() {
@@ -391,9 +376,8 @@ public class PoolType {
   /**
    * Sets the value of the idleTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setIdleTimeout(String value) {
@@ -403,9 +387,8 @@ public class PoolType {
   /**
    * Gets the value of the pingInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getPingInterval() {
@@ -415,9 +398,8 @@ public class PoolType {
   /**
    * Sets the value of the pingInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setPingInterval(String value) {
@@ -427,9 +409,8 @@ public class PoolType {
   /**
    * Gets the value of the name property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getName() {
@@ -439,9 +420,8 @@ public class PoolType {
   /**
    * Sets the value of the name property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setName(String value) {
@@ -451,9 +431,8 @@ public class PoolType {
   /**
    * Gets the value of the readTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getReadTimeout() {
@@ -463,9 +442,8 @@ public class PoolType {
   /**
    * Sets the value of the readTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setReadTimeout(String value) {
@@ -475,9 +453,8 @@ public class PoolType {
   /**
    * Gets the value of the serverGroup property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getServerGroup() {
@@ -487,9 +464,8 @@ public class PoolType {
   /**
    * Sets the value of the serverGroup property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setServerGroup(String value) {
@@ -499,9 +475,8 @@ public class PoolType {
   /**
    * Gets the value of the socketBufferSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSocketBufferSize() {
@@ -511,9 +486,8 @@ public class PoolType {
   /**
    * Sets the value of the socketBufferSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSocketBufferSize(String value) {
@@ -523,9 +497,8 @@ public class PoolType {
   /**
    * Gets the value of the subscriptionEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isSubscriptionEnabled() {
@@ -535,9 +508,8 @@ public class PoolType {
   /**
    * Sets the value of the subscriptionEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setSubscriptionEnabled(Boolean value) {
@@ -547,9 +519,8 @@ public class PoolType {
   /**
    * Gets the value of the subscriptionMessageTrackingTimeout property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSubscriptionMessageTrackingTimeout() {
@@ -559,9 +530,8 @@ public class PoolType {
   /**
    * Sets the value of the subscriptionMessageTrackingTimeout property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSubscriptionMessageTrackingTimeout(String value) {
@@ -571,9 +541,8 @@ public class PoolType {
   /**
    * Gets the value of the subscriptionAckInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSubscriptionAckInterval() {
@@ -583,9 +552,8 @@ public class PoolType {
   /**
    * Sets the value of the subscriptionAckInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSubscriptionAckInterval(String value) {
@@ -595,9 +563,8 @@ public class PoolType {
   /**
    * Gets the value of the subscriptionRedundancy property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSubscriptionRedundancy() {
@@ -607,9 +574,8 @@ public class PoolType {
   /**
    * Sets the value of the subscriptionRedundancy property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSubscriptionRedundancy(String value) {
@@ -619,9 +585,8 @@ public class PoolType {
   /**
    * Gets the value of the statisticInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getStatisticInterval() {
@@ -631,9 +596,8 @@ public class PoolType {
   /**
    * Sets the value of the statisticInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setStatisticInterval(String value) {
@@ -643,9 +607,8 @@ public class PoolType {
   /**
    * Gets the value of the threadLocalConnections property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isThreadLocalConnections() {
@@ -655,9 +618,8 @@ public class PoolType {
   /**
    * Sets the value of the threadLocalConnections property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setThreadLocalConnections(Boolean value) {
@@ -667,9 +629,8 @@ public class PoolType {
   /**
    * Gets the value of the prSingleHopEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isPrSingleHopEnabled() {
@@ -679,9 +640,8 @@ public class PoolType {
   /**
    * Sets the value of the prSingleHopEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setPrSingleHopEnabled(Boolean value) {
@@ -691,9 +651,8 @@ public class PoolType {
   /**
    * Gets the value of the multiuserAuthentication property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isMultiuserAuthentication() {
@@ -703,9 +662,8 @@ public class PoolType {
   /**
    * Sets the value of the multiuserAuthentication property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setMultiuserAuthentication(Boolean value) {
@@ -745,9 +703,8 @@ public class PoolType {
     /**
      * Gets the value of the host property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getHost() {
@@ -757,9 +714,8 @@ public class PoolType {
     /**
      * Sets the value of the host property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setHost(String value) {
@@ -769,9 +725,8 @@ public class PoolType {
     /**
      * Gets the value of the port property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getPort() {
@@ -781,9 +736,8 @@ public class PoolType {
     /**
      * Sets the value of the port property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setPort(String value) {
@@ -825,9 +779,8 @@ public class PoolType {
     /**
      * Gets the value of the host property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getHost() {
@@ -837,9 +790,8 @@ public class PoolType {
     /**
      * Sets the value of the host property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setHost(String value) {
@@ -849,9 +801,8 @@ public class PoolType {
     /**
      * Gets the value of the port property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getPort() {
@@ -861,9 +812,8 @@ public class PoolType {
     /**
      * Sets the value of the port property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setPort(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionAttributesType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionAttributesType.java
index b1d9cad..a829629 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionAttributesType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionAttributesType.java
@@ -427,9 +427,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the keyConstraint property.
    *
-   * @return
-   *         possible object is
-   *         {@link Object }
+   * possible object is
+   * {@link Object }
    *
    */
   public Object getKeyConstraint() {
@@ -439,9 +438,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the keyConstraint property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Object }
+   * allowed object is
+   * {@link Object }
    *
    */
   public void setKeyConstraint(Object value) {
@@ -451,9 +449,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the valueConstraint property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getValueConstraint() {
@@ -463,9 +460,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the valueConstraint property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setValueConstraint(String value) {
@@ -475,9 +471,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the regionTimeToLive property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.RegionTimeToLive }
+   * possible object is
+   * {@link RegionAttributesType.RegionTimeToLive }
    *
    */
   public RegionAttributesType.RegionTimeToLive getRegionTimeToLive() {
@@ -487,9 +482,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the regionTimeToLive property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.RegionTimeToLive }
+   * allowed object is
+   * {@link RegionAttributesType.RegionTimeToLive }
    *
    */
   public void setRegionTimeToLive(RegionAttributesType.RegionTimeToLive value) {
@@ -499,9 +493,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the regionIdleTime property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.RegionIdleTime }
+   * possible object is
+   * {@link RegionAttributesType.RegionIdleTime }
    *
    */
   public RegionAttributesType.RegionIdleTime getRegionIdleTime() {
@@ -511,9 +504,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the regionIdleTime property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.RegionIdleTime }
+   * allowed object is
+   * {@link RegionAttributesType.RegionIdleTime }
    *
    */
   public void setRegionIdleTime(RegionAttributesType.RegionIdleTime value) {
@@ -523,9 +515,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the entryTimeToLive property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.EntryTimeToLive }
+   * possible object is
+   * {@link RegionAttributesType.EntryTimeToLive }
    *
    */
   public RegionAttributesType.EntryTimeToLive getEntryTimeToLive() {
@@ -535,9 +526,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the entryTimeToLive property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.EntryTimeToLive }
+   * allowed object is
+   * {@link RegionAttributesType.EntryTimeToLive }
    *
    */
   public void setEntryTimeToLive(RegionAttributesType.EntryTimeToLive value) {
@@ -547,9 +537,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the entryIdleTime property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.EntryIdleTime }
+   * possible object is
+   * {@link RegionAttributesType.EntryIdleTime }
    *
    */
   public RegionAttributesType.EntryIdleTime getEntryIdleTime() {
@@ -559,9 +548,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the entryIdleTime property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.EntryIdleTime }
+   * allowed object is
+   * {@link RegionAttributesType.EntryIdleTime }
    *
    */
   public void setEntryIdleTime(RegionAttributesType.EntryIdleTime value) {
@@ -571,9 +559,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the diskWriteAttributes property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.DiskWriteAttributes }
+   * possible object is
+   * {@link RegionAttributesType.DiskWriteAttributes }
    *
    */
   public RegionAttributesType.DiskWriteAttributes getDiskWriteAttributes() {
@@ -583,9 +570,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the diskWriteAttributes property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.DiskWriteAttributes }
+   * allowed object is
+   * {@link RegionAttributesType.DiskWriteAttributes }
    *
    */
   public void setDiskWriteAttributes(RegionAttributesType.DiskWriteAttributes value) {
@@ -595,9 +581,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the diskDirs property.
    *
-   * @return
-   *         possible object is
-   *         {@link DiskDirsType }
+   * possible object is
+   * {@link DiskDirsType }
    *
    */
   public DiskDirsType getDiskDirs() {
@@ -607,9 +592,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the diskDirs property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link DiskDirsType }
+   * allowed object is
+   * {@link DiskDirsType }
    *
    */
   public void setDiskDirs(DiskDirsType value) {
@@ -619,9 +603,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the partitionAttributes property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.PartitionAttributes }
+   * possible object is
+   * {@link RegionAttributesType.PartitionAttributes }
    *
    */
   public RegionAttributesType.PartitionAttributes getPartitionAttributes() {
@@ -631,9 +614,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the partitionAttributes property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.PartitionAttributes }
+   * allowed object is
+   * {@link RegionAttributesType.PartitionAttributes }
    *
    */
   public void setPartitionAttributes(RegionAttributesType.PartitionAttributes value) {
@@ -643,9 +625,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the membershipAttributes property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.MembershipAttributes }
+   * possible object is
+   * {@link RegionAttributesType.MembershipAttributes }
    *
    */
   public RegionAttributesType.MembershipAttributes getMembershipAttributes() {
@@ -655,9 +636,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the membershipAttributes property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.MembershipAttributes }
+   * allowed object is
+   * {@link RegionAttributesType.MembershipAttributes }
    *
    */
   public void setMembershipAttributes(RegionAttributesType.MembershipAttributes value) {
@@ -667,9 +647,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the subscriptionAttributes property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.SubscriptionAttributes }
+   * possible object is
+   * {@link RegionAttributesType.SubscriptionAttributes }
    *
    */
   public RegionAttributesType.SubscriptionAttributes getSubscriptionAttributes() {
@@ -679,9 +658,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the subscriptionAttributes property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.SubscriptionAttributes }
+   * allowed object is
+   * {@link RegionAttributesType.SubscriptionAttributes }
    *
    */
   public void setSubscriptionAttributes(RegionAttributesType.SubscriptionAttributes value) {
@@ -691,9 +669,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the cacheLoader property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheLoaderType }
+   * possible object is
+   * {@link CacheLoaderType }
    *
    */
   public CacheLoaderType getCacheLoader() {
@@ -703,9 +680,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the cacheLoader property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheLoaderType }
+   * allowed object is
+   * {@link CacheLoaderType }
    *
    */
   public void setCacheLoader(CacheLoaderType value) {
@@ -715,9 +691,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the cacheWriter property.
    *
-   * @return
-   *         possible object is
-   *         {@link CacheWriterType }
+   * possible object is
+   * {@link CacheWriterType }
    *
    */
   public CacheWriterType getCacheWriter() {
@@ -727,9 +702,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the cacheWriter property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link CacheWriterType }
+   * allowed object is
+   * {@link CacheWriterType }
    *
    */
   public void setCacheWriter(CacheWriterType value) {
@@ -769,9 +743,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the compressor property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.Compressor }
+   * possible object is
+   * {@link RegionAttributesType.Compressor }
    *
    */
   public RegionAttributesType.Compressor getCompressor() {
@@ -781,9 +754,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the compressor property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.Compressor }
+   * allowed object is
+   * {@link RegionAttributesType.Compressor }
    *
    */
   public void setCompressor(RegionAttributesType.Compressor value) {
@@ -793,9 +765,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the evictionAttributes property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesType.EvictionAttributes }
+   * possible object is
+   * {@link RegionAttributesType.EvictionAttributes }
    *
    */
   public RegionAttributesType.EvictionAttributes getEvictionAttributes() {
@@ -805,9 +776,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the evictionAttributes property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesType.EvictionAttributes }
+   * allowed object is
+   * {@link RegionAttributesType.EvictionAttributes }
    *
    */
   public void setEvictionAttributes(RegionAttributesType.EvictionAttributes value) {
@@ -817,9 +787,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the concurrencyLevel property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getConcurrencyLevel() {
@@ -829,9 +798,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the concurrencyLevel property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setConcurrencyLevel(String value) {
@@ -841,9 +809,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the dataPolicy property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesDataPolicy }
+   * possible object is
+   * {@link RegionAttributesDataPolicy }
    *
    */
   public RegionAttributesDataPolicy getDataPolicy() {
@@ -853,9 +820,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the dataPolicy property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesDataPolicy }
+   * allowed object is
+   * {@link RegionAttributesDataPolicy }
    *
    */
   public void setDataPolicy(RegionAttributesDataPolicy value) {
@@ -865,9 +831,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the earlyAck property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isEarlyAck() {
@@ -877,9 +842,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the earlyAck property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setEarlyAck(Boolean value) {
@@ -889,9 +853,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the enableAsyncConflation property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isEnableAsyncConflation() {
@@ -901,9 +864,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the enableAsyncConflation property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setEnableAsyncConflation(Boolean value) {
@@ -913,9 +875,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the enableGateway property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isEnableGateway() {
@@ -925,9 +886,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the enableGateway property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setEnableGateway(Boolean value) {
@@ -937,9 +897,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the enableSubscriptionConflation property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isEnableSubscriptionConflation() {
@@ -949,9 +908,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the enableSubscriptionConflation property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setEnableSubscriptionConflation(Boolean value) {
@@ -961,9 +919,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the gatewaySenderIds property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getGatewaySenderIds() {
@@ -973,9 +930,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the gatewaySenderIds property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setGatewaySenderIds(String value) {
@@ -985,9 +941,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the asyncEventQueueIds property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getAsyncEventQueueIds() {
@@ -997,9 +952,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the asyncEventQueueIds property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setAsyncEventQueueIds(String value) {
@@ -1009,9 +963,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the hubId property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getHubId() {
@@ -1021,9 +974,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the hubId property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setHubId(String value) {
@@ -1033,9 +985,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the id property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getId() {
@@ -1045,9 +996,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the id property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setId(String value) {
@@ -1057,9 +1007,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the ignoreJta property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isIgnoreJta() {
@@ -1069,9 +1018,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the ignoreJta property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setIgnoreJta(Boolean value) {
@@ -1081,9 +1029,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the indexUpdateType property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesIndexUpdateType }
+   * possible object is
+   * {@link RegionAttributesIndexUpdateType }
    *
    */
   public RegionAttributesIndexUpdateType getIndexUpdateType() {
@@ -1093,9 +1040,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the indexUpdateType property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesIndexUpdateType }
+   * allowed object is
+   * {@link RegionAttributesIndexUpdateType }
    *
    */
   public void setIndexUpdateType(RegionAttributesIndexUpdateType value) {
@@ -1105,9 +1051,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the initialCapacity property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getInitialCapacity() {
@@ -1117,9 +1062,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the initialCapacity property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setInitialCapacity(String value) {
@@ -1129,9 +1073,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the isLockGrantor property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isIsLockGrantor() {
@@ -1141,9 +1084,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the isLockGrantor property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setIsLockGrantor(Boolean value) {
@@ -1153,9 +1095,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the loadFactor property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getLoadFactor() {
@@ -1165,9 +1106,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the loadFactor property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setLoadFactor(String value) {
@@ -1177,9 +1117,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the mirrorType property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesMirrorType }
+   * possible object is
+   * {@link RegionAttributesMirrorType }
    *
    */
   public RegionAttributesMirrorType getMirrorType() {
@@ -1189,9 +1128,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the mirrorType property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesMirrorType }
+   * allowed object is
+   * {@link RegionAttributesMirrorType }
    *
    */
   public void setMirrorType(RegionAttributesMirrorType value) {
@@ -1201,9 +1139,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the multicastEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isMulticastEnabled() {
@@ -1213,9 +1150,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the multicastEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setMulticastEnabled(Boolean value) {
@@ -1225,9 +1161,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the persistBackup property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isPersistBackup() {
@@ -1237,9 +1172,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the persistBackup property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setPersistBackup(Boolean value) {
@@ -1249,9 +1183,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the poolName property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getPoolName() {
@@ -1261,9 +1194,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the poolName property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setPoolName(String value) {
@@ -1273,9 +1205,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the diskStoreName property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getDiskStoreName() {
@@ -1285,9 +1216,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the diskStoreName property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setDiskStoreName(String value) {
@@ -1297,9 +1227,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the diskSynchronous property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isDiskSynchronous() {
@@ -1309,9 +1238,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the diskSynchronous property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setDiskSynchronous(Boolean value) {
@@ -1321,9 +1249,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the publisher property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isPublisher() {
@@ -1333,9 +1260,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the publisher property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setPublisher(Boolean value) {
@@ -1345,9 +1271,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the refid property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getRefid() {
@@ -1357,9 +1282,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the refid property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setRefid(String value) {
@@ -1369,9 +1293,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the scope property.
    *
-   * @return
-   *         possible object is
-   *         {@link RegionAttributesScope }
+   * possible object is
+   * {@link RegionAttributesScope }
    *
    */
   public RegionAttributesScope getScope() {
@@ -1381,9 +1304,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the scope property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link RegionAttributesScope }
+   * allowed object is
+   * {@link RegionAttributesScope }
    *
    */
   public void setScope(RegionAttributesScope value) {
@@ -1393,9 +1315,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the statisticsEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isStatisticsEnabled() {
@@ -1405,9 +1326,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the statisticsEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setStatisticsEnabled(Boolean value) {
@@ -1417,9 +1337,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the cloningEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isCloningEnabled() {
@@ -1429,9 +1348,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the cloningEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setCloningEnabled(Boolean value) {
@@ -1441,9 +1359,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the concurrencyChecksEnabled property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public boolean isConcurrencyChecksEnabled() {
@@ -1457,9 +1374,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the concurrencyChecksEnabled property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setConcurrencyChecksEnabled(Boolean value) {
@@ -1469,9 +1385,8 @@ public class RegionAttributesType {
   /**
    * Gets the value of the offHeap property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isOffHeap() {
@@ -1481,9 +1396,8 @@ public class RegionAttributesType {
   /**
    * Sets the value of the offHeap property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setOffHeap(Boolean value) {
@@ -1526,9 +1440,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -1538,9 +1451,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
@@ -1612,9 +1524,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -1624,9 +1535,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
@@ -1685,9 +1595,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the asynchronousWrites property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionAttributesType.DiskWriteAttributes.AsynchronousWrites }
+     * possible object is
+     * {@link RegionAttributesType.DiskWriteAttributes.AsynchronousWrites }
      *
      */
     public RegionAttributesType.DiskWriteAttributes.AsynchronousWrites getAsynchronousWrites() {
@@ -1697,9 +1606,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the asynchronousWrites property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionAttributesType.DiskWriteAttributes.AsynchronousWrites }
+     * allowed object is
+     * {@link RegionAttributesType.DiskWriteAttributes.AsynchronousWrites }
      *
      */
     public void setAsynchronousWrites(
@@ -1710,9 +1618,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the synchronousWrites property.
      *
-     * @return
-     *         possible object is
-     *         {@link Object }
+     * possible object is
+     * {@link Object }
      *
      */
     public Object getSynchronousWrites() {
@@ -1722,9 +1629,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the synchronousWrites property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Object }
+     * allowed object is
+     * {@link Object }
      *
      */
     public void setSynchronousWrites(Object value) {
@@ -1734,9 +1640,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the maxOplogSize property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getMaxOplogSize() {
@@ -1746,9 +1651,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the maxOplogSize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setMaxOplogSize(String value) {
@@ -1758,9 +1662,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the rollOplogs property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getRollOplogs() {
@@ -1770,9 +1673,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the rollOplogs property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setRollOplogs(String value) {
@@ -1812,9 +1714,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the bytesThreshold property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getBytesThreshold() {
@@ -1824,9 +1725,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the bytesThreshold property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setBytesThreshold(String value) {
@@ -1836,9 +1736,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the timeInterval property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getTimeInterval() {
@@ -1848,9 +1747,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the timeInterval property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setTimeInterval(String value) {
@@ -1894,9 +1792,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the expirationAttributes property.
      *
-     * @return
-     *         possible object is
-     *         {@link ExpirationAttributesType }
+     * possible object is
+     * {@link ExpirationAttributesType }
      *
      */
     public ExpirationAttributesType getExpirationAttributes() {
@@ -1906,9 +1803,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the expirationAttributes property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ExpirationAttributesType }
+     * allowed object is
+     * {@link ExpirationAttributesType }
      *
      */
     public void setExpirationAttributes(ExpirationAttributesType value) {
@@ -1950,9 +1846,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the expirationAttributes property.
      *
-     * @return
-     *         possible object is
-     *         {@link ExpirationAttributesType }
+     * possible object is
+     * {@link ExpirationAttributesType }
      *
      */
     public ExpirationAttributesType getExpirationAttributes() {
@@ -1962,9 +1857,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the expirationAttributes property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ExpirationAttributesType }
+     * allowed object is
+     * {@link ExpirationAttributesType }
      *
      */
     public void setExpirationAttributes(ExpirationAttributesType value) {
@@ -2045,9 +1939,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the lruEntryCount property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionAttributesType.EvictionAttributes.LruEntryCount }
+     * possible object is
+     * {@link RegionAttributesType.EvictionAttributes.LruEntryCount }
      *
      */
     public RegionAttributesType.EvictionAttributes.LruEntryCount getLruEntryCount() {
@@ -2057,9 +1950,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the lruEntryCount property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionAttributesType.EvictionAttributes.LruEntryCount }
+     * allowed object is
+     * {@link RegionAttributesType.EvictionAttributes.LruEntryCount }
      *
      */
     public void setLruEntryCount(RegionAttributesType.EvictionAttributes.LruEntryCount value) {
@@ -2069,9 +1961,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the lruHeapPercentage property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionAttributesType.EvictionAttributes.LruHeapPercentage }
+     * possible object is
+     * {@link RegionAttributesType.EvictionAttributes.LruHeapPercentage }
      *
      */
     public RegionAttributesType.EvictionAttributes.LruHeapPercentage getLruHeapPercentage() {
@@ -2081,9 +1972,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the lruHeapPercentage property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionAttributesType.EvictionAttributes.LruHeapPercentage }
+     * allowed object is
+     * {@link RegionAttributesType.EvictionAttributes.LruHeapPercentage }
      *
      */
     public void setLruHeapPercentage(
@@ -2094,9 +1984,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the lruMemorySize property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionAttributesType.EvictionAttributes.LruMemorySize }
+     * possible object is
+     * {@link RegionAttributesType.EvictionAttributes.LruMemorySize }
      *
      */
     public RegionAttributesType.EvictionAttributes.LruMemorySize getLruMemorySize() {
@@ -2106,9 +1995,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the lruMemorySize property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionAttributesType.EvictionAttributes.LruMemorySize }
+     * allowed object is
+     * {@link RegionAttributesType.EvictionAttributes.LruMemorySize }
      *
      */
     public void setLruMemorySize(RegionAttributesType.EvictionAttributes.LruMemorySize value) {
@@ -2148,9 +2036,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the action property.
        *
-       * @return
-       *         possible object is
-       *         {@link EnumActionDestroyOverflow }
+       * possible object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public EnumActionDestroyOverflow getAction() {
@@ -2160,9 +2047,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the action property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link EnumActionDestroyOverflow }
+       * allowed object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public void setAction(EnumActionDestroyOverflow value) {
@@ -2172,9 +2058,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the maximum property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getMaximum() {
@@ -2184,9 +2069,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the maximum property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setMaximum(String value) {
@@ -2233,9 +2117,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the className property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getClassName() {
@@ -2245,9 +2128,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the className property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setClassName(String value) {
@@ -2287,9 +2169,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the action property.
        *
-       * @return
-       *         possible object is
-       *         {@link EnumActionDestroyOverflow }
+       * possible object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public EnumActionDestroyOverflow getAction() {
@@ -2299,9 +2180,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the action property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link EnumActionDestroyOverflow }
+       * allowed object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public void setAction(EnumActionDestroyOverflow value) {
@@ -2351,9 +2231,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the className property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getClassName() {
@@ -2363,9 +2242,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the className property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setClassName(String value) {
@@ -2405,9 +2283,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the action property.
        *
-       * @return
-       *         possible object is
-       *         {@link EnumActionDestroyOverflow }
+       * possible object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public EnumActionDestroyOverflow getAction() {
@@ -2417,9 +2294,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the action property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link EnumActionDestroyOverflow }
+       * allowed object is
+       * {@link EnumActionDestroyOverflow }
        *
        */
       public void setAction(EnumActionDestroyOverflow value) {
@@ -2429,9 +2305,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the maximum property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getMaximum() {
@@ -2441,9 +2316,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the maximum property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setMaximum(String value) {
@@ -2546,9 +2420,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the lossAction property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getLossAction() {
@@ -2558,9 +2431,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the lossAction property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setLossAction(String value) {
@@ -2570,9 +2442,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the resumptionAction property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getResumptionAction() {
@@ -2582,9 +2453,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the resumptionAction property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setResumptionAction(String value) {
@@ -2621,9 +2491,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the name property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getName() {
@@ -2633,9 +2502,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the name property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setName(String value) {
@@ -2740,9 +2608,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the partitionResolver property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionAttributesType.PartitionAttributes.PartitionResolver }
+     * possible object is
+     * {@link RegionAttributesType.PartitionAttributes.PartitionResolver }
      *
      */
     public RegionAttributesType.PartitionAttributes.PartitionResolver getPartitionResolver() {
@@ -2752,9 +2619,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the partitionResolver property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionAttributesType.PartitionAttributes.PartitionResolver }
+     * allowed object is
+     * {@link RegionAttributesType.PartitionAttributes.PartitionResolver }
      *
      */
     public void setPartitionResolver(
@@ -2827,9 +2693,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the localMaxMemory property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getLocalMaxMemory() {
@@ -2839,9 +2704,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the localMaxMemory property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setLocalMaxMemory(String value) {
@@ -2851,9 +2715,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the recoveryDelay property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getRecoveryDelay() {
@@ -2863,9 +2726,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the recoveryDelay property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setRecoveryDelay(String value) {
@@ -2875,9 +2737,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the redundantCopies property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getRedundantCopies() {
@@ -2887,9 +2748,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the redundantCopies property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setRedundantCopies(String value) {
@@ -2899,9 +2759,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the startupRecoveryDelay property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getStartupRecoveryDelay() {
@@ -2911,9 +2770,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the startupRecoveryDelay property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setStartupRecoveryDelay(String value) {
@@ -2923,9 +2781,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the totalMaxMemory property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getTotalMaxMemory() {
@@ -2935,9 +2792,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the totalMaxMemory property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setTotalMaxMemory(String value) {
@@ -2947,9 +2803,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the totalNumBuckets property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getTotalNumBuckets() {
@@ -2959,9 +2814,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the totalNumBuckets property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setTotalNumBuckets(String value) {
@@ -2971,9 +2825,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the colocatedWith property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getColocatedWith() {
@@ -2983,9 +2836,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the colocatedWith property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setColocatedWith(String value) {
@@ -3028,9 +2880,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the partitionName property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getPartitionName() {
@@ -3040,9 +2891,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the partitionName property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setPartitionName(String value) {
@@ -3052,9 +2902,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the isPrimary property.
        *
-       * @return
-       *         possible object is
-       *         {@link Boolean }
+       * possible object is
+       * {@link Boolean }
        *
        */
       public Boolean isIsPrimary() {
@@ -3064,9 +2913,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the isPrimary property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link Boolean }
+       * allowed object is
+       * {@link Boolean }
        *
        */
       public void setIsPrimary(Boolean value) {
@@ -3076,9 +2924,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the numBuckets property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getNumBuckets() {
@@ -3088,9 +2935,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the numBuckets property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setNumBuckets(String value) {
@@ -3135,9 +2981,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the className property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getClassName() {
@@ -3147,9 +2992,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the className property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setClassName(String value) {
@@ -3227,9 +3071,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the className property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getClassName() {
@@ -3239,9 +3082,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the className property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setClassName(String value) {
@@ -3281,9 +3123,8 @@ public class RegionAttributesType {
       /**
        * Gets the value of the name property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getName() {
@@ -3293,9 +3134,8 @@ public class RegionAttributesType {
       /**
        * Sets the value of the name property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setName(String value) {
@@ -3339,9 +3179,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the expirationAttributes property.
      *
-     * @return
-     *         possible object is
-     *         {@link ExpirationAttributesType }
+     * possible object is
+     * {@link ExpirationAttributesType }
      *
      */
     public ExpirationAttributesType getExpirationAttributes() {
@@ -3351,9 +3190,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the expirationAttributes property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ExpirationAttributesType }
+     * allowed object is
+     * {@link ExpirationAttributesType }
      *
      */
     public void setExpirationAttributes(ExpirationAttributesType value) {
@@ -3395,9 +3233,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the expirationAttributes property.
      *
-     * @return
-     *         possible object is
-     *         {@link ExpirationAttributesType }
+     * possible object is
+     * {@link ExpirationAttributesType }
      *
      */
     public ExpirationAttributesType getExpirationAttributes() {
@@ -3407,9 +3244,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the expirationAttributes property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link ExpirationAttributesType }
+     * allowed object is
+     * {@link ExpirationAttributesType }
      *
      */
     public void setExpirationAttributes(ExpirationAttributesType value) {
@@ -3455,9 +3291,8 @@ public class RegionAttributesType {
     /**
      * Gets the value of the interestPolicy property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getInterestPolicy() {
@@ -3467,9 +3302,8 @@ public class RegionAttributesType {
     /**
      * Sets the value of the interestPolicy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setInterestPolicy(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionConfig.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionConfig.java
index 583117e..8af552b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/RegionConfig.java
@@ -321,9 +321,8 @@ public class RegionConfig implements CacheElement {
   /**
    * Gets the value of the name property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getName() {
@@ -333,9 +332,8 @@ public class RegionConfig implements CacheElement {
   /**
    * Sets the value of the name property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setName(String value) {
@@ -345,9 +343,8 @@ public class RegionConfig implements CacheElement {
   /**
    * Gets the value of the refid property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getRefid() {
@@ -357,9 +354,8 @@ public class RegionConfig implements CacheElement {
   /**
    * Sets the value of the refid property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setRefid(String value) {
@@ -428,9 +424,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the key property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionConfig.Entry.Key }
+     * possible object is
+     * {@link RegionConfig.Entry.Key }
      *
      */
     public RegionConfig.Entry.Key getKey() {
@@ -440,9 +435,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the key property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionConfig.Entry.Key }
+     * allowed object is
+     * {@link RegionConfig.Entry.Key }
      *
      */
     public void setKey(RegionConfig.Entry.Key value) {
@@ -452,9 +446,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the value property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionConfig.Entry.Value }
+     * possible object is
+     * {@link RegionConfig.Entry.Value }
      *
      */
     public RegionConfig.Entry.Value getValue() {
@@ -464,9 +457,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the value property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionConfig.Entry.Value }
+     * allowed object is
+     * {@link RegionConfig.Entry.Value }
      *
      */
     public void setValue(RegionConfig.Entry.Value value) {
@@ -508,9 +500,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the string property.
        *
-       * @return
-       *         possible object is
-       *         {@link StringType }
+       * possible object is
+       * {@link StringType }
        *
        */
       public StringType getString() {
@@ -520,9 +511,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the string property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link StringType }
+       * allowed object is
+       * {@link StringType }
        *
        */
       public void setString(StringType value) {
@@ -532,9 +522,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the declarable property.
        *
-       * @return
-       *         possible object is
-       *         {@link DeclarableType }
+       * possible object is
+       * {@link DeclarableType }
        *
        */
       public DeclarableType getDeclarable() {
@@ -544,9 +533,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the declarable property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link DeclarableType }
+       * allowed object is
+       * {@link DeclarableType }
        *
        */
       public void setDeclarable(DeclarableType value) {
@@ -590,9 +578,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the string property.
        *
-       * @return
-       *         possible object is
-       *         {@link StringType }
+       * possible object is
+       * {@link StringType }
        *
        */
       public StringType getString() {
@@ -602,9 +589,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the string property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link StringType }
+       * allowed object is
+       * {@link StringType }
        *
        */
       public void setString(StringType value) {
@@ -614,9 +600,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the declarable property.
        *
-       * @return
-       *         possible object is
-       *         {@link DeclarableType }
+       * possible object is
+       * {@link DeclarableType }
        *
        */
       public DeclarableType getDeclarable() {
@@ -626,9 +611,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the declarable property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link DeclarableType }
+       * allowed object is
+       * {@link DeclarableType }
        *
        */
       public void setDeclarable(DeclarableType value) {
@@ -717,9 +701,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the functional property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionConfig.Index.Functional }
+     * possible object is
+     * {@link RegionConfig.Index.Functional }
      *
      */
     public RegionConfig.Index.Functional getFunctional() {
@@ -729,9 +712,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the functional property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionConfig.Index.Functional }
+     * allowed object is
+     * {@link RegionConfig.Index.Functional }
      *
      */
     public void setFunctional(RegionConfig.Index.Functional value) {
@@ -741,9 +723,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the primaryKey property.
      *
-     * @return
-     *         possible object is
-     *         {@link RegionConfig.Index.PrimaryKey }
+     * possible object is
+     * {@link RegionConfig.Index.PrimaryKey }
      *
      */
     public RegionConfig.Index.PrimaryKey getPrimaryKey() {
@@ -753,9 +734,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the primaryKey property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link RegionConfig.Index.PrimaryKey }
+     * allowed object is
+     * {@link RegionConfig.Index.PrimaryKey }
      *
      */
     public void setPrimaryKey(RegionConfig.Index.PrimaryKey value) {
@@ -765,9 +745,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the name property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getName() {
@@ -777,9 +756,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the name property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setName(String value) {
@@ -789,9 +767,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the expression property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getExpression() {
@@ -801,9 +778,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the expression property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setExpression(String value) {
@@ -813,9 +789,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the fromClause property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getFromClause() {
@@ -825,9 +800,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the fromClause property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setFromClause(String value) {
@@ -837,9 +811,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the imports property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getImports() {
@@ -849,9 +822,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the imports property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setImports(String value) {
@@ -861,9 +833,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the keyIndex property.
      *
-     * @return
-     *         possible object is
-     *         {@link Boolean }
+     * possible object is
+     * {@link Boolean }
      *
      */
     public Boolean isKeyIndex() {
@@ -873,9 +844,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the keyIndex property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link Boolean }
+     * allowed object is
+     * {@link Boolean }
      *
      */
     public void setKeyIndex(Boolean value) {
@@ -885,9 +855,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Gets the value of the type property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getType() {
@@ -901,9 +870,8 @@ public class RegionConfig implements CacheElement {
     /**
      * Sets the value of the type property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setType(String value) {
@@ -946,9 +914,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the expression property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getExpression() {
@@ -958,9 +925,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the expression property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setExpression(String value) {
@@ -970,9 +936,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the fromClause property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getFromClause() {
@@ -982,9 +947,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the fromClause property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setFromClause(String value) {
@@ -994,9 +958,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the imports property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getImports() {
@@ -1006,9 +969,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the imports property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setImports(String value) {
@@ -1047,9 +1009,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Gets the value of the field property.
        *
-       * @return
-       *         possible object is
-       *         {@link String }
+       * possible object is
+       * {@link String }
        *
        */
       public String getField() {
@@ -1059,9 +1020,8 @@ public class RegionConfig implements CacheElement {
       /**
        * Sets the value of the field property.
        *
-       * @param value
-       *        allowed object is
-       *        {@link String }
+       * allowed object is
+       * {@link String }
        *
        */
       public void setField(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/ResourceManagerType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/ResourceManagerType.java
index 1cb7f6e..345826b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/ResourceManagerType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/ResourceManagerType.java
@@ -70,9 +70,8 @@ public class ResourceManagerType {
   /**
    * Gets the value of the criticalHeapPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getCriticalHeapPercentage() {
@@ -82,9 +81,8 @@ public class ResourceManagerType {
   /**
    * Sets the value of the criticalHeapPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setCriticalHeapPercentage(String value) {
@@ -94,9 +92,8 @@ public class ResourceManagerType {
   /**
    * Gets the value of the evictionHeapPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getEvictionHeapPercentage() {
@@ -106,9 +103,8 @@ public class ResourceManagerType {
   /**
    * Sets the value of the evictionHeapPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setEvictionHeapPercentage(String value) {
@@ -118,9 +114,8 @@ public class ResourceManagerType {
   /**
    * Gets the value of the criticalOffHeapPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getCriticalOffHeapPercentage() {
@@ -130,9 +125,8 @@ public class ResourceManagerType {
   /**
    * Sets the value of the criticalOffHeapPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setCriticalOffHeapPercentage(String value) {
@@ -142,9 +136,8 @@ public class ResourceManagerType {
   /**
    * Gets the value of the evictionOffHeapPercentage property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getEvictionOffHeapPercentage() {
@@ -154,9 +147,8 @@ public class ResourceManagerType {
   /**
    * Sets the value of the evictionOffHeapPercentage property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setEvictionOffHeapPercentage(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/SerializationRegistrationType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/SerializationRegistrationType.java
index a282b4a..389783e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/SerializationRegistrationType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/SerializationRegistrationType.java
@@ -185,9 +185,8 @@ public class SerializationRegistrationType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -197,9 +196,8 @@ public class SerializationRegistrationType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
@@ -209,9 +207,8 @@ public class SerializationRegistrationType {
     /**
      * Gets the value of the id property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getId() {
@@ -221,9 +218,8 @@ public class SerializationRegistrationType {
     /**
      * Sets the value of the id property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setId(String value) {
@@ -265,9 +261,8 @@ public class SerializationRegistrationType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -277,9 +272,8 @@ public class SerializationRegistrationType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/ServerType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/ServerType.java
index ef0f83c..d7bf7d5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/ServerType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/ServerType.java
@@ -163,9 +163,8 @@ public class ServerType {
   /**
    * Gets the value of the clientSubscription property.
    *
-   * @return
-   *         possible object is
-   *         {@link ServerType.ClientSubscription }
+   * possible object is
+   * {@link ServerType.ClientSubscription }
    *
    */
   public ServerType.ClientSubscription getClientSubscription() {
@@ -175,9 +174,8 @@ public class ServerType {
   /**
    * Sets the value of the clientSubscription property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link ServerType.ClientSubscription }
+   * allowed object is
+   * {@link ServerType.ClientSubscription }
    *
    */
   public void setClientSubscription(ServerType.ClientSubscription value) {
@@ -187,9 +185,8 @@ public class ServerType {
   /**
    * Gets the value of the customLoadProbe property.
    *
-   * @return
-   *         possible object is
-   *         {@link ServerType.CustomLoadProbe }
+   * possible object is
+   * {@link ServerType.CustomLoadProbe }
    *
    */
   public ServerType.CustomLoadProbe getCustomLoadProbe() {
@@ -199,9 +196,8 @@ public class ServerType {
   /**
    * Sets the value of the customLoadProbe property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link ServerType.CustomLoadProbe }
+   * allowed object is
+   * {@link ServerType.CustomLoadProbe }
    *
    */
   public void setCustomLoadProbe(ServerType.CustomLoadProbe value) {
@@ -211,9 +207,8 @@ public class ServerType {
   /**
    * Gets the value of the bindAddress property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getBindAddress() {
@@ -223,9 +218,8 @@ public class ServerType {
   /**
    * Sets the value of the bindAddress property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setBindAddress(String value) {
@@ -235,9 +229,8 @@ public class ServerType {
   /**
    * Gets the value of the hostnameForClients property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getHostnameForClients() {
@@ -247,9 +240,8 @@ public class ServerType {
   /**
    * Sets the value of the hostnameForClients property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setHostnameForClients(String value) {
@@ -259,9 +251,8 @@ public class ServerType {
   /**
    * Gets the value of the maxConnections property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaxConnections() {
@@ -271,9 +262,8 @@ public class ServerType {
   /**
    * Sets the value of the maxConnections property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaxConnections(String value) {
@@ -283,9 +273,8 @@ public class ServerType {
   /**
    * Gets the value of the maximumMessageCount property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaximumMessageCount() {
@@ -295,9 +284,8 @@ public class ServerType {
   /**
    * Sets the value of the maximumMessageCount property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaximumMessageCount(String value) {
@@ -307,9 +295,8 @@ public class ServerType {
   /**
    * Gets the value of the maximumTimeBetweenPings property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaximumTimeBetweenPings() {
@@ -319,9 +306,8 @@ public class ServerType {
   /**
    * Sets the value of the maximumTimeBetweenPings property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaximumTimeBetweenPings(String value) {
@@ -331,9 +317,8 @@ public class ServerType {
   /**
    * Gets the value of the maxThreads property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMaxThreads() {
@@ -343,9 +328,8 @@ public class ServerType {
   /**
    * Sets the value of the maxThreads property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMaxThreads(String value) {
@@ -355,9 +339,8 @@ public class ServerType {
   /**
    * Gets the value of the messageTimeToLive property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getMessageTimeToLive() {
@@ -367,9 +350,8 @@ public class ServerType {
   /**
    * Sets the value of the messageTimeToLive property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setMessageTimeToLive(String value) {
@@ -379,9 +361,8 @@ public class ServerType {
   /**
    * Gets the value of the notifyBySubscription property.
    *
-   * @return
-   *         possible object is
-   *         {@link Boolean }
+   * possible object is
+   * {@link Boolean }
    *
    */
   public Boolean isNotifyBySubscription() {
@@ -391,9 +372,8 @@ public class ServerType {
   /**
    * Sets the value of the notifyBySubscription property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link Boolean }
+   * allowed object is
+   * {@link Boolean }
    *
    */
   public void setNotifyBySubscription(Boolean value) {
@@ -403,9 +383,8 @@ public class ServerType {
   /**
    * Gets the value of the port property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getPort() {
@@ -415,9 +394,8 @@ public class ServerType {
   /**
    * Sets the value of the port property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setPort(String value) {
@@ -427,9 +405,8 @@ public class ServerType {
   /**
    * Gets the value of the socketBufferSize property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getSocketBufferSize() {
@@ -439,9 +416,8 @@ public class ServerType {
   /**
    * Sets the value of the socketBufferSize property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setSocketBufferSize(String value) {
@@ -451,9 +427,8 @@ public class ServerType {
   /**
    * Gets the value of the loadPollInterval property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getLoadPollInterval() {
@@ -463,9 +438,8 @@ public class ServerType {
   /**
    * Sets the value of the loadPollInterval property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setLoadPollInterval(String value) {
@@ -518,9 +492,8 @@ public class ServerType {
     /**
      * Gets the value of the evictionPolicy property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getEvictionPolicy() {
@@ -530,9 +503,8 @@ public class ServerType {
     /**
      * Sets the value of the evictionPolicy property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setEvictionPolicy(String value) {
@@ -542,9 +514,8 @@ public class ServerType {
     /**
      * Gets the value of the capacity property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getCapacity() {
@@ -554,9 +525,8 @@ public class ServerType {
     /**
      * Sets the value of the capacity property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setCapacity(String value) {
@@ -566,9 +536,8 @@ public class ServerType {
     /**
      * Gets the value of the diskStoreName property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getDiskStoreName() {
@@ -578,9 +547,8 @@ public class ServerType {
     /**
      * Sets the value of the diskStoreName property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setDiskStoreName(String value) {
@@ -590,9 +558,8 @@ public class ServerType {
     /**
      * Gets the value of the overflowDirectory property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getOverflowDirectory() {
@@ -602,9 +569,8 @@ public class ServerType {
     /**
      * Sets the value of the overflowDirectory property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setOverflowDirectory(String value) {
@@ -649,9 +615,8 @@ public class ServerType {
     /**
      * Gets the value of the className property.
      *
-     * @return
-     *         possible object is
-     *         {@link String }
+     * possible object is
+     * {@link String }
      *
      */
     public String getClassName() {
@@ -661,9 +626,8 @@ public class ServerType {
     /**
      * Sets the value of the className property.
      *
-     * @param value
-     *        allowed object is
-     *        {@link String }
+     * allowed object is
+     * {@link String }
      *
      */
     public void setClassName(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/configuration/StringType.java b/geode-core/src/main/java/org/apache/geode/cache/configuration/StringType.java
index 64d9deb..4fa5e19 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/configuration/StringType.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/configuration/StringType.java
@@ -60,9 +60,8 @@ public class StringType {
   /**
    * Gets the value of the value property.
    *
-   * @return
-   *         possible object is
-   *         {@link String }
+   * possible object is
+   * {@link String }
    *
    */
   public String getValue() {
@@ -72,9 +71,8 @@ public class StringType {
   /**
    * Sets the value of the value property.
    *
-   * @param value
-   *        allowed object is
-   *        {@link String }
+   * allowed object is
+   * {@link String }
    *
    */
   public void setValue(String value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
index 791998f..bc91180 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionContext.java
@@ -62,7 +62,6 @@ public interface FunctionContext<T1> {
    * The returned ResultSender is only valid for the duration of the function call. If the Function
    * needs to return a result, the result should be sent before the function exits.
    *
-   * @return ResultSender
    * @since GemFire 6.0
    */
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
index 0feb2ac..00554e5 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionException.java
@@ -56,7 +56,6 @@ public class FunctionException extends GemFireException {
   /**
    * Creates new function exception with given error message.
    *
-   * @param msg
    * @since GemFire 6.0
    */
   public FunctionException(String msg) {
@@ -66,8 +65,6 @@ public class FunctionException extends GemFireException {
   /**
    * Creates new function exception with given error message and optional nested exception.
    *
-   * @param msg
-   * @param cause
    * @since GemFire 6.0
    */
   public FunctionException(String msg, Throwable cause) {
@@ -77,7 +74,6 @@ public class FunctionException extends GemFireException {
   /**
    * Creates new function exception given throwable as a cause and source of error message.
    *
-   * @param cause
    * @since GemFire 6.0
    */
   public FunctionException(Throwable cause) {
@@ -87,7 +83,6 @@ public class FunctionException extends GemFireException {
   /**
    * Adds exceptions thrown from different nodes to a ds
    *
-   * @param cause
    * @since GemFire 6.5
    */
   public void addException(Throwable cause) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
index 40ed42e..7101f9e 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/FunctionService.java
@@ -60,8 +60,6 @@ public class FunctionService {
    * with DataPolicy.PARTITION, it executes on members where the data resides as specified by the
    * filter.
    *
-   * @param region
-   * @return Execution
    * @throws FunctionException if the region passed in is null
    * @since GemFire 6.0
    */
@@ -77,7 +75,6 @@ public class FunctionService {
    * thrown.
    *
    * @param pool from which to chose a server for execution
-   * @return Execution
    * @throws FunctionException if Pool instance passed in is null
    * @since GemFire 6.0
    */
@@ -91,7 +88,6 @@ public class FunctionService {
    * or executing the function on the server, an Exception will be thrown.
    *
    * @param pool the set of servers to execute the function
-   * @return Execution
    * @throws FunctionException if Pool instance passed in is null
    * @since GemFire 6.0
    */
@@ -108,7 +104,6 @@ public class FunctionService {
    *
    * @param regionService obtained from {@link ClientCacheFactory#create} or
    *        {@link ClientCache#createAuthenticatedView(Properties)}.
-   * @return Execution
    * @throws FunctionException if cache is null, is not on a client, or it does not have a default
    *         pool
    * @since GemFire 6.5
@@ -124,7 +119,6 @@ public class FunctionService {
    *
    * @param regionService obtained from {@link ClientCacheFactory#create} or
    *        {@link ClientCache#createAuthenticatedView(Properties)}.
-   * @return Execution
    * @throws FunctionException if cache is null, is not on a client, or it does not have a default
    *         pool
    * @since GemFire 6.5
@@ -140,7 +134,6 @@ public class FunctionService {
    * an Exception will be thrown.
    *
    * @param distributedMember defines a member in the distributed system
-   * @return Execution
    * @throws FunctionException if distributedMember is null
    * @since GemFire 7.0
    *
@@ -160,7 +153,6 @@ public class FunctionService {
    * @param groups optional list of GemFire configuration property "groups" (see
    *        <a href="../../distributed/DistributedSystem.html#groups"> <code>groups</code></a>) on
    *        which to execute the function. Function will be executed on all members of each group
-   * @return Execution
    *
    * @throws FunctionException if no members are found belonging to the provided groups
    * @since GemFire 7.0
@@ -190,7 +182,6 @@ public class FunctionService {
    *        <a href="../../distributed/DistributedSystem.html#groups"> <code>groups</code></a>) on
    *        which to execute the function. Function will be executed on one member of each group
    *
-   * @return Execution
    * @throws FunctionException if no members are found belonging to the provided groups
    * @since GemFire 7.0
    */
@@ -202,8 +193,6 @@ public class FunctionService {
    * Returns the {@link Function} defined by the functionId, returns null if no function is found
    * for the specified functionId
    *
-   * @param functionId
-   * @return Function
    * @throws FunctionException if functionID passed is null
    * @since GemFire 6.0
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
index 0700216..10f95b4 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultCollector.java
@@ -89,7 +89,6 @@ public interface ResultCollector<T, S> {
    * Method used to feed result to the ResultCollector. It adds a single function execution result
    * to the ResultCollector It is invoked every time a result is sent using ResultSender.
    *
-   * @param resultOfSingleExecution
    * @since GemFire 6.0
    * @param memberID DistributedMember ID to which result belongs
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
index 236f622..2628b28 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/ResultSender.java
@@ -53,7 +53,6 @@ public interface ResultSender<T> {
    * Sends a result back to the FunctionService calling thread and invokes
    * {@link ResultCollector#addResult(org.apache.geode.distributed.DistributedMember, Object)}.
    *
-   * @param oneResult
    */
   void sendResult(T oneResult);
 
@@ -76,7 +75,6 @@ public interface ResultSender<T> {
    * will not throw exception but will have exception as a part of results received. Calling
    * sendException will act as a lastResult.
    *
-   * @param t
    *
    * @see #lastResult(Object)
    * @since GemFire 6.3
diff --git a/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java b/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
index 682d13c..9322ed0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/execute/internal/FunctionServiceManager.java
@@ -95,7 +95,6 @@ public class FunctionServiceManager {
    * with DataPolicy.PARTITION, it executes on members where the data resides as specified by the
    * filter.
    *
-   * @return Execution
    * @throws FunctionException if the region passed in is null
    * @since GemFire 6.0
    */
@@ -137,7 +136,6 @@ public class FunctionServiceManager {
    * thrown.
    *
    * @param pool from which to chose a server for execution
-   * @return Execution
    * @throws FunctionException if Pool instance passed in is null
    * @since GemFire 6.0
    */
@@ -160,7 +158,6 @@ public class FunctionServiceManager {
    * or executing the function on the server, an Exception will be thrown.
    *
    * @param pool the set of servers to execute the function
-   * @return Execution
    * @throws FunctionException if Pool instance passed in is null
    * @since GemFire 6.0
    */
@@ -186,7 +183,6 @@ public class FunctionServiceManager {
    *
    * @param regionService obtained from {@link ClientCacheFactory#create} or
    *        {@link ClientCache#createAuthenticatedView(Properties)} .
-   * @return Execution
    * @throws FunctionException if cache is null, is not on a client, or it does not have a default
    *         pool
    * @since GemFire 6.5
@@ -219,7 +215,6 @@ public class FunctionServiceManager {
    *
    * @param regionService obtained from {@link ClientCacheFactory#create} or
    *        {@link ClientCache#createAuthenticatedView(Properties)} .
-   * @return Execution
    * @throws FunctionException if cache is null, is not on a client, or it does not have a default
    *         pool
    * @since GemFire 6.5
@@ -253,7 +248,6 @@ public class FunctionServiceManager {
    *
    * @param system defines the distributed system
    * @param distributedMember defines a member in the distributed system
-   * @return Execution
    * @throws FunctionException if either input parameter is null
    * @since GemFire 6.0
    *
@@ -276,7 +270,6 @@ public class FunctionServiceManager {
    * or executing the function on the member, an Exception will be thrown.
    *
    * @param system defines the distributed system
-   * @return Execution
    *
    * @throws FunctionException if DistributedSystem instance passed is null
    * @since GemFire 6.0
@@ -326,7 +319,6 @@ public class FunctionServiceManager {
    * Returns the {@link Function} defined by the functionId, returns null if no function is found
    * for the specified functionId
    *
-   * @return Function
    * @throws FunctionException if functionID passed is null
    * @since GemFire 6.0
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
index 6f6146b..930df8f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/partition/PartitionRegionHelper.java
@@ -119,7 +119,6 @@ public final class PartitionRegionHelper {
   /**
    * Test a Region to see if it is a partitioned Region
    *
-   * @param r
    * @return true if it is a partitioned Region
    * @since GemFire 6.0
    */
@@ -134,8 +133,6 @@ public final class PartitionRegionHelper {
   /**
    * Test a Region to see if it is a partitioned Region
    *
-   * @param r
-   * @throws IllegalStateException
    * @return PartitionedRegion if it is a partitioned Region
    * @since GemFire 6.0
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java b/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
index bd34037..4fa55e0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/Aggregator.java
@@ -25,7 +25,6 @@ public interface Aggregator {
   /**
    * Accumulate the next scalar value
    *
-   * @param value
    */
   void accumulate(Object value);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java b/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
index 1d33d59..36621a3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/CqServiceStatistics.java
@@ -63,7 +63,6 @@ public interface CqServiceStatistics {
    * Get number of CQs on the given region. Active CQs and stopped CQs on this region are included
    * and closed CQs are not included.
    *
-   * @param regionFullPath
    * @return long number of CQs on the region.
    */
   long numCqsOnRegion(String regionFullPath);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java b/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
index 93fefce..6250308 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/QueryService.java
@@ -706,7 +706,6 @@ public interface QueryService {
    * @see CqServiceStatistics
    *
    * @since GemFire 5.5
-   * @return CqServiceStatistics
    *
    */
   CqServiceStatistics getCqStatistics();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
index bf8dbda..f7d036c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AbstractGroupOrRangeJunction.java
@@ -28,9 +28,6 @@ import org.apache.geode.distributed.internal.DistributionConfig;
 import org.apache.geode.internal.Assert;
 import org.apache.geode.internal.i18n.LocalizedStrings;
 
-/**
- *
- */
 public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
     implements Filter, OQLLexerTokenTypes {
   /** left operand */
@@ -515,8 +512,6 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
    * @param operator The junction type ( AND or OR ) of the old junction
    * @param indpndntItr Array of RuntimeIterator representing the Independent Iterator for the Group
    *        or Range Junction
-   * @param isCompleteExpansion
-   * @param operands
    * @return Object of type GroupJunction or RangeJunction depending on the type of the invoking
    *         Object
    */
@@ -530,10 +525,6 @@ public abstract class AbstractGroupOrRangeJunction extends AbstractCompiledValue
    *
    * @param context ExecutionContext object
    * @return Object of type OrganizedOperands
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   abstract OrganizedOperands organizeOperands(ExecutionContext context)
       throws FunctionDomainException, TypeMismatchException, NameResolutionException,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
index c72ce11..1938e21 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AllGroupJunction.java
@@ -91,11 +91,6 @@ public class AllGroupJunction extends AbstractCompiledValue implements Filter, O
    * subtree CompiledJunction
    *
    * @param context ExecutionContext object
-   * @return SelectResults
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   // Asif : For doing the Cartesian first evaluate the result of all Group
   // Junction. Doing Cartesian of all the Results together is better than doing
@@ -186,10 +181,6 @@ public class AllGroupJunction extends AbstractCompiledValue implements Filter, O
    *
    * @param context ExecutionContext object
    * @return SelectResults object
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   private SelectResults evaluateOrJunction(ExecutionContext context) throws FunctionDomainException,
       TypeMismatchException, NameResolutionException, QueryInvocationTargetException {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
index 53c2e7f..06e25fe 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/AttributeDescriptor.java
@@ -199,10 +199,7 @@ public class AttributeDescriptor {
   /**
    * reads field value from a PdxInstance
    *
-   * @param target
    * @return the value of the field from PdxInstance
-   * @throws NameNotFoundException
-   * @throws QueryInvocationTargetException
    */
   private Object readPdx(PdxInstance target)
       throws NameNotFoundException, QueryInvocationTargetException {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
index a62e39a..ac39288 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
@@ -339,20 +339,10 @@ public abstract class Bag<E> extends AbstractCollection<E> implements CqResults<
     }
   }
 
-  /**
-   *
-   * @param out
-   * @throws IOException
-   */
   void writeNumNulls(DataOutput out) throws IOException {
     out.writeInt(this.numNulls);
   }
 
-  /**
-   *
-   * @param in
-   * @throws IOException
-   */
   void readNumNulls(DataInput in) throws IOException {
     this.numNulls = in.readInt();
   }
@@ -659,9 +649,6 @@ public abstract class Bag<E> extends AbstractCollection<E> implements CqResults<
     }
   }
 
-  /**
-   *
-   */
   protected class LimitBagIterator extends Bag.BagIterator {
     private final int localLimit;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
index d6b2eed..8a442f7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledAggregateFunction.java
@@ -37,10 +37,6 @@ import org.apache.geode.cache.query.internal.parse.OQLLexerTokenTypes;
 import org.apache.geode.cache.query.internal.types.ObjectTypeImpl;
 import org.apache.geode.cache.query.types.ObjectType;
 
-/**
- *
- *
- */
 public class CompiledAggregateFunction extends AbstractCompiledValue {
 
   private final CompiledValue expr;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
index 651cf23..6953c7f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledComparison.java
@@ -145,7 +145,6 @@ public class CompiledComparison extends AbstractCompiledValue
    * are iter operands. In such cases , the iter operands will be evaluated while expanding/cutting
    * down the index resultset
    *
-   * @return SelectResults
    */
   @Override
   public SelectResults filterEvaluate(ExecutionContext context, SelectResults intermediateResults,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
index 5d8c97d..4116d47 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledGroupBySelect.java
@@ -40,10 +40,6 @@ import org.apache.geode.cache.query.types.ObjectType;
 import org.apache.geode.cache.query.types.StructType;
 import org.apache.geode.internal.i18n.LocalizedStrings;
 
-/**
- *
- *
- */
 public class CompiledGroupBySelect extends CompiledSelect {
 
   private final BitSet aggregateColsPos;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
index 409fb29..4b2b195 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIn.java
@@ -362,7 +362,6 @@ public class CompiledIn extends AbstractCompiledValue implements Indexable {
    * are iter operands. In such cases , the iter operands will be evaluated while expanding/cutting
    * down the index resultset
    *
-   * @return SelectResults
    */
   public SelectResults filterEvaluate(ExecutionContext context, SelectResults intermediateResults,
       boolean completeExpansionNeeded, CompiledValue iterOperands, RuntimeIterator[] indpndntItrs,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
index 3c5c268..f21c0cb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledJunction.java
@@ -444,12 +444,7 @@ public class CompiledJunction extends AbstractCompiledValue implements Negatable
    * ultimately dependent on more than one independent iterators cannot be assumed to be part of the
    * GroupJunction, even if one of independent iterator belongs to a different scope.
    *
-   * @param context
    * @return New combination of AbstractCompiledValue(s) in form of CompiledJunction.
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   OrganizedOperands organizeOperands(ExecutionContext context) throws FunctionDomainException,
       TypeMismatchException, NameResolutionException, QueryInvocationTargetException {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
index 7a0a9ae..195476c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
@@ -1465,17 +1465,11 @@ public class CompiledSelect extends AbstractCompiledValue {
    *
    * It assumes the limit is either a CompiledBindArgument or a CompiledLiteral
    *
-   * @param bindArguments
    *
-   * @return
    *
-   * @throws FunctionDomainException
    *
-   * @throws TypeMismatchException
    *
-   * @throws NameResolutionException
    *
-   * @throws QueryInvocationTargetException
    */
   private Integer evaluateLimitValue(Object[] bindArguments) throws FunctionDomainException,
       TypeMismatchException, NameResolutionException, QueryInvocationTargetException {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
index f1b62e4..f1da35b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUnaryMinus.java
@@ -24,17 +24,10 @@ import org.apache.geode.cache.query.QueryService;
 import org.apache.geode.cache.query.TypeMismatchException;
 import org.apache.geode.internal.i18n.LocalizedStrings;
 
-/**
- *
- */
 public class CompiledUnaryMinus extends AbstractCompiledValue {
 
   private CompiledValue _value;
 
-  /**
-   *
-   * @param value
-   */
   public CompiledUnaryMinus(CompiledValue value) {
     _value = value;
   }
@@ -45,37 +38,21 @@ public class CompiledUnaryMinus extends AbstractCompiledValue {
     return Collections.singletonList(this._value);
   }
 
-  /**
-   * @return int
-   */
   public int getType() {
     return LITERAL_sum;
   }
 
-  /**
-   * @param context
-   * @return Object
-   */
   public Object evaluate(ExecutionContext context) throws FunctionDomainException,
       TypeMismatchException, NameResolutionException, QueryInvocationTargetException {
     return minus(_value.evaluate(context));
   }
 
-  /**
-   *
-   */
   @Override
   public Set computeDependencies(ExecutionContext context)
       throws TypeMismatchException, AmbiguousNameException, NameResolutionException {
     return context.addDependencies(this, this._value.computeDependencies(context));
   }
 
-  /**
-   *
-   * @param obj
-   * @return Object
-   * @throws TypeMismatchException
-   */
   private Object minus(Object obj) throws TypeMismatchException {
 
     if (obj instanceof Number) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
index 59f523c..ef55d6c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledUndefined.java
@@ -64,7 +64,6 @@ public class CompiledUndefined extends AbstractCompiledValue implements Negatabl
    * are iter operands. In such cases , the iter operands will be evaluated while expanding/cutting
    * down the index resultset
    *
-   * @return SelectResults
    */
   @Override
   public SelectResults filterEvaluate(ExecutionContext context, SelectResults intermediateResults,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
index 213f0b7..5074d59 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CqStateImpl.java
@@ -69,7 +69,6 @@ public class CqStateImpl implements CqState {
   /**
    * Sets the state of CQ.
    *
-   * @param state
    */
   public void setState(int state) {
     this.state = state;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
index 88f2ada..05d897e 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/DefaultQueryService.java
@@ -273,9 +273,6 @@ public class DefaultQueryService implements InternalQueryService {
    *        be created
    * @param context ExecutionContext
    * @return IndexData object
-   * @throws NameResolutionException
-   * @throws TypeMismatchException
-   * @throws AmbiguousNameException
    */
   public IndexData getIndex(String regionPath, String[] definitions, IndexType indexType,
       CompiledValue indexedExpression, ExecutionContext context)
@@ -330,9 +327,6 @@ public class DefaultQueryService implements InternalQueryService {
    *        be created
    * @param context ExecutionContext object
    * @return IndexData object
-   * @throws NameResolutionException
-   * @throws TypeMismatchException
-   * @throws AmbiguousNameException
    */
   public IndexData getBestMatchIndex(String regionPath, String definitions[], IndexType indexType,
       CompiledValue indexedExpression, ExecutionContext context)
@@ -769,9 +763,6 @@ public class DefaultQueryService implements InternalQueryService {
     cache.getCqService().close();
   }
 
-  /**
-   * @return CqService
-   */
   public CqService getCqService() throws CqException {
     CqService service = cache.getCqService();
     service.start();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
index 4cac6f7..98bec3b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Filter.java
@@ -31,7 +31,6 @@ public interface Filter {
   /**
    * Evaluates as a filter taking advantage of indexes if appropriate.
    *
-   * @return SelectResults
    */
   SelectResults filterEvaluate(ExecutionContext context, SelectResults iterationLimit)
       throws FunctionDomainException, TypeMismatchException, NameResolutionException,
@@ -78,15 +77,8 @@ public interface Filter {
    *        iterators being that of CompositeGroupJunction. If the completeExpansion flag is true ,
    *        then this will be null as in that case , the position of iterators in the Results is
    *        decided by the actual order of iterators in the Query from clause .
-   * @param isIntersection
-   * @param conditioningNeeded
-   * @param evaluateProjection
    * @return Object of type SelectResults representing the Results obtained from evaluation of the
    *         condition
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   SelectResults filterEvaluate(ExecutionContext context, SelectResults iterationLimit,
       boolean completeExpansionNeeded, CompiledValue iterOperands, RuntimeIterator[] indpndntItrs,
@@ -103,10 +95,6 @@ public interface Filter {
    *        ignored
    * @return Object of type SelectResults representing the Results obtained from evaluation of the
    *         condition
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   SelectResults auxFilterEvaluate(ExecutionContext context, SelectResults intermediateResults)
       throws FunctionDomainException, TypeMismatchException, NameResolutionException,
@@ -115,15 +103,6 @@ public interface Filter {
   int getSizeEstimate(ExecutionContext context) throws FunctionDomainException,
       TypeMismatchException, NameResolutionException, QueryInvocationTargetException;
 
-  /**
-   *
-   * @param context
-   * @return boolean
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
-   */
   boolean isProjectionEvaluationAPossibility(ExecutionContext context)
       throws FunctionDomainException, TypeMismatchException, NameResolutionException,
       QueryInvocationTargetException;
@@ -131,13 +110,6 @@ public interface Filter {
   /**
    * Only used by single base collection index
    *
-   * @param independentIter
-   * @param context
-   * @param completeExpnsNeeded
-   * @return boolean
-   * @throws AmbiguousNameException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
    */
   boolean isConditioningNeededForIndex(RuntimeIterator independentIter, ExecutionContext context,
       boolean completeExpnsNeeded)
@@ -145,14 +117,7 @@ public interface Filter {
 
   /**
    *
-   * @param comparedTo
-   * @param context
-   * @param thisSize
    * @return boolean true if this is the better filter as compared to the Filter passed as parameter
-   * @throws FunctionDomainException
-   * @throws TypeMismatchException
-   * @throws NameResolutionException
-   * @throws QueryInvocationTargetException
    */
   boolean isBetterFilter(Filter comparedTo, ExecutionContext context, int thisSize)
       throws FunctionDomainException, TypeMismatchException, NameResolutionException,
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
index bf4afeb..d379cb1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/HashingStrategy.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal;
 
 import java.io.Serializable;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
index 7204eec..9e88df3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/IndexTrackingQueryObserver.java
@@ -171,7 +171,6 @@ public class IndexTrackingQueryObserver extends QueryObserverAdapter {
     /**
      * Adds a results map (mostly a bucket index lookup results) to the "this" IndexInfo.
      *
-     * @param rslts
      */
     public void addResults(Map rslts) {
       for (Object obj : rslts.entrySet()) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
index 7daf32f..9788f9c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Indexable.java
@@ -30,9 +30,6 @@ public interface Indexable {
    *
    * @param context ExecutionContext object
    * @return IndexInfo object , if any, associated with the CompiledValue
-   * @throws TypeMismatchException
-   * @throws AmbiguousNameException
-   * @throws NameResolutionException
    */
   IndexInfo[] getIndexInfo(ExecutionContext context)
       throws TypeMismatchException, AmbiguousNameException, NameResolutionException;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
index f762973..62236f4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/PathUtils.java
@@ -194,10 +194,7 @@ public class PathUtils {
    * Collects all the compiled values in the path , starting from the self at position 0 in the
    * returned List
    *
-   * @param expr
    * @return List of CompiledValues ( includes the RuntimeIterator)
-   * @throws TypeMismatchException
-   * @throws AmbiguousNameException
    */
   public static List<CompiledValue> collectCompiledValuesInThePath(CompiledValue expr,
       ExecutionContext context) throws AmbiguousNameException, TypeMismatchException {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
index c43e74e..8546b2d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
@@ -140,7 +140,6 @@ public class QCompiler implements OQLLexerTokenTypes {
   /**
    * Yogesh: compiles order by clause and push into the stack
    *
-   * @param numOfChildren
    */
   public void compileOrederByClause(int numOfChildren) {
     List list = new ArrayList();
@@ -163,7 +162,6 @@ public class QCompiler implements OQLLexerTokenTypes {
   /**
    * Yogesh: compiles sort criteria present in order by clause and push into the stack
    *
-   * @param sortCriterion
    */
   public void compileSortCriteria(String sortCriterion) {
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
index 6372fd1..ef7d300 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryObserver.java
@@ -265,24 +265,10 @@ public interface QueryObserver {
    */
   void afterIterJoinOfSingleIndexResults(Collection finalResult);
 
-  /**
-   *
-   * @param preProjectionAppliedResult
-   */
   void beforeApplyingProjectionOnFilterEvaluatedResults(Object preProjectionAppliedResult);
 
-  /**
-   *
-   * @param sr1
-   * @param sr2
-   */
   void invokedQueryUtilsUnion(SelectResults sr1, SelectResults sr2);
 
-  /**
-   *
-   * @param sr1
-   * @param sr2
-   */
   void invokedQueryUtilsIntersection(SelectResults sr1, SelectResults sr2);
 
   void limitAppliedAtIndexLevel(Index index, int limit, Collection indexResult);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
index b73bf28..ec7086d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QueryUtils.java
@@ -762,7 +762,6 @@ public class QueryUtils {
    * marks the termination, but in case of CompiledOperation this is not the case
    *
    * @param expr CompiledValue object
-   * @return CompiledValue
    */
   static CompiledValue obtainTheBottomMostCompiledValue(CompiledValue expr) {
     boolean toContinue = true;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
index 652d46b..e235688 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/RangeJunction.java
@@ -383,11 +383,7 @@ public class RangeJunction extends AbstractGroupOrRangeJunction {
   /**
    * Checks if key1 operator key2 is true or not. The operator could be =, != , <, >,<=,>=
    *
-   * @param key1
-   * @param key2
-   * @param operator
    * @return boolean true if the condition is satisfied else false
-   * @throws TypeMismatchException
    */
   private boolean isConditionSatisfied(Object key1, Object key2, int operator)
       throws TypeMismatchException {
@@ -406,7 +402,6 @@ public class RangeJunction extends AbstractGroupOrRangeJunction {
    * @param greaterCondnKey Key of the 'greater' condition operand
    * @param greaterCondnOp Type of 'greater' operator ( > or >=)
    * @return boolean true if the nature is bounded else false ( unbounded )
-   * @throws TypeMismatchException
    */
   private boolean checkForRangeBoundednessAndTrimNotEqualKeyset(Set notEqualKeys,
       Object lessCondnKey, int lessOperator, Object greaterCondnKey, int greaterCondnOp)
@@ -446,7 +441,6 @@ public class RangeJunction extends AbstractGroupOrRangeJunction {
    *        inequality
    * @param indxInfo The IndexInfo object for this RangeJunction
    * @return Filter object of type CompiledComparison or RangeJunction.SingleCondnEvaluator object
-   * @throws TypeMismatchException
    */
   private Filter generateSingleCondnEvaluatorIfRequired(Set notEqualKeys, CompiledValue operand,
       int operator, Object condnKey, IndexInfo indxInfo) throws TypeMismatchException {
@@ -669,7 +663,6 @@ public class RangeJunction extends AbstractGroupOrRangeJunction {
    * Test function which retrieves the underlying Index for a NotEqualConditionEvaluator operator
    *
    * @param o Object of type NotEqualConditionEvaluator from which the index needs to be retrieved
-   * @return Index
    */
   static Index getIndex(Object o) {
     if (o instanceof NotEqualConditionEvaluator) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
index 6efbdd5..3443ea8 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
@@ -178,8 +178,6 @@ public class ResultsBag extends Bag implements DataSerializableFixedID {
     }
   }
 
-  /**
-   */
   void createIntHashMap() {
     this.map = new ObjectIntHashMap(this.size - this.numNulls);
   }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
index ecb1f4a..da470a5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
@@ -558,10 +558,6 @@ public class ResultsCollectionWrapper implements SelectResults, DataSerializable
     }
   }
 
-  /**
-   *
-   *
-   */
   class LimitIterator implements Iterator {
     private final Iterator iter;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
index dc5a888..af50e8d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedResultsBag.java
@@ -44,7 +44,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for unordered input
    *
-   * @param comparator
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
@@ -58,8 +57,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param elementType
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
@@ -74,9 +71,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param elementType
-   * @param stats
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
@@ -91,8 +85,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param stats
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
@@ -106,7 +98,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for ordered input. Creates underlying Map as LinkedHashMap
    *
-   * @param stats
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
@@ -133,7 +124,6 @@ public class SortedResultsBag<E> extends Bag implements Ordered {
   /**
    * Constructor for ordered input. Creates underlying Map as LinkedHashMap
    *
-   * @param elementType
    * @param nullAtStart Indicates that the first order by coumn is asc , so that tuple with null
    *        order by column value need to be emitted at start, else if desc, then emit at last
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
index c84578c..0096839 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
@@ -30,18 +30,12 @@ import org.apache.geode.cache.query.types.StructType;
 import org.apache.geode.internal.cache.CachePerfStats;
 import org.apache.geode.internal.i18n.LocalizedStrings;
 
-/**
- *
- *
- */
 public class SortedStructBag extends SortedResultsBag<Object[]> implements StructFields {
 
 
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param nullAtStart
    */
   public SortedStructBag(Comparator<Object[]> comparator, boolean nullAtStart) {
     super(comparator, nullAtStart);
@@ -51,9 +45,6 @@ public class SortedStructBag extends SortedResultsBag<Object[]> implements Struc
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param elementType
-   * @param nullAtStart
    */
   public SortedStructBag(Comparator<Object[]> comparator, StructType elementType,
       boolean nullAtStart) {
@@ -63,10 +54,6 @@ public class SortedStructBag extends SortedResultsBag<Object[]> implements Struc
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param elementType
-   * @param stats
-   * @param nullAtStart
    */
   public SortedStructBag(Comparator<Object[]> comparator, ObjectType elementType,
       CachePerfStats stats, boolean nullAtStart) {
@@ -77,9 +64,6 @@ public class SortedStructBag extends SortedResultsBag<Object[]> implements Struc
   /**
    * Constructor for unordered input
    *
-   * @param comparator
-   * @param stats
-   * @param nullAtStart
    */
   public SortedStructBag(Comparator<Object[]> comparator, CachePerfStats stats,
       boolean nullAtStart) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
index 458dbed..b57c692 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ClientCQ.java
@@ -26,7 +26,6 @@ public interface ClientCQ extends InternalCqQuery {
    * care of repository cleanup.
    *
    * @param sendRequestToServer true to send the request to server.
-   * @throws CqException
    */
   void close(boolean sendRequestToServer) throws CqClosedException, CqException;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
index 3995411..497a31c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqAttributesImpl.java
@@ -65,7 +65,6 @@ public class CqAttributesImpl implements CqAttributes, CqAttributesMutator, Clon
   /**
    * Returns the CqListener set with the CQ
    *
-   * @return CqListener
    */
   public CqListener getCqListener() {
     ArrayList<CqListener> listeners = this.cqListeners;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
index c4d1e70..5f5084c 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/CqService.java
@@ -127,9 +127,6 @@ public interface CqService {
   /**
    * Called directly on server side.
    *
-   * @param cqName
-   * @param clientProxyId
-   * @throws CqException
    */
   void closeCq(String cqName, ClientProxyMembershipID clientProxyId) throws CqException;
 
@@ -148,15 +145,12 @@ public interface CqService {
   /**
    * Server side method.
    *
-   * @param clientProxyId
-   * @throws CqException
    */
   void closeClientCqs(ClientProxyMembershipID clientProxyId) throws CqException;
 
   /**
    * Returns all the CQs registered by the client.
    *
-   * @param clientProxyId
    * @return CQs registered by the client.
    */
   List<ServerCQ> getAllClientCqs(ClientProxyMembershipID clientProxyId);
@@ -164,7 +158,6 @@ public interface CqService {
   /**
    * Returns all the durable client CQs registered by the client.
    *
-   * @param clientProxyId
    * @return CQs registered by the client.
    */
   List<String> getAllDurableClientCqs(ClientProxyMembershipID clientProxyId) throws CqException;
@@ -174,8 +167,6 @@ public interface CqService {
    *
    * @param cqs list of cqs with the cq operation from the Server.
    * @param messageType base operation
-   * @param key
-   * @param value
    */
   void dispatchCqListeners(HashMap<String, Integer> cqs, int messageType, Object key, Object value,
       byte[] delta, QueueManager qManager, EventID eventId);
@@ -205,9 +196,6 @@ public interface CqService {
   /**
    * Called directly on server side.
    *
-   * @param cqName
-   * @param clientId
-   * @throws CqException
    */
   void stopCq(String cqName, ClientProxyMembershipID clientId) throws CqException;
 
@@ -215,7 +203,6 @@ public interface CqService {
    * Called directly on the server side.
    *
    * @param cqState new state
-   * @param cQuery
    */
   void resumeCQ(int cqState, ServerCQ cQuery);
 
@@ -227,17 +214,11 @@ public interface CqService {
    * Executes the given CqQuery, if the CqQuery for that name is not there it registers the one and
    * executes. This is called on the Server.
    *
-   * @param cqName
-   * @param queryString
-   * @param cqState
-   * @param clientProxyId
-   * @param ccn
    * @param manageEmptyRegions whether to update the 6.1 emptyRegions map held in the CCN
    * @param regionDataPolicy the data policy of the region associated with the query. This is only
    *        needed if manageEmptyRegions is true.
    * @param emptyRegionsMap map of empty regions.
    * @throws IllegalStateException if this is called at client side.
-   * @throws CqException
    */
   ServerCQ executeCq(String cqName, String queryString, int cqState,
       ClientProxyMembershipID clientProxyId, CacheClientNotifier ccn, boolean isDurable,
@@ -247,8 +228,6 @@ public interface CqService {
   /**
    * Server side method. Closes non-durable CQs for the given client proxy id.
    *
-   * @param clientProxyId
-   * @throws CqException
    */
   void closeNonDurableClientCqs(ClientProxyMembershipID clientProxyId) throws CqException;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
index c0dab64..43c9cd0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/InternalCqQuery.java
@@ -35,7 +35,6 @@ public interface InternalCqQuery extends CqQuery {
    * care of repository cleanup.
    *
    * @param sendRequestToServer true to send the request to server.
-   * @throws CqException
    */
   void close(boolean sendRequestToServer) throws CqClosedException, CqException;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
index eb7e3b0..7c5e40f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/cq/ServerCQ.java
@@ -35,9 +35,6 @@ public interface ServerCQ extends InternalCqQuery {
   /**
    * Register the Query on server.
    *
-   * @param p_clientProxyId
-   * @param p_ccn
-   * @throws CqException
    */
   void registerCq(ClientProxyMembershipID p_clientProxyId, CacheClientNotifier p_ccn, int p_cqState)
       throws CqException, RegionNotFoundException;
@@ -45,14 +42,12 @@ public interface ServerCQ extends InternalCqQuery {
   /**
    * Adds into the CQ Results key cache.
    *
-   * @param key
    */
   void addToCqResultKeys(Object key);
 
   /**
    * Removes the key from CQ Results key cache.
    *
-   * @param key
    * @param isTokenMode if true removes the key if its in destroy token mode if false removes the
    *        key without any check.
    */
@@ -73,7 +68,6 @@ public interface ServerCQ extends InternalCqQuery {
    * care of repository cleanup.
    *
    * @param sendRequestToServer true to send the request to server.
-   * @throws CqException
    */
   void close(boolean sendRequestToServer) throws CqClosedException, CqException;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
index 7e60234..c9b98b8 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndexSet.java
@@ -177,8 +177,6 @@ public class HashIndexSet implements Set {
   /**
    * Locates index slot of object using the provided key (in this case we are passing in old key)
    *
-   * @param key
-   * @param obj
    * @return the indexSlot of the given key/object combination
    */
   protected int index(Object key, Object obj, int ignoreThisSlot) {
@@ -261,10 +259,8 @@ public class HashIndexSet implements Set {
   /**
    * Add an object using the hash value of the provided indexKey
    *
-   * @param indexKey
    * @param obj the object to add
    * @return true if object has been added
-   * @throws TypeMismatchException
    */
   public synchronized int add(Object indexKey, Object obj) throws TypeMismatchException {
     if (indexKey == null) {
@@ -456,7 +452,6 @@ public class HashIndexSet implements Set {
   /**
    *
    * @param key assumed to not be null, rather needs to be NULL token
-   * @param obj
    * @param newIndexSlot if inplace modification occurs with out having a reversemap we end up
    *        scanning the entire index. We want to remove the region entry from the index slot but
    *        not the newly added (correct) slot. Rather only the "old/wrong" slot
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
index 81e06c4..0a9cd6f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IMQException.java
@@ -22,9 +22,6 @@ package org.apache.geode.cache.query.internal.index;
 
 import org.apache.geode.cache.query.QueryException;
 
-/**
- *
- */
 public class IMQException extends QueryException {
   private static final long serialVersionUID = -5012914292321850775L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
index b5c5799..fc7b8b7 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexConcurrentHashSet.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal.index;
 
 import java.util.Collection;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
index 0772b10..ab22e87 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexElemArray.java
@@ -124,7 +124,6 @@ public class IndexElemArray implements Iterable, Collection {
    *
    * @param index index of the element to return
    * @return the element at the specified position in this list
-   * @throws IndexOutOfBoundsException
    *
    */
   public Object get(int index) {
@@ -140,7 +139,6 @@ public class IndexElemArray implements Iterable, Collection {
    * @param index index of the element to replace
    * @param element element to be stored at the specified position
    * @return the element previously at the specified position
-   * @throws IndexOutOfBoundsException
    *
    */
   public Object set(int index, Object element) {
@@ -159,7 +157,6 @@ public class IndexElemArray implements Iterable, Collection {
    *
    * @param e element to be appended to this list
    * @return <tt>true</tt> (as specified by {@link Collection#add})
-   * @throws ArrayIndexOutOfBoundsException
    */
   public boolean add(Object e) {
     synchronized (lock) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
index 9700fb3..de9c709 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexManager.java
@@ -1392,7 +1392,6 @@ public class IndexManager {
    * Asif : Given a definition returns the canonicalized iterator name for the definition. If the
    * definition does not exist , null is returned
    *
-   * @return String
    */
   public String getCanonicalizedIteratorName(String definition) {
     return ((String) (this.canonicalizedIteratorNameMap.get(definition)));
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
index 1ee5e8a..2dfda41 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexProtocol.java
@@ -63,7 +63,6 @@ public interface IndexProtocol extends Index {
    * @param keysToRemove Set containing Index key which should not be included in the results being
    *        fetched
    * @param context ExecutionContext object
-   * @throws TypeMismatchException
    */
   void query(Collection results, Set keysToRemove, ExecutionContext context)
       throws TypeMismatchException, FunctionDomainException, NameResolutionException,
@@ -83,7 +82,6 @@ public interface IndexProtocol extends Index {
    *        both should not be present in the index results being fetched ( Fetched results should
    *        not contain index results corresponding to key + keys of keysToRemove set )
    * @param context ExecutionContext object
-   * @throws TypeMismatchException
    */
   void query(Object key, int operator, Collection results, Set keysToRemove,
       ExecutionContext context) throws TypeMismatchException, FunctionDomainException,
@@ -96,25 +94,11 @@ public interface IndexProtocol extends Index {
    *        resultset
    * @param results The Collection object used for fetching the index results
    * @param context ExecutionContext object
-   * @throws TypeMismatchException
    */
   void query(Object key, int operator, Collection results, ExecutionContext context)
       throws TypeMismatchException, FunctionDomainException, NameResolutionException,
       QueryInvocationTargetException;
 
-  /**
-   *
-   * @param key
-   * @param operator
-   * @param results
-   * @param iterOp
-   * @param indpndntItr
-   * @param context
-   * @throws TypeMismatchException
-   * @throws QueryInvocationTargetException
-   * @throws NameResolutionException
-   * @throws FunctionDomainException
-   */
   void query(Object key, int operator, Collection results, CompiledValue iterOp,
       RuntimeIterator indpndntItr, ExecutionContext context, List projAttrib,
       SelectResults intermediateResults, boolean isIntersection) throws TypeMismatchException,
@@ -131,7 +115,6 @@ public interface IndexProtocol extends Index {
    * @param keysToRemove Set containing Index key which should not be included in the results being
    *        fetched
    * @param context ExecutionContext object
-   * @throws TypeMismatchException
    */
   void query(Object lowerBoundKey, int lowerBoundOperator, Object upperBoundKey,
       int upperBoundOperator, Collection results, Set keysToRemove, ExecutionContext context)
@@ -149,10 +132,6 @@ public interface IndexProtocol extends Index {
    *         List represents a value (key of Range Index) which satisfies the equi join condition.
    *         The Object array will have two rows. Each row ( one dimensional Object Array ) will
    *         contain objects or type Struct or Object.
-   * @throws TypeMismatchException
-   * @throws QueryInvocationTargetException
-   * @throws NameResolutionException
-   * @throws FunctionDomainException
    */
   List queryEquijoinCondition(IndexProtocol index, ExecutionContext context)
       throws TypeMismatchException, FunctionDomainException, NameResolutionException,
@@ -178,7 +157,6 @@ public interface IndexProtocol extends Index {
    * Asif: Object type of the data ( tuple ) contained in the Index Results . It will be either of
    * type ObjectType or StructType
    *
-   * @return ObjectType
    */
   ObjectType getResultSetType();
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
index 2aafeda..8ec99b1 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexStore.java
@@ -28,8 +28,6 @@ public interface IndexStore {
   /**
    * Add a mapping to the index store
    *
-   * @param indexKey
-   * @param re
    */
   void addMapping(Object indexKey, RegionEntry re) throws IMQException;
 
@@ -37,17 +35,12 @@ public interface IndexStore {
    * Remove a mapping from the index store If entry at indexKey is not found, we must crawl the
    * index to be sure the region entry does not exist
    *
-   * @param indexKey
-   * @param re
    */
   void removeMapping(Object indexKey, RegionEntry re) throws IMQException;
 
   /**
    * Update a mapping in the index store. This method adds a new mapping and removes the old mapping
    *
-   * @param indexKey
-   * @param oldKey
-   * @param re
    */
   void updateMapping(Object indexKey, Object oldKey, RegionEntry re, Object oldValue)
       throws IMQException;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
index 1a62e1e..824cb6a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexedExpressionEvaluator.java
@@ -24,9 +24,6 @@ import java.util.List;
 import org.apache.geode.cache.query.types.ObjectType;
 import org.apache.geode.internal.cache.RegionEntry;
 
-/**
- *
- */
 public interface IndexedExpressionEvaluator {
 
   String getIndexedExpression();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
index 2fced96..a093517 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
@@ -246,7 +246,6 @@ public class MemoryIndexStore implements IndexStore {
    * Find the old key by traversing the forward map in case of in-place update modification If not
    * found it means the value object was modified with same value. So oldKey is same as newKey.
    *
-   * @return oldKey
    */
   private Object getOldKey(Object newKey, RegionEntry entry) throws TypeMismatchException {
     for (Object mapEntry : valueToEntriesMap.entrySet()) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
index 5a20d49..ab61767 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/PartitionedIndex.java
@@ -411,7 +411,6 @@ public class PartitionedIndex extends AbstractIndex {
   /**
    * This will create extra {@link IndexStatistics} statistics for MapType PartitionedIndex.
    *
-   * @param indexName
    * @return new PartitionedIndexStatistics
    */
   protected InternalIndexStatistics createExplicitStats(String indexName) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
index 03eb981..b3ebbdc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTAggregateFunc.java
@@ -20,10 +20,6 @@ import org.apache.geode.cache.query.QueryInvalidException;
 import org.apache.geode.cache.query.internal.CompiledValue;
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- *
- */
 public class ASTAggregateFunc extends GemFireAST {
   private static final long serialVersionUID = 8713004765228379685L;
   private int aggFunctionType;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
index b830bd5..dd69ab5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTCombination.java
@@ -20,9 +20,6 @@ import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- */
 public class ASTCombination extends GemFireAST {
   private static final long serialVersionUID = -5390937242819850292L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
index 0e0d453..384c21d 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTGroupBy.java
@@ -18,10 +18,6 @@ import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- *
- */
 public class ASTGroupBy extends GemFireAST {
   private static final long serialVersionUID = 2262777181888775078L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
index 8e36a9b..0ae5a38 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHint.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
index 93f9db4..c425465 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTHintIdentifier.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal.parse;
 
 import antlr.Token;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
index 4af8ee8..6598c0f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTIteratorDef.java
@@ -20,9 +20,6 @@ import antlr.*;
 import org.apache.geode.cache.query.internal.QCompiler;
 import org.apache.geode.internal.Assert;
 
-/**
- *
- */
 public class ASTIteratorDef extends GemFireAST {
   private static final long serialVersionUID = -736956634497535951L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
index ac9de3d..31dfd2c 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLike.java
@@ -12,18 +12,12 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal.parse;
 
 import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- */
 public class ASTLike extends GemFireAST {
   private static final long serialVersionUID = 1171234838254852463L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
index 576976b..a2c8bfd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTLimit.java
@@ -18,9 +18,6 @@ import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- */
 public class ASTLimit extends GemFireAST {
 
   public ASTLimit() {}
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
index 13d841d..81181bb 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTOrderBy.java
@@ -18,10 +18,6 @@ import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- *
- */
 public class ASTOrderBy extends GemFireAST {
   private static final long serialVersionUID = 2262777181888775078L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
index e44e093..84bc7ca 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTSortCriterion.java
@@ -19,9 +19,6 @@ import antlr.*;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- */
 public class ASTSortCriterion extends GemFireAST {
   private static final long serialVersionUID = -3654854374157753771L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
index fee80d6..0b13f1a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTTrace.java
@@ -12,9 +12,6 @@
  * or implied. See the License for the specific language governing permissions and limitations under
  * the License.
  */
-/**
- *
- */
 package org.apache.geode.cache.query.internal.parse;
 
 import org.apache.geode.cache.query.internal.QCompiler;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
index 04bfe7a..9221593 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/ASTUnary.java
@@ -19,25 +19,13 @@ import antlr.*;
 import org.apache.geode.cache.query.internal.QCompiler;
 import org.apache.geode.cache.query.internal.Support;
 
-/**
- *
- *
- */
 public class ASTUnary extends GemFireAST {
   private static final long serialVersionUID = -3906821390970046083L;
 
-  /**
-   *
-   * @param t
-   */
   public ASTUnary(Token t) {
     super(t);
   }
 
-  /**
-   *
-   *
-   */
   public ASTUnary() {}
 
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
index a0f54b0..240faed 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/GemFireAST.java
@@ -20,9 +20,6 @@ import antlr.Token;
 
 import org.apache.geode.cache.query.internal.QCompiler;
 
-/**
- *
- */
 public class GemFireAST extends CommonAST {
   private static final long serialVersionUID = 779964802274305208L;
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
index 08b7469..bc7a5fd 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/parse/UtilParser.java
@@ -26,9 +26,6 @@ import antlr.*;
 import antlr.collections.*;
 import antlr.debug.misc.ASTFrame;
 
-/**
- *
- */
 public class UtilParser extends LLkParser {
 
   public UtilParser(int k_) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
index 133d4b5..76fa3e3 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/types/TypeUtils.java
@@ -91,13 +91,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
       }
     };
 
-    /**
-     *
-     * @param temporalResult
-     * @param comparator
-     * @return
-     * @throws IllegalArgumentException
-     */
     protected Boolean applyComparator(int temporalResult, int comparator)
         throws IllegalArgumentException {
       switch (comparator) {
@@ -119,13 +112,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
       }
     }
 
-    /**
-     *
-     * @param object1Class
-     * @param object2Class
-     * @param comparator
-     * @return
-     */
     public static ComparisonStrategy get(Class object1Class, Class object2Class, int comparator)
         throws TypeMismatchException {
       if (isAssignableFrom(object1Class, Date.class)
@@ -159,12 +145,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
     /**
      * Executes the comparison strategy.
      *
-     * @param object1
-     * @param object2
-     * @param comparator
-     * @return
-     * @throws TypeMismatchException
-     * @throws ClassCastException
      */
     public abstract Boolean execute(Object object1, Object object2, int comparator)
         throws TypeMismatchException, ClassCastException;
@@ -369,7 +349,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
    * Return the {@link org.apache.geode.cache.query.types.ObjectType} corresponding to the specified
    * Class.
    *
-   * @param cls
    * @return the internal ObjectType implementation that represents the specified class.
    */
   public static ObjectType getObjectType(Class cls) {
@@ -403,7 +382,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
    * Return a fixed {@link org.apache.geode.cache.query.types.ObjectType} representing a Region
    * Entry.
    *
-   * @param rgn
    * @return the internal ObjectType implementation that represents a the region entry class.
    */
   public static ObjectType getRegionEntryType(Region rgn) {
@@ -414,9 +392,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
   /**
    * Compare two booleans.
    *
-   * @param obj1
-   * @param obj2
-   * @param compOp
    * @return a boolean indicating the result of applying the comparison operator on the arguments.
    * @throws TypeMismatchException When either one of the arguments is not a Boolean, or the
    *         comparison operator is not supported.
@@ -442,9 +417,6 @@ public class TypeUtils implements OQLLexerTokenTypes {
 
   /**
    *
-   * @param obj1
-   * @param obj2
-   * @param compOp
    * @return a Boolean, or null if UNDEFINED.
    */
   private static Boolean nullCompare(Object obj1, Object obj2, int compOp) {
@@ -478,13 +450,9 @@ public class TypeUtils implements OQLLexerTokenTypes {
   /**
    * Compares two objects using the operator
    *
-   * @param obj1
-   * @param obj2
-   * @param compOp
    * @return boolean;<br>
    *         {@link Undefined} if either of the operands is {@link Undefined} or if either of the
    *         operands is Null and operator is other than == or !=
-   * @throws TypeMismatchException
    */
   public static Object compare(Object obj1, Object obj2, int compOp) throws TypeMismatchException {
     // Check for nulls first.
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java b/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
index d5916d1..4faa6a6 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/CacheServer.java
@@ -431,7 +431,6 @@ public interface CacheServer {
    * Get the ClientSubscriptionConfig for this cache server. See {@link ClientSubscriptionConfig}
    * for details on the client subscription configuration.
    *
-   * @return ClientSubscriptionConfig
    * @since GemFire 5.7
    */
   ClientSubscriptionConfig getClientSubscriptionConfig();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java b/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
index e022fa6..3911bc9 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/server/ClientSubscriptionConfig.java
@@ -135,7 +135,6 @@ public interface ClientSubscriptionConfig {
   /**
    * Sets the disk store name for overflow
    *
-   * @param diskStoreName
    * @since GemFire 6.5
    */
   void setDiskStoreName(String diskStoreName);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
index 8ab7f14..b8e1fc5 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/snapshot/SnapshotOptions.java
@@ -61,7 +61,6 @@ public interface SnapshotOptions<K, V> extends Serializable {
   /**
    * Sets whether to invoke callbacks when loading a snapshot. The default is false.
    *
-   * @param invokeCallbacks
    *
    * @return the snapshot options
    */
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
index 3cac778..7a82fc4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayEventFilter.java
@@ -29,7 +29,6 @@ public interface GatewayEventFilter extends CacheCallback {
    * This callback is synchronous with the thread which is enqueuing the event into GatewaySender's
    * queue.
    *
-   * @param event
    * @return true if event should be enqueued otherwise return false.
    */
   boolean beforeEnqueue(GatewayQueueEvent event);
@@ -41,7 +40,6 @@ public interface GatewayEventFilter extends CacheCallback {
    * This callback will always be called from the thread which is dispatching events to remote
    * distributed systems
    *
-   * @param event
    * @return true if event should be dispatched otherwise return false.
    */
   boolean beforeTransmit(GatewayQueueEvent event);
@@ -51,7 +49,6 @@ public interface GatewayEventFilter extends CacheCallback {
    * This callback will always be called from the thread which is dispatching events to remote
    * distributed systems
    *
-   * @param event
    */
   void afterAcknowledgement(GatewayQueueEvent event);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
index b5726f4..7ceee56 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewayReceiverFactory.java
@@ -24,7 +24,6 @@ public interface GatewayReceiverFactory {
    * Sets the start port for the <code>GatewayReceiver</code>. If set the GatewayReceiver will start
    * at one of the port between startPort and endPort. The default startPort 50505.
    *
-   * @param startPort
    */
   GatewayReceiverFactory setStartPort(int startPort);
 
@@ -32,7 +31,6 @@ public interface GatewayReceiverFactory {
    * Sets the end port for the GatewayReceiver. If set the GatewayReceiver will start at one of the
    * port between startPort and endPort. The default endPort 50605.
    *
-   * @param endPort
    */
   GatewayReceiverFactory setEndPort(int endPort);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
index ea96345..2fa9907 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySender.java
@@ -236,14 +236,12 @@ public interface GatewaySender {
   /**
    * Adds the provided <code>GatewayEventFilter</code> to this GatewaySender.
    *
-   * @param filter
    */
   void addGatewayEventFilter(GatewayEventFilter filter);
 
   /**
    * Removes the provided <code>GatewayEventFilter</code> from this GatewaySender.
    *
-   * @param filter
    */
   void removeGatewayEventFilter(GatewayEventFilter filter);
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
index 81cd7ab..652de4f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/wan/GatewaySenderFactory.java
@@ -70,21 +70,18 @@ public interface GatewaySenderFactory {
   /**
    * Sets the disk store name for overflow or persistence
    *
-   * @param name
    */
   GatewaySenderFactory setDiskStoreName(String name);
 
   /**
    * Sets the number of dispatcher thread. Default number of dispatcher threads is 5.
    *
-   * @param numThreads
    */
   GatewaySenderFactory setDispatcherThreads(int numThreads);
 
   /**
    * Sets <code>OrderPolicy</code> for this GatewaySender. Default order policy is KEY.
    *
-   * @param policy
    */
   GatewaySenderFactory setOrderPolicy(OrderPolicy policy);
 
@@ -161,14 +158,12 @@ public interface GatewaySenderFactory {
   /**
    * Removes the provided <code>GatewayEventFilter</code> from this GatewaySender.
    *
-   * @param filter
    */
   GatewaySenderFactory removeGatewayEventFilter(GatewayEventFilter filter);
 
   /**
    * Removes the provided <code>GatewayTransportFilter</code> from this GatewaySender.
    *
-   * @param filter
    */
   GatewaySenderFactory removeGatewayTransportFilter(GatewayTransportFilter filter);
 

-- 
To stop receiving notification emails like this one, please contact
prhomberg@apache.org.