You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/02/01 19:58:04 UTC

[3/4] incubator-geode git commit: GEODE-805: Fix javadoc warnings.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
index 1eaabf1..98e72bd 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/BucketAdvisor.java
@@ -506,7 +506,7 @@ public final class BucketAdvisor extends CacheDistributionAdvisor  {
   }
   
   /**
-   * @guarded.By this
+   * Concurrency: protected by synchronizing on *this*
    */
   @Override
   protected void profileCreated(Profile profile) {
@@ -527,7 +527,7 @@ public final class BucketAdvisor extends CacheDistributionAdvisor  {
   }
 
   /**
-   * @guarded.By this
+   * Concurrency: protected by synchronizing on *this*
    */
   @Override
   protected void profileUpdated(Profile profile) {
@@ -548,7 +548,7 @@ public final class BucketAdvisor extends CacheDistributionAdvisor  {
   }
 
   /**
-   * @guarded.By this
+   * Concurrency: protected by synchronizing on *this*
    */
   @Override
   protected void profileRemoved(Profile profile) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheObserver.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheObserver.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheObserver.java
index 6b18d86..e74760c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheObserver.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/CacheObserver.java
@@ -185,7 +185,6 @@ public interface CacheObserver
   
   /**
    * Invoked just before ShutdownAll operation
-   * @param emptyOplog
    */
   void beforeShutdownAll();
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXRollbackMessage.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXRollbackMessage.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXRollbackMessage.java
index d21fc28..a69a276 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXRollbackMessage.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXRollbackMessage.java
@@ -256,7 +256,7 @@ public final class DistTXRollbackMessage extends TXMessage {
 
   /**
    * A processor to capture the value returned by
-   * {@link DistTXRollbackMessage.DistTXCommitReplyMessage}
+   * {@link DistTXRollbackReplyMessage}
    * 
    */
   public static class DistTXRollbackResponse extends RemoteOperationResponse {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
index 95deab6..c81db38 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/DistTXState.java
@@ -345,10 +345,6 @@ public class DistTXState extends TXState {
     // Cleanup is called next
   }
 
-  /**
-   * @param txStateProxy
-   * @return
-   */
   protected boolean applyOpsOnRedundantCopy(DistributedMember sender,
       ArrayList<DistTxEntryEvent> secondaryTransactionalOperations) {
     boolean returnValue = true;
@@ -434,7 +430,7 @@ public class DistTXState extends TXState {
    * Apply the individual tx op on secondary
    * 
    * Calls local function such as putEntry instead of putEntryOnRemote as for
-   * this {@link DistTXStateOnCoordinator) as events will always be local. In
+   * this {@link DistTXStateOnCoordinator} as events will always be local. In
    * parent {@link DistTXState} class will call remote version of functions
    * 
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
index a4f53a5..83b00b4 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
@@ -62,7 +62,7 @@ public class EventTracker
    * a mapping of originator to the last event applied to this cache 
    *
    * Keys are instances of {@link ThreadIdentifier}, values are instances
-   * of {@link EventSeqnoHolder}.
+   * of {@link com.gemstone.gemfire.internal.cache.EventTracker.EventSeqnoHolder}.
    */
   protected final ConcurrentMap<ThreadIdentifier, EventSeqnoHolder> recordedEvents 
       = new ConcurrentHashMap<ThreadIdentifier, EventSeqnoHolder>(100);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index 4e8f0c9..256e293 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -1127,8 +1127,6 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Perform initialization, solve the early escaped reference problem by putting publishing references to this instance
    * in this method (vs. the constructor).
-   *
-   * @return the initialized instance of the cache
    */
   private void initialize() {
     if (GemFireCacheImpl.instance != null) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/IdentityArrayList.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/IdentityArrayList.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/IdentityArrayList.java
index 71d8f4e..3b54687 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/IdentityArrayList.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/IdentityArrayList.java
@@ -46,7 +46,7 @@ import it.unimi.dsi.fastutil.objects.ObjectListIterator;
  * <em>never</em> made smaller (even on a {@link #clear()}). A family of
  * {@linkplain #trim() trimming methods} lets you control the size of the
  * backing array; this is particularly useful if you reuse instances of this class.
- * Range checks are equivalent to those of {@link java.util}'s classes, but
+ * Range checks are equivalent to those of <code>java.util</code>'s classes, but
  * they are delayed as much as possible. 
  *
  * <p>The backing array is exposed by the {@link #elements()} method. If an instance

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
index c7ceff4..7ca8a29 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/InitialImageOperation.java
@@ -1566,7 +1566,7 @@ public class InitialImageOperation  {
     public String regionPath;
     
     /**
-     * Id of the {@link ImageProcessor} that will handle the replies
+     * Id of the {@link InitialImageOperation.ImageProcessor} that will handle the replies
      */
     protected int processorId;
     
@@ -2237,7 +2237,7 @@ public class InitialImageOperation  {
     protected String regionPath;
     
     /**
-     * Id of the {@link ImageProcessor} that will handle the replies
+     * Id of the {@link InitialImageOperation.ImageProcessor} that will handle the replies
      */
     protected int processorId;
             
@@ -2499,7 +2499,7 @@ public class InitialImageOperation  {
     protected String regionPath;
     
     /**
-     * Id of the {@link ImageProcessor} that will handle the replies
+     * Id of the {@link InitialImageOperation.ImageProcessor} that will handle the replies
      */
     protected int processorId;
     

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
index 3186989..1c5f321 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
@@ -12828,7 +12828,11 @@ public class LocalRegion extends AbstractRegion
    * or it may recover an index map that was previously persisted, depending
    * on whether the index previously existed.
    * 
+   * @param indexName the name of the index
+   * @param indexedExpression the index expression
+   * @param fromClause the from clause.
    * 
+   * @return The index map.
    * 
    * @throws IllegalStateException if this region is not using
    * soplog persistence
@@ -12836,12 +12840,6 @@ public class LocalRegion extends AbstractRegion
    * @throws IllegalStateException if this index was previously
    * persisted with a different expression or from clause.
    * 
-   * @param indexName the name of the index
-   * @param indexedExpression the index expression
-   * @param fromClause the from clause.
-   *  
-   * 
-   * @return The index map.
    */
   public IndexMap getIndexMap(String indexName, String indexedExpression, 
       String fromClause) {
@@ -12860,18 +12858,18 @@ public class LocalRegion extends AbstractRegion
    * or it may recover an index map that was previously persisted, depending
    * on whether the index previously existed.
    * 
+   * @param indexName the name of the index
+   * @param indexedExpression the index expression
+   * @param fromClause the from clause.
+   * 
+   * @return The index map.
+   * 
    * @throws IllegalStateException if this region is not using
    * soplog persistence
    * 
    * @throws IllegalStateException if this index was previously
    * persisted with a different expression or from clause.
    * 
-   * @param indexName the name of the index
-   * @param indexedExpression the index expression
-   * @param fromClause the from clause.
-   *  
-   * 
-   * @return The index map.
    */
   public IndexMap getUnsortedIndexMap(String indexName, String indexedExpression, 
       String fromClause) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
index a14e99f..09e945b 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
@@ -407,7 +407,7 @@ public class PartitionedRegion extends LocalRegion implements
    * the thread locally destroying this pr.  not volatile,
    * so always check isLocallyDestroyed before checking locallyDestroyingThread
    * 
-   * @guarded.By {@link #isLocallyDestroyed}
+   * Concurrency: {@link #isLocallyDestroyed} is volatile
    */
   public Thread locallyDestroyingThread;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
index 3a1a664..ee01c9b 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
@@ -174,7 +174,6 @@ public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
    * acknowledgement
    * 
    * @throws EntryExistsException
-   * @throws DataLocationException 
    */
   @Override
   protected boolean operateOnRegion(DistributionManager dm,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
index ba7659b..b6af62a 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
@@ -581,8 +581,6 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
     /**
      * Waits for the response from the {@link RemoteOperationMessage}'s recipient
      * @throws CacheException  if the recipient threw a cache exception during message processing 
-     * @throws ForceReattemptException if the recipient left the distributed system before the response
-     * was received.  
      * @throws PrimaryBucketException 
      */
     final public void waitForCacheException() 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable.java
index 2214b93..ff200ac 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable.java
@@ -134,7 +134,7 @@ public abstract class CompressedCachedDeserializable implements
 
   /**
    * Returns the deserialized value.  However, unlike the specification of this method as described in
-   * @link {@link CachedDeserializable#getDeserializedForReading()} this method does not 
+   * {@link CachedDeserializable#getDeserializedForReading()} this method does not 
    * optimize for future calls leaving the value serialized and compressed.
    */
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceAdvisor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceAdvisor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceAdvisor.java
index 7ac5340..3b28628 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceAdvisor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceAdvisor.java
@@ -186,7 +186,6 @@ public class ResourceAdvisor extends DistributionAdvisor {
      * @param irm The resource manager which is requesting distribution
      * @param recips The recipients of the message
      * @param profile Profile to send in this message
-     * @throws InterruptedException
      * @throws ReplyException
      */
     public static void send(final InternalResourceManager irm, Set<InternalDistributedMember> recips,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceListener.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceListener.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceListener.java
index 947ee96..aa8845c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceListener.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/control/ResourceListener.java
@@ -18,7 +18,7 @@
 package com.gemstone.gemfire.internal.cache.control;
 
 /**
- * Provides notification of {@link com.gemstone.gemfire.cache GemFire Cache}
+ * Provides notification of {@link com.gemstone.gemfire.cache.Cache}
  * resource management events.
  * 
  * @since 6.0

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStats.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStats.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStats.java
index 2683964..905211a 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStats.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/FunctionServiceStats.java
@@ -198,7 +198,6 @@ public class FunctionServiceStats {
    *          <code>Statistics</code> instance
    * @param name
    *          The name of the <code>Statistics</code>
-   * @throws Exception 
    */
   public FunctionServiceStats(StatisticsFactory factory, String name) {
     this._stats = factory.createAtomicStatistics(_type, name);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
index 829ac71..fa4d283 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalExecution.java
@@ -71,8 +71,6 @@ public interface InternalExecution extends Execution {
    * @param bucketIDs
    *          Set of bucketIDs defining the buckets to be used for executing the function
    * @return an Execution with the filter
-   * @throws FunctionExecutionException
-   *           if bucketIDs is null or empty.
    * @throws UnsupportedOperationException
    *           if not called after
    *           {@link FunctionService#onRegion(com.gemstone.gemfire.cache.Region)}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
index ea0fcf4..eae2bc8 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/InternalFunctionService.java
@@ -114,16 +114,13 @@ public class InternalFunctionService {
    *
    * @param regionService
    *          obtained from {@link ClientCacheFactory#create} or
-   *          {@link ClientCache#createAuthenticatedView(Properties)}.
+   *          {@link ClientCache#createAuthenticatedView(java.util.Properties)}.
    * @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 servers of each group
    * @return Execution
-   * @throws FunctionException
-   *           if cache is null, is not on a client, or it does not have a
-   *           default pool
    * @since 7.0
    */
   public static Execution onServers(RegionService regionService, String... groups) {
@@ -141,16 +138,13 @@ public class InternalFunctionService {
    *
    * @param regionService
    *          obtained from {@link ClientCacheFactory#create()} or
-   *          {@link ClientCache#createAuthenticatedView(Properties)}.
+   *          {@link ClientCache#createAuthenticatedView(java.util.Properties)}.
    * @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 one server of each group
    * @return Execution
-   * @throws FunctionException
-   *           if cache is null, is not on a client, or it does not have a
-   *           default pool
    * @since 7.0
    */
   public static Execution onServer(RegionService regionService, String... groups) {
@@ -174,8 +168,6 @@ public class InternalFunctionService {
    *          <code>groups</code></a>) on which to execute the function.
    *          Function will be executed on all servers of each group
    * @return Execution
-   * @throws FunctionException
-   *           if Pool instance passed in is null
    * @since 7.0
    */
   public static Execution onServers(Pool pool, String... groups) {
@@ -199,8 +191,6 @@ public class InternalFunctionService {
    *          <code>groups</code></a>) on which to execute the function.
    *          Function will be executed on one server of each group
    * @return Execution
-   * @throws FunctionException
-   *           if Pool instance passed in is null
    * @since 7.0
    */
   public static Execution onServer(Pool pool, String... groups) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
index b0f4d93..b5a9478 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/CommitFunction.java
@@ -51,7 +51,7 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * <code>Boolean.FALSE</code>.<br />
  * 
  * To execute this function, it is recommended to use the {@link Execution} obtained by
- * using {@link TransactionFunctionService}. <br />
+ * using TransactionFunctionService. <br />
  * 
  * To summarize, this function should be used as follows:
  * 
@@ -65,7 +65,6 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * it is the user's responsibility to register this function. see
  * {@link FunctionService#registerFunction(Function)}
  * 
- * @see TransactionFunctionService
  * @since 6.6.1
  * @author sbawaska
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
index 459cd47..beccebb 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/execute/util/RollbackFunction.java
@@ -50,7 +50,7 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * <code>Boolean.FALSE</code>.<br />
  * 
  * To execute this function, it is recommended to use the {@link Execution} obtained by
- * using {@link TransactionFunctionService}. <br />
+ * using TransactionFunctionService. <br />
  * 
  * To summarize, this function should be used as follows:
  * 
@@ -64,7 +64,6 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * it is the user's responsibility to register this function. see
  * {@link FunctionService#registerFunction(Function)}
  * 
- * @see TransactionFunctionService
  * @since 6.6.1
  * @author sbawaska
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperation.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperation.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperation.java
index e21644d..e0bf42d 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperation.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/StreamingPartitionOperation.java
@@ -211,8 +211,6 @@ public abstract class StreamingPartitionOperation extends StreamingOperation {
     /**
      * Waits for the response from the {@link PartitionMessage}'s recipient
      * @throws CacheException  if the recipient threw a cache exception during message processing
-     * @throws ForceReattemptException if the recipient left the distributed system before the response
-     * was received.
      * @throws QueryException if the recipient threw a query exception
      * @throws RegionDestroyedException if the peer has closed its copy of the region
      * @return The set of members that failed.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
index 96bf657..2bbde75 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/partitioned/rebalance/PartitionedRegionLoadModel.java
@@ -161,8 +161,6 @@ public class PartitionedRegionLoadModel {
    * Create a new model
    * @param operator the operator which performs the actual creates/moves for buckets
    * @param redundancyLevel The expected redundancy level for the region
-   * @param enforceLocalMaxMemory 
-   * @param criticalMembers 
    */
   public PartitionedRegionLoadModel(BucketOperator operator,
       int redundancyLevel, int numBuckets, AddressComparor addressComparor,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistenceAdvisorImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistenceAdvisorImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistenceAdvisorImpl.java
index 168fbfc..750cf81 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistenceAdvisorImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistenceAdvisorImpl.java
@@ -285,10 +285,6 @@ public class PersistenceAdvisorImpl implements PersistenceAdvisor {
     return memberManager.isRevoked(this.regionPath, id);
   }
 
-  /**
-   * @throws ReplyException 
-   * @throws IOException 
-   */
   public void setOnline(boolean didGII, boolean atomicCreation,
       PersistentMemberID newId) throws ReplyException {
     if(online) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistentMemberView.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistentMemberView.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistentMemberView.java
index f4d9e94..3f4f2ab 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistentMemberView.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/persistence/PersistentMemberView.java
@@ -81,7 +81,6 @@ public interface PersistentMemberView {
    * This is only called after this member is online.
    * 
    * @param persistentID
-   * @throws IOException
    */
   public void memberRemoved(PersistentMemberID persistentID);
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/InternalClientMembership.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/InternalClientMembership.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/InternalClientMembership.java
index 00d1539..806a412 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/InternalClientMembership.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/InternalClientMembership.java
@@ -73,7 +73,7 @@ public final class InternalClientMembership  {
   
   /**
    * Must be locked whenever references to the volatile field 
-   * {@link #membershipListeners} is changed.
+   * {@link #clientMembershipListeners} is changed.
    */
   private static final Object membershipLock = new Object();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheClientProxy.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheClientProxy.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheClientProxy.java
index 5101770..adaf400 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheClientProxy.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/cache/tier/sockets/CacheClientProxy.java
@@ -137,7 +137,7 @@ public class CacheClientProxy implements ClientSession {
   protected String _remoteHostAddress;
 
   /**
-   * @guarded.By {@link #isMarkedForRemovalLock}
+   * Concurrency: protected by synchronization of {@link #isMarkedForRemovalLock}
    */
   protected boolean isMarkedForRemoval = false;
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/concurrent/CompactConcurrentHashSet2.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/concurrent/CompactConcurrentHashSet2.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/concurrent/CompactConcurrentHashSet2.java
index 2276758..549c04e 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/concurrent/CompactConcurrentHashSet2.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/concurrent/CompactConcurrentHashSet2.java
@@ -929,10 +929,10 @@ public class CompactConcurrentHashSet2<V> extends AbstractSet<V> implements Set<
     /**
      * Returns a string representation of this map.  The string
      * representation consists of a list of key-value mappings (in no
-     * particular order) enclosed in braces ("{@code {}}").  Adjacent
-     * mappings are separated by the characters {@code ", "} (comma
+     * particular order) enclosed in braces (<code>{}</code>).  Adjacent
+     * mappings are separated by the characters <code>", "</code> (comma
      * and space).  Each key-value mapping is rendered as the key
-     * followed by an equals sign ("{@code =}") followed by the
+     * followed by an equals sign (<code>=</code>) followed by the
      * associated value.
      *
      * @return a string representation of this map

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/jta/GlobalTransaction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/jta/GlobalTransaction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/jta/GlobalTransaction.java
index 189c006..585470a 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/jta/GlobalTransaction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/jta/GlobalTransaction.java
@@ -117,7 +117,8 @@ public class GlobalTransaction  {
    * Delists the XAResources associated with the Global Transaction and
    * Completes the Global transaction associated with the current thread. If any
    * exception is encountered, rollback is called on the current transaction.
-   * @.concurrency Some paths invoke this method after taking a lock on "this" while 
+   * 
+   * Concurrency: Some paths invoke this method after taking a lock on "this" while 
    * other paths invoke this method without taking a lock on "this". Since both types of path do
    * act on the resourceMap collection, it is being protected by a lock on resourceMap too.
    * 
@@ -236,6 +237,10 @@ public class GlobalTransaction  {
    * Delists the XAResources associated with the Global Transaction and Roll
    * back the transaction associated with the current thread.
    * 
+   * Concurrency: Some paths invoke this method after taking a lock on "this" while 
+   * other paths invoke this method without taking a lock on "this". Since both types of path do
+   * act on the resourceMap collection, it is being protected by a lock on resourceMap too.
+   * 
    * @throws java.lang.SecurityException -
    *           Thrown to indicate that the thread is not allowed to roll back
    *           the transaction.
@@ -245,9 +250,6 @@ public class GlobalTransaction  {
    * @throws SystemException -
    *           Thrown if the transaction manager encounters an unexpected error
    *           condition.
-   * @.concurrency Some paths invoke this method after taking a lock on "this" while 
-   * other paths invoke this method without taking a lock on "this". Since both types of path do
-   * act on the resourceMap collection, it is being protected by a lock on resourceMap too.
    * 
    * @see javax.transaction.TransactionManager#rollback()
    */
@@ -331,7 +333,8 @@ public class GlobalTransaction  {
    * XAResource, then enlists the current XAResource. For subsequent
    * XAResources, it checks if is the same Resource Manager. If it is, then the
    * XAResources are addded, else an exception is thrown
-   * @.concurrency The order of acquiring lock will be lock on "this" followed
+   * 
+   * Concurrency: The order of acquiring lock will be lock on "this" followed
    * by lock on resourceMap. It is possible that in some functions of this
    * class both the locks are not needed , but if the two are acquired then the realitive
    * order will always be"this" followed by resourceMap. 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/ProcessController.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/ProcessController.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/ProcessController.java
index 94ea8cf..71fb2e3 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/ProcessController.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/ProcessController.java
@@ -47,7 +47,7 @@ public interface ProcessController {
    * is provided. Only the {@link MBeanProcessController} supports the use of
    * specifying a PID because it uses the Attach API.
    *  
-   * @throws AttachAPINotFoundException if the Attach API is not found
+   * @throws com.gemstone.gemfire.lang.AttachAPINotFoundException if the Attach API is not found
    */
   public void checkPidSupport();
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/signal/Signal.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/signal/Signal.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/signal/Signal.java
index 98a9b79..6649f40 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/signal/Signal.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/process/signal/Signal.java
@@ -25,9 +25,9 @@ import com.gemstone.gemfire.internal.lang.StringUtils;
  * @author John Blum
  * @see com.gemstone.gemfire.internal.process.signal.SignalType
  * @since 7.0
- * @link http://www.fromdual.com/operating-system-signals
- * @link http://www.ibm.com/developerworks/java/library/i-signalhandling/#table1
- * @link http://publib.boulder.ibm.com/infocenter/java7sdk/v7r0/index.jsp?topic=%2Fcom.ibm.java.aix.70.doc%2Fuser%2Fsighand.html
+ * @see <a href="http://www.fromdual.com/operating-system-signals">http://www.fromdual.com/operating-system-signals</a>
+ * @see <a href="http://www.ibm.com/developerworks/java/library/i-signalhandling/#table1">http://www.ibm.com/developerworks/java/library/i-signalhandling/#table1</a>
+ * @see <a href="http://publib.boulder.ibm.com/infocenter/java7sdk/v7r0/index.jsp?topic=%2Fcom.ibm.java.aix.70.doc%2Fuser%2Fsighand.html">http://publib.boulder.ibm.com/infocenter/java7sdk/v7r0/index.jsp?topic=%2Fcom.ibm.java.aix.70.doc%2Fuser%2Fsighand.html</a>
  */
 @SuppressWarnings("unused")
 public enum Signal {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteArrayWrapper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteArrayWrapper.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteArrayWrapper.java
index cc36e1d..1554b1c 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteArrayWrapper.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteArrayWrapper.java
@@ -117,7 +117,7 @@ public class ByteArrayWrapper implements DataSerializable, Comparable<ByteArrayW
   /**
    * This equals is neither symmetric and therefore not transitive, 
    * because a String with the same underlying bytes is considered
-   * equal. Clearly calling {@link String#equals(Object)) would not 
+   * equal. Clearly calling {@link String#equals(Object)} would not 
    * yield the same result
    */
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteToCommandDecoder.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteToCommandDecoder.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteToCommandDecoder.java
index dcd080e..96d7853 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteToCommandDecoder.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/ByteToCommandDecoder.java
@@ -26,7 +26,7 @@ import java.util.List;
 /**
  * This is the first part of the channel pipeline for Netty. Here incoming
  * bytes are read and a created {@link Command} is sent down the pipeline.
- * It is unfortunate that this class is not {@link Sharable} because no state
+ * It is unfortunate that this class is not {@link io.netty.channel.ChannelHandler.Sharable} because no state
  * is kept in this class. State is kept by {@link ByteToMessageDecoder}, it may
  * be worthwhile to look at a different decoder setup as to avoid allocating a decoder
  * for every new connection.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/Coder.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/Coder.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/Coder.java
index 50486c1..6906eb6 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/Coder.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/Coder.java
@@ -489,7 +489,7 @@ public class Coder {
    * so it is converted as a string not as a literal double
    * @param bytes Array holding double
    * @return Parsed value
-   * @throw NumberFormatException if bytes to string does not yield a convertable double
+   * @throws NumberFormatException if bytes to string does not yield a convertible double
    */
   public static Double bytesToDouble(byte[] bytes) {
     return stringToDouble(bytesToString(bytes));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RedisCommandParserException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RedisCommandParserException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RedisCommandParserException.java
index f660206..d58e20d 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RedisCommandParserException.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RedisCommandParserException.java
@@ -17,7 +17,7 @@
 package com.gemstone.gemfire.internal.redis;
 
 /**
- * Exception thrown by {@link CommandParser} when a command has illegal syntax
+ * Exception thrown by CommandParser (non-existent class) when a command has illegal syntax
  * 
  * @author Vitaliy Gavrilov
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionCreationException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionCreationException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionCreationException.java
index b21ce14..6ecaf8b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionCreationException.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionCreationException.java
@@ -17,7 +17,7 @@
 package com.gemstone.gemfire.internal.redis;
 
 /**
- * This exception is used when an error happens while creating a {@link Region} globally
+ * This exception is used when an error happens while creating a {@link com.gemstone.gemfire.cache.Region} globally
  * 
  * @author Vitaliy Gavrilov
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionProvider.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionProvider.java
index d568386..f9539e5 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionProvider.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/RegionProvider.java
@@ -503,7 +503,6 @@ public class RegionProvider implements Closeable {
    * Removes an expiration from a key
    * 
    * @param key Key
-   * @param context Context
    * @return True is expiration cancelled on the key, false otherwise
    */
   public final boolean cancelKeyExpiration(ByteArrayWrapper key) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/AbstractExecutor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/AbstractExecutor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/AbstractExecutor.java
index 787268e..c6b275f 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/AbstractExecutor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/AbstractExecutor.java
@@ -90,14 +90,6 @@ public abstract class AbstractExecutor implements Executor {
       throw new RedisDataTypeMismatchException("The key name \"" + key + "\" is already used by a " + currentType.toString());
   }
 
-  /**
-   * Getter method for a {@link QueryType}
-   * 
-   * @param key Key
-   * @param type The specific query
-   * @param context context
-   * @return The Query of this key and QueryType
-   */
   protected Query getQuery(ByteArrayWrapper key, Enum<?> type, ExecutionHandlerContext context) {
     return context.getRegionProvider().getQuery(key, type);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/hll/HyperLogLogPlus.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/hll/HyperLogLogPlus.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/hll/HyperLogLogPlus.java
index 059c7c9..8bba36d 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/hll/HyperLogLogPlus.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/redis/executor/hll/HyperLogLogPlus.java
@@ -789,7 +789,6 @@ public class HyperLogLogPlus implements ICardinality, Serializable {
    * This operation does not imply a loss of precision.
    *
    * @param other A compatible Hyperloglog++ instance (same p and sp)
-   * @throws CardinalityMergeException if other is not compatible
    */
   public void addAll(HyperLogLogPlus other) throws HyperLogLogPlusMergeException {
     if (other.sizeof() != sizeof()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
index dcffd75..c1b40e4 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
@@ -381,8 +381,6 @@ public abstract class NativeCalls {
   /**
    * Set given extended socket options on a Java {@link Socket}.
    * 
-   * @throws SocketException
-   *           if there was an exception setting the option on the socket
    * @throws UnsupportedOperationException
    *           if the native API to set the option could not be found or invoked
    * 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
index 75dc330..0695e4c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
@@ -275,7 +275,7 @@ public class CustomEntryConcurrentHashMap<K, V> extends AbstractMap<K, V> implem
    * never exported out as a user-visible Map.Entry.
    * 
    * Made this public so RegionEntries can directly implement this to reduce
-   * memory overhead of separate {@link HashEntry} objects for each entry in the
+   * memory overhead of separate {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry} objects for each entry in the
    * map.
    */
   public static interface HashEntry<K, V> {
@@ -398,13 +398,13 @@ public class CustomEntryConcurrentHashMap<K, V> extends AbstractMap<K, V> implem
   }
 
   /**
-   * Interface to enable creation of new {@link HashEntry} objects by caller.
+   * Interface to enable creation of new {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry} objects by caller.
    * This can be used, for example, to return GemFire RegionEntries directly.
    */
   public static interface HashEntryCreator<K, V> {
 
     /**
-     * Create a new {@link HashEntry} given the key, hash, value and next
+     * Create a new {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry} given the key, hash, value and next
      * element.
      */
     public HashEntry<K, V> newEntry(K key, int hash, HashEntry<K, V> next,
@@ -502,12 +502,12 @@ public class CustomEntryConcurrentHashMap<K, V> extends AbstractMap<K, V> implem
 // GemStone addition
 
     /**
-     * {@link HashEntryCreator} for the map to create {@link HashEntry}s.
+     * {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntryCreator} for the map to create {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry}s.
      */
     final HashEntryCreator<K, V> entryCreator;
 
     /**
-     * Lock used when updating the {@link HashEntry#getNextEntry()} link of an
+     * Lock used when updating the {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.HashEntry#getNextEntry()} link of an
      * entry.
      */
     final ReentrantReadWriteLock listUpdateLock;
@@ -1129,7 +1129,7 @@ RETRYLOOP:
   }
 
   /**
-   * Extension of {@link Segment} using reference-equality comparison for key,
+   * Extension of {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.Segment} using reference-equality comparison for key,
    * value equality instead of equals method.
    * 
    * @author swale
@@ -1738,7 +1738,7 @@ RETRYLOOP:
 
   /**
    * Simple adapter class providing empty default implementations for
-   * {@link MapCallback}.
+   * {@link com.gemstone.gemfire.internal.util.concurrent.CustomEntryConcurrentHashMap.MapCallback}.
    */
   public static class MapCallbackAdapter<K, V, C, P> implements
       MapCallback<K, V, C, P> {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/AgentUtil.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/AgentUtil.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/AgentUtil.java
index b8a68c0..4bfabeb 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/AgentUtil.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/AgentUtil.java
@@ -52,7 +52,6 @@ public class AgentUtil {
    *    classpath
    *
    * @param warFilePrefix : the prefix of the war file, e.g. gemfire-web, gemfire-pulse, or gemfire-web-api
-   * @return
      */
   public String findWarLocation(String warFilePrefix) {
     String gemfireHome = getGemFireHome();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/FederatingManager.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/FederatingManager.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/FederatingManager.java
index 91e7b22..ccfa0a8 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/FederatingManager.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/FederatingManager.java
@@ -584,8 +584,6 @@ public class FederatingManager extends Manager {
    * @param objectName
    *          {@link javax.management.ObjectName} of the MBean
    * @return last updated time of the proxy
-   * 
-   * @throws InstanceNotFoundException
    */
   public long getLastUpdateTime(ObjectName objectName) {
     return proxyFactory.getLastUpdateTime(objectName);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/JmxManagerAdvisor.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/JmxManagerAdvisor.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/JmxManagerAdvisor.java
index e47400d..c0d1c0b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/JmxManagerAdvisor.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/JmxManagerAdvisor.java
@@ -241,7 +241,6 @@ public class JmxManagerAdvisor extends DistributionAdvisor {
     /**
      * Send profile to the provided members
      * @param recips The recipients of the message
-     * @throws InterruptedException
      * @throws ReplyException
      */
     public static void send(final DM dm, Set<InternalDistributedMember> recips,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/MBeanProxyFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/MBeanProxyFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/MBeanProxyFactory.java
index 4e14e5e..58e1adf 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/MBeanProxyFactory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/MBeanProxyFactory.java
@@ -342,8 +342,6 @@ public class MBeanProxyFactory {
    * @param objectName
    *          {@link javax.management.ObjectName} of the MBean
    * @return last updated time of the proxy
-   * 
-   * @throws InstanceNotFoundException
    */
   public long getLastUpdateTime(ObjectName objectName) {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/configuration/domain/CacheElement.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/configuration/domain/CacheElement.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/configuration/domain/CacheElement.java
index aed1058..7779d0f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/configuration/domain/CacheElement.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/configuration/domain/CacheElement.java
@@ -169,7 +169,6 @@ public class CacheElement {
    * @throws IOException
    * @throws ParserConfigurationException 
    * @throws XPathExpressionException 
-   * @throws ValidityException
    * @since 8.1
    */
   private static final void buildElementMapCacheType(final LinkedHashMap<String, CacheElement> elementMap, final InputSource inputSource) throws SAXException,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/domain/Link.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/domain/Link.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/domain/Link.java
index d557cb7..92677d6 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/domain/Link.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/domain/Link.java
@@ -141,7 +141,7 @@ public class Link implements Comparable<Link>, Serializable {
    * @return a String representation of the HTTP request-line.
    * @see java.net.URI
    * @see com.gemstone.gemfire.management.internal.web.http.HttpMethod
-   * @link http://www.w3.org/Protocols/rfc2616/rfc2616-sec5.html
+   * @see <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec5.html">http://www.w3.org/Protocols/rfc2616/rfc2616-sec5.html</a>
    */
   public String toHttpRequestLine() {
     return getMethod().name().concat(StringUtils.SPACE).concat(UriUtils.decode(getHref().toString()));

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/ClientHttpRequest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/ClientHttpRequest.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/ClientHttpRequest.java
index 667b444..1b8f42f 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/ClientHttpRequest.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/ClientHttpRequest.java
@@ -392,7 +392,7 @@ public class ClientHttpRequest implements HttpRequest {
    * <p/>
    * @param headerName a String specifying the name of the HTTP header.
    * @param headerValue a String containing the value of the HTTP header.
-   * @see org.springframework.http.HttpHeaders#set(Object, Object)
+   * @see org.springframework.http.HttpHeaders#set(String, String)
    */
   public void setHeader(final String headerName, final String headerValue) {
     getHeaders().set(headerName, headerValue);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/HttpHeader.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/HttpHeader.java b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/HttpHeader.java
index 2896a97..4e17503 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/HttpHeader.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/management/internal/web/http/HttpHeader.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.internal.lang.StringUtils;
  * The HttpHeader enum is an enumeration of all HTTP request/response header names.
  * <p/>
  * @author John Blum
- * @link http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html
+ * @see <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html">http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html</a>
  * @since 8.0
  */
 @SuppressWarnings("unused")

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/package.html
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/package.html b/gemfire-core/src/main/java/com/gemstone/gemfire/package.html
index 1da3b37..198df7c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/package.html
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/package.html
@@ -19,9 +19,9 @@ limitations under the License.
 
 <P>The base package of the GemFire Java product, featuring highly
 concurrent distributed {@linkplain com.gemstone.gemfire.cache.Cache caching}
-with {@linkplain com.gemstone.gemfire.cache.CacheEvent cache event} delivery, {@linkplain
-com.gemstone.gemfire.cache.query OQL querying}, and {@linkplain
-com.gemstone.gemfire.admin remote cache administration}, built using a {@linkplain
+with {@linkplain com.gemstone.gemfire.cache.CacheEvent cache event} delivery,
+<a href="{@docRoot}/com/gemstone/gemfire/cache/query/package-summary.html#package_description">OQL querying</a>, and
+<a href="{@docRoot}/com/gemstone/gemfire/admin/package-summary.html#package_description">remote cache administration</a>, built using a {@linkplain
 com.gemstone.gemfire.distributed.DistributedSystem} which includes a
 {@linkplain com.gemstone.gemfire.distributed.DistributedLockService}.
 </P>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/pdx/PdxInstance.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/pdx/PdxInstance.java b/gemfire-core/src/main/java/com/gemstone/gemfire/pdx/PdxInstance.java
index 69236e4..7f6b831 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/pdx/PdxInstance.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/pdx/PdxInstance.java
@@ -195,7 +195,7 @@ public boolean isIdentityField(String fieldName);
    * made to the returned value will not modify this PdxInstance.
    * 
    * @return a {@link WritablePdxInstance}
-   * @throws IllegaStateException if the PdxInstance is an enum.
+   * @throws IllegalStateException if the PdxInstance is an enum.
    */
   public WritablePdxInstance createWriter();
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/redis/GemFireRedisServer.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/redis/GemFireRedisServer.java b/gemfire-core/src/main/java/com/gemstone/gemfire/redis/GemFireRedisServer.java
index 15929d5..e90b724 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/redis/GemFireRedisServer.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/redis/GemFireRedisServer.java
@@ -283,7 +283,7 @@ public class GemFireRedisServer {
    * Helper method to set the number of worker threads
    * 
    * @return If the System property {@value #NUM_THREADS_SYS_PROP_NAME} is set then that number
-   * is used, otherwise {@value #DEFAULT_WORKER_THREADS_PER_CORE} * # of cores
+   * is used, otherwise 4 * # of cores
    */
   private int setNumWorkerThreads() {
     String prop = System.getProperty(NUM_THREADS_SYS_PROP_NAME);
@@ -631,7 +631,6 @@ public class GemFireRedisServer {
    * <br>-log-level=
    * 
    * @param args Command line args
-   * @throws IOException
    */
   public static void main(String[] args) {
     int port = DEFAULT_REDIS_SERVER_PORT;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/main/java/com/gemstone/gemfire/security/GemFireSecurityException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/security/GemFireSecurityException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/security/GemFireSecurityException.java
index 0a2aeb9..1f97420 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/security/GemFireSecurityException.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/security/GemFireSecurityException.java
@@ -20,7 +20,7 @@ package com.gemstone.gemfire.security;
 import com.gemstone.gemfire.GemFireException;
 
 /**
- * The base class for all {@link com.gemstone.gemfire.security} related
+ * The base class for all com.gemstone.gemfire.security package related
  * exceptions.
  * 
  * @author Sumedh Wale

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/examples/TestObject.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/examples/TestObject.java b/gemfire-core/src/test/java/com/examples/TestObject.java
index fe7a4dc..0eb5d4a 100644
--- a/gemfire-core/src/test/java/com/examples/TestObject.java
+++ b/gemfire-core/src/test/java/com/examples/TestObject.java
@@ -17,8 +17,10 @@
 package com.examples;
 
 /**
- * A simple test object used by the {@link
- * com.gemstone.gemfire.internal.enhancer.serializer.SerializingStreamPerfTest} * that must be in a non-<code>com.gemstone</code> package.
+ * A simple test object used by the 
+ * com.gemstone.gemfire.internal.enhancer.serializer.SerializingStreamPerfTest 
+ * (this test no longer exists?) 
+ * that must be in a non-<code>com.gemstone</code> package.
  *
  * @author David Whitlock
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/examples/ds/PutDataSerializables.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/examples/ds/PutDataSerializables.java b/gemfire-core/src/test/java/com/examples/ds/PutDataSerializables.java
index 938665f..2a5e891 100644
--- a/gemfire-core/src/test/java/com/examples/ds/PutDataSerializables.java
+++ b/gemfire-core/src/test/java/com/examples/ds/PutDataSerializables.java
@@ -22,9 +22,9 @@ import java.util.Date;
 import java.util.Properties;
 
 /**
- * Places various objects that use {@link DataSerializer}s and {@link
- * Instantiator}s into a cache {@link Region}.  Among other things,
- * this is used to test bug 31573.
+ * Places various objects that use {@link com.gemstone.gemfire.DataSerializer}s 
+ * and {@link com.gemstone.gemfire.Instantiator}s into a cache {@link Region}.  
+ * Among other things, this is used to test bug 31573.
  *
  * @since 3.5
  * @author David Whitlock

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/GemFireTestCase.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/GemFireTestCase.java b/gemfire-core/src/test/java/com/gemstone/gemfire/GemFireTestCase.java
index f856d3f..8857992 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/GemFireTestCase.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/GemFireTestCase.java
@@ -82,7 +82,7 @@ public abstract class GemFireTestCase {
   /**
    * Assert an Invariant condition on an object.
    * @param inv the Invariant to assert. If null, this method just returns
-   * @param the obj to assert the Invariant on.
+   * @param obj the Object to assert the Invariant on.
    */
   protected void assertInvariant(Invariant inv, Object obj) {
     if (inv == null) return;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
index e8d4915..2d5f8fe 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/client/internal/AutoConnectionSourceDUnitTest.java
@@ -427,7 +427,7 @@ public class AutoConnectionSourceDUnitTest extends LocatorTestBase {
    * Assert that there is one endpoint with the given host in port
    * on the client vm.
    * @param vm - the vm the client is running in
-   * @param expectedPort - The server port we expect the client to be connected to.
+   * @param expectedPorts - The server ports we expect the client to be connected to.
    */
   protected void checkEndpoints(VM vm, final int[] expectedPorts) {
     vm.invoke(new SerializableRunnable("Check endpoint") {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MXMemoryPoolListenerExample.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MXMemoryPoolListenerExample.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MXMemoryPoolListenerExample.java
index e6863a2..eb9f4c7 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MXMemoryPoolListenerExample.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MXMemoryPoolListenerExample.java
@@ -151,10 +151,6 @@ public class MXMemoryPoolListenerExample implements NotificationListener {
     private final Cache cache;
     private final AtomicBoolean criticalState;
 
-    /**
-     * @param logWriter
-     * @param criticalState
-     */
     public MemoryHog(String n, Cache c, AtomicBoolean critical) {
       this.name = n;
       this.cache = c;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
index 9f84325..b9e213a 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsDUnitTest.java
@@ -1440,8 +1440,7 @@ public class MemoryThresholdsDUnitTest extends ClientServerTestCase {
    * Verifies that the test listener value on the given vm is what is expected
    * Note that for remote events useWaitCriterion must be true
    * @param vm the vm where verification should take place
-   * @param type the type of event to validate, use {@link MemoryEventType#UNKNOWN}
-   * to verify all events
+   * @param state
    * @param value the expected value
    * @param useWaitCriterion must be true for remote events
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
index afe551b..43b53a3 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/management/MemoryThresholdsOffHeapDUnitTest.java
@@ -1668,9 +1668,6 @@ public class MemoryThresholdsOffHeapDUnitTest extends ClientServerTestCase {
    * 
    * @param vm
    *          the vm where verification should take place
-   * @param type
-   *          the type of event to validate, use {@link MemoryEventType#UNKNOWN}
-   *          to verify all events
    * @param value
    *          the expected value
    * @param useWaitCriterion

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
index 5ce23a4..ce7c9fd 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/QueryTestUtils.java
@@ -1323,7 +1323,6 @@ public class QueryTestUtils implements Serializable {
    *  The VM on which the queries are to be executed
    * @param qarr
    *  Array of keys, queries in the values of which to be executed
-   * @return
    */
   public void executeQueries(VM vm, final String qarr[]) {
     vm.invoke(new CacheSerializableRunnable("Executing query") {
@@ -1441,7 +1440,6 @@ public class QueryTestUtils implements Serializable {
   /**
    * Execute all the queries in the map
    * @param vm
-   * @param qarr
    */
   public void executeAllQueries(VM vm) {
     vm.invoke(new CacheSerializableRunnable("Execute all queries") {
@@ -1453,8 +1451,6 @@ public class QueryTestUtils implements Serializable {
 
   /**
    * Execute all the queries in the map
-   * @param qarr
-   * @throws Exception 
    */
   public Object[] executeAllQueries() {
     qs = cache.getQueryService();
@@ -1483,9 +1479,6 @@ public class QueryTestUtils implements Serializable {
    *    </code></P>
    * @param vm
    *  The vm on which the query is to be executed   
-   * @param qarr
-   *  Array of keys, queries in the values of which to be executed
-   * @return
    */
   public void executeBindQuery(VM vm, final String queryId,
       final Object[] params) {
@@ -1502,9 +1495,6 @@ public class QueryTestUtils implements Serializable {
    *    String[] arr = {"1", "2", "3"};<br>
    *    new QueryTestUtils().executeBindQuery("1", arr);
    *    </code></P>
-   * @param qarr
-   *  Array of keys, queries in the values of which to be executed
-   * @return
    */
   
   public Object executeBindQuery(final String queryId, final Object[] params) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
index 27619c0..8384c18 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
@@ -854,9 +854,6 @@ public class QueryUsingFunctionContextDUnitTest extends CacheTestCase {
   /**
    * Run query on server using LocalDataSet.executeQuery() to compare results
    * received from client function execution.
-   * @param queries
-   * @param filter
-   * @return
    */
   public static ArrayList runQueryOnServerLocalDataSet(String query, Set filter) {
     return new QueryUsingFunctionContextDUnitTest("temp").runQueryOnServerLDS(query, filter);
@@ -883,9 +880,7 @@ public class QueryUsingFunctionContextDUnitTest extends CacheTestCase {
   }
 
   /**
-   * Run query on server to compare the results recieved from client function execution.
-   * @param queries
-   * @return ArrayList of results
+   * Run query on server to compare the results received from client function execution.
    */
   public static ArrayList runQueryOnServerRegion(String query) {
     return new QueryUsingFunctionContextDUnitTest("temp").runQueryOnServerReg(query);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CountStarJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CountStarJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CountStarJUnitTest.java
index 60aeef3..922c5a4 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CountStarJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/CountStarJUnitTest.java
@@ -59,9 +59,6 @@ public class CountStarJUnitTest {
   private static String exampleRegionName = "employee";
   private int numElem = 100;
   
-  /**
-   * @param name
-   */
   public CountStarJUnitTest() {
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
index 76595ff..4a351aa 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/functional/DistinctResultsWithDupValuesInRegionJUnitTest.java
@@ -53,9 +53,6 @@ public class DistinctResultsWithDupValuesInRegionJUnitTest {
   private static String regionName = "test";
   private int numElem = 100;
 
-  /**
-   * @param name
-   */
   public DistinctResultsWithDupValuesInRegionJUnitTest() {
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
index 6a546b1..620caa3 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryCacheClosedJUnitTest.java
@@ -70,12 +70,6 @@ public class PRQueryCacheClosedJUnitTest
   static final int delayQuery = 1000;
 
 
-  /**
-   * setUp*
-   * 
-   * @param name
-   */
-
   @Before
   public void setUp() throws Exception
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
index 333cb07..04dd49b 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryDUnitHelper.java
@@ -114,11 +114,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
   /**
    * This function creates a appropriate region (Local or PR ) given the scope &
    * the isPR parameters *
-   * 
-   * @param regionName
-   * @param isPR
-   * 
-   * @return cacheSerializable object
    */
   public CacheSerializableRunnable getCacheSerializableRunnableForLocalRegionCreation(
       final String regionName) {
@@ -631,11 +626,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
    * 1. Creates & executes a query with Logical Operators on the given PR Region
    * 2. Executes the same query on the local region <br>
    * 3. Compares the appropriate resultSet <br>
-   * 
-   * @param regionName
-   * @param localRegionNeme
-   * 
-   * @return cacheSerializable object
    */
 
   public CacheSerializableRunnable getCacheSerializableRunnableForPRQueryAndCompareResults(
@@ -1399,11 +1389,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
    * 1. Creates & executes a query with Constants on the given PR Region <br>
    * 2. Executes the same query on the local region <br>
    * 3. Compares the appropriate resultSet <br>
-   * 
-   * @param regionName
-   * @param localRegionNeme
-   * 
-   * @return cacheSerializable object
    */
 
   public CacheSerializableRunnable getCacheSerializableRunnableForPRQueryWithConstantsAndComparingResults(
@@ -1855,10 +1840,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
    * This function <br>
    * 1. The Creates an array of PortfolioData objects
    * 
-   * @param count ,
-   *          CountDestisnation
-   * 
-   * 
    * @return PortFolioData Objects
    */
 
@@ -1935,11 +1916,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
    * 2. Executes the same query on the local region <br>
    * 3. Compares the appropriate resultSet <br>
    * 4. Compares and Print's the time taken for each <br>
-   * 
-   * @param regionName
-   * @param localRegionNeme
-   * 
-   * @return cacheSerializable object
    */
 
   public CacheSerializableRunnable PRQueryingVsLocalQuerying(
@@ -2065,11 +2041,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
     /**
    * This function creates a appropriate index on a  PR given the name and 
    * other parameters.
-   * 
-   * @param regionName
-   * @param indexName
-   * 
-   * @return cacheSerializable object
    */
   public CacheSerializableRunnable getCacheSerializableRunnableForPRIndexCreate(
       final String prRegionName, final String indexName,
@@ -2134,11 +2105,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
  /**
   * This function defines a appropriate index on a  PR given the name and 
   * other parameters.
-  * 
-  * @param regionName
-  * @param indexName
-  * 
-  * @return cacheSerializable object
   */
   public CacheSerializableRunnable getCacheSerializableRunnableForDefineIndex(
       final String prRegionName, final ArrayList<String> indexName,
@@ -2395,10 +2361,6 @@ public class PRQueryDUnitHelper extends PartitionedRegionDUnitTestCase
   /**
    * This function creates a duplicate index should throw an IndexNameConflictException
    * and if not the test should fail.
-   * 
-   * @param regionName
-   * @param IndexName
-   * 
    */
   public CacheSerializableRunnable getCacheSerializableRunnableForDuplicatePRIndexCreate(
       final String prRegionName, final String indexName,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionClosedJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionClosedJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionClosedJUnitTest.java
index 6b76b04..0a804af 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionClosedJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionClosedJUnitTest.java
@@ -61,12 +61,6 @@ public class PRQueryRegionClosedJUnitTest
 
   
 
-  /**
-   * setUp*
-   * 
-   * @param name
-   */
-
   @Before
   public void setUp() throws Exception
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
index 95d846e..4b9ae3d 100755
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/partitioned/PRQueryRegionDestroyedJUnitTest.java
@@ -63,11 +63,6 @@ public class PRQueryRegionDestroyedJUnitTest
   boolean encounteredException = false;
   static final int dataSize =100; 
   static final int delayQuery = 1000;
-  /**
-   * setUp*
-   * 
-   * @param name
-   */
 
   @Before
   public void setUp() throws Exception

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
index f4d1a10..162ffb1 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache/query/transaction/QueryAndJtaJUnitTest.java
@@ -277,7 +277,6 @@ public class QueryAndJtaJUnitTest {
   /**
    * verify that queries on indexes work with transaction
    * 
-   * @see bug#40842
    * @throws Exception
    */
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/172135e2/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLogRollDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLogRollDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLogRollDUnitTest.java
index 3d06eab..2689096 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLogRollDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/cache30/CacheLogRollDUnitTest.java
@@ -43,13 +43,6 @@ public class CacheLogRollDUnitTest extends CacheTestCase {
 
   //////////////////////  Test Methods  //////////////////////
 
-  /**
-   * @param baseLogName
-   * @param logfile
-   * @param ds
-   * @throws FileNotFoundException
-   * @throws IOException
-   */
   private void logAndRollAndVerify(String baseLogName,
       DistributedSystem ds,String mainId) throws FileNotFoundException, IOException {
     String logfile = baseLogName+".log";
@@ -124,15 +117,6 @@ public class CacheLogRollDUnitTest extends CacheTestCase {
     }
   }
 
-  /**
-   * @param baseLogName
-   * @param logfile
-   * @param ds
-   * @throws FileNotFoundException
-   * @throws IOException
-   * 
-   * @author xzhou
-   */
   private void SecurityLogAndRollAndVerify(String baseLogName,
       DistributedSystem ds,String mainId) throws FileNotFoundException, IOException {
     String logfile = baseLogName+".log";