You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ja...@apache.org on 2016/05/31 17:11:02 UTC

[17/29] incubator-geode git commit: GEODE-1316: Changing @since tags to @GemFire or @Geode

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ClientSubscriptionConfigImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ClientSubscriptionConfigImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ClientSubscriptionConfigImpl.java
index a44677a..a4a8882 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ClientSubscriptionConfigImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ClientSubscriptionConfigImpl.java
@@ -58,7 +58,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
    * will be in MB for eviction-policy mem else
    * number of entries
    * @see #DEFAULT_CAPACITY
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public int getCapacity(){
     return this.haQueueCapacity ;
@@ -68,7 +68,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
    * will be in MB for eviction-policy mem else
    * number of entries
    * @see #DEFAULT_CAPACITY
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public void setCapacity(int capacity){
     this.haQueueCapacity = capacity;
@@ -76,7 +76,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
   /**
    * Returns the eviction policy that is executed when capacity of the client client queue is reached.
    * @see #DEFAULT_EVICTION_POLICY
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public String getEvictionPolicy(){
     return this.haEvictionPolicy ;
@@ -84,7 +84,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
   /**
    * Sets the eviction policy that is executed when capacity of the client client queue is reached.
    * @see #DEFAULT_EVICTION_POLICY
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public void setEvictionPolicy(String policy){
     this.haEvictionPolicy = policy;
@@ -93,7 +93,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
   /**
    * Sets the overflow directory for a client client queue 
    * @param overflowDirectory the overflow directory for a client queue's overflowed entries
-   * @since 5.7
+   * @since GemFire 5.7
    * @deprecated as of prPersistSprint2 
    */
   @Deprecated
@@ -111,7 +111,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
    * overflowed client queue entries.
    * @return the overflow directory for a client queue's
    * overflowed entries
-   * @since 5.7
+   * @since GemFire 5.7
    * @deprecated as of prPersistSprint2 
    */
   @Deprecated
@@ -137,7 +137,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
   }
   /**
    * get the diskStoreName for overflow
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public String getDiskStoreName() {
     return diskStoreName;
@@ -145,7 +145,7 @@ public class ClientSubscriptionConfigImpl implements ClientSubscriptionConfig {
   /**
    * Sets the disk store name for overflow  
    * @param diskStoreName 
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public void setDiskStoreName(String diskStoreName) {
     if (hasOverflowDirectory()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
index 72edc10..7e97f4d 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ColocationHelper.java
@@ -51,7 +51,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
  * various scenarios
  * 
  * 
- * @since 6.0
+ * @since GemFire 6.0
  */
 public class ColocationHelper {
 
@@ -63,7 +63,7 @@ public class ColocationHelper {
     *
     * @param partitionedRegion
     * @return colocated PartitionedRegion
-    * @since cheetah
+    * @since GemFire cheetah
     */
   public static PartitionedRegion getColocatedRegionName(
       final PartitionedRegion partitionedRegion) {
@@ -124,7 +124,7 @@ public class ColocationHelper {
    * 
    * @param partitionedRegion
    * @return colocated PartitionedRegion
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public static PartitionedRegion getColocatedRegion(
       final PartitionedRegion partitionedRegion) {
@@ -339,7 +339,7 @@ public class ColocationHelper {
    * @param partitionedRegion
    * @return List of all partitioned regions (excluding self) in a colocated
    *         chain
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public static Map<String, PartitionedRegion> getAllColocationRegions(
       PartitionedRegion partitionedRegion) {
@@ -375,7 +375,7 @@ public class ColocationHelper {
    * 
    * @param partitionedRegion
    * @return map of region name to local colocated regions
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public static Map<String, Region> getAllColocatedLocalDataSets(
       PartitionedRegion partitionedRegion, InternalRegionFunctionContext context) {
@@ -432,7 +432,7 @@ public class ColocationHelper {
    * 
    * @param partitionedRegion
    * @return list of all child partitioned regions colocated with the region
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public static List<PartitionedRegion> getColocatedChildRegions(
       PartitionedRegion partitionedRegion) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CommitReplyException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CommitReplyException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CommitReplyException.java
index 8cf9665..bf3e341 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CommitReplyException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CommitReplyException.java
@@ -22,7 +22,7 @@ import java.util.*;
 /**
  * Contains exceptions generated when attempting to process a commit operation.
  *
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class CommitReplyException extends ReplyException {
 private static final long serialVersionUID = -7711083075296622596L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CompactableOplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CompactableOplog.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CompactableOplog.java
index 697214d..8691ec9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CompactableOplog.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CompactableOplog.java
@@ -24,7 +24,7 @@ import com.gemstone.gemfire.internal.cache.persistence.DiskRegionView;
  * they can be compacted.
  * 
  * 
- * @since 6.5
+ * @since GemFire 6.5
  */
 
 public interface CompactableOplog {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Conflatable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Conflatable.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Conflatable.java
index 7178bc7..cb5cb0d 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Conflatable.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Conflatable.java
@@ -25,7 +25,7 @@ import java.io.Serializable;
  * client.
  * 
  * 
- * @since 4.2
+ * @since GemFire 4.2
  */
 public interface Conflatable extends Serializable
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ControllerAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ControllerAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ControllerAdvisor.java
index ccc14eb..fb826f4 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ControllerAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ControllerAdvisor.java
@@ -112,7 +112,7 @@ public class ControllerAdvisor extends GridAdvisor {
      * controller. The reply needs to contain any controller(s) that exist in
      * this vm and any bridge servers that exist in this vm.
      * 
-     * @since 5.7
+     * @since GemFire 5.7
      */
     @Override
     public void processIncoming(DistributionManager dm, String adviseePath,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CountingDataInputStream.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CountingDataInputStream.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CountingDataInputStream.java
index 36fc752..ce0273d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CountingDataInputStream.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CountingDataInputStream.java
@@ -22,7 +22,7 @@ import java.io.*;
  * A data input stream that counts the bytes it plans on reading.
  * 
  * 
- * @since prPersistSprint2
+ * @since GemFire prPersistSprint2
  */
 
 public class CountingDataInputStream implements DataInput {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CustomEntryExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CustomEntryExpiryTask.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CustomEntryExpiryTask.java
index d7382bd..2c380f2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CustomEntryExpiryTask.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/CustomEntryExpiryTask.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.cache.ExpirationAttributes;
  * Remembers the expiration attributes returned from
  * the customer's CustomExpiry callback, if any.
  * 
- * @since 8.0
+ * @since GemFire 8.0
  *
  */
 public class CustomEntryExpiryTask extends EntryExpiryTask {  

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyPartitionedRegionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyPartitionedRegionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyPartitionedRegionMessage.java
index 9715992..4539526 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyPartitionedRegionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DestroyPartitionedRegionMessage.java
@@ -58,7 +58,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * A standard {@link ReplyMessage} is used to send the reply, however any exception that it carries
  * is ignored, preventing interuption after sending this message.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public final class DestroyPartitionedRegionMessage extends PartitionMessage
 {
@@ -225,7 +225,7 @@ public final class DestroyPartitionedRegionMessage extends PartitionMessage
   /**
    * The response on which to wait for all the replies.  This response ignores any exceptions received from the "far side"
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   static public class DestroyPartitionedRegionResponse extends ReplyProcessor21
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DirectoryHolder.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DirectoryHolder.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DirectoryHolder.java
index dfdf984..d3ad07e 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DirectoryHolder.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DirectoryHolder.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.StatisticsFactory;
  * A holder for a disk Directory. Used for maintaining the available space and
  * updating disk statistics
  * 
- * @since 5.1
+ * @since GemFire 5.1
  * 
  */
 public class DirectoryHolder

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskDirectoryStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskDirectoryStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskDirectoryStats.java
index 5aeec38..21a7b26 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskDirectoryStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskDirectoryStats.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.internal.*;
  * GemFire statistics about Disk Directories
  *
  *
- * @since 3.2
+ * @since GemFire 3.2
  */
 public class DiskDirectoryStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
index 54ecb04..e015460 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskEntry.java
@@ -69,7 +69,7 @@ import com.gemstone.gemfire.internal.util.BlobHelper;
  * @see DiskRegion
  *
  *
- * @since 3.2
+ * @since GemFire 3.2
  */
 public interface DiskEntry extends RegionEntry {
   /**
@@ -138,7 +138,7 @@ public interface DiskEntry extends RegionEntry {
      * Testing purpose only
      * Get the value of an entry that is on disk without faulting
      * it in and without looking in the io buffer.
-     * @since 3.2.1
+     * @since GemFire 3.2.1
      */
     static Object getValueOnDisk(DiskEntry entry, DiskRegion dr) {
       DiskId id = entry.getDiskId();
@@ -168,7 +168,7 @@ public interface DiskEntry extends RegionEntry {
      * @param entry the entry used to identify the value to fetch
      * @param dr the persistent storage from which to fetch the value
      * @return either null, byte array, or CacheDeserializable
-     * @since gemfire57_hotfix
+     * @since GemFire 57_hotfix
      */
     public static Object getSerializedValueOnDisk(
         DiskEntry entry, DiskRegion dr) {
@@ -199,7 +199,7 @@ public interface DiskEntry extends RegionEntry {
      * This method is used for concurrent map operations and CQ processing
      * 
      * @throws DiskAccessException
-     * @since 5.1
+     * @since GemFire 5.1
      */
     static Object getValueOnDiskOrBuffer(DiskEntry entry, DiskRegion dr, RegionEntryContext context) {
       @Released Object v = getOffHeapValueOnDiskOrBuffer(entry, dr, context);
@@ -252,7 +252,7 @@ public interface DiskEntry extends RegionEntry {
      * Returns false if the entry is INVALID (or LOCAL_INVALID). Determines this
      * without faulting in the value from disk.
      * 
-     * @since 3.2.1
+     * @since GemFire 3.2.1
      */
     /* TODO prpersist - Do we need this method? It was added by the sqlf merge
     static boolean isValid(DiskEntry entry, DiskRegion dr) {
@@ -309,7 +309,7 @@ public interface DiskEntry extends RegionEntry {
     /**
      * Get the value of an entry that is on disk without faulting
      * it in.
-     * @since 3.2.1
+     * @since GemFire 3.2.1
      */
     static boolean fillInValue(DiskEntry de, InitialImageOperation.Entry entry,
                                DiskRegion dr, DM mgr, ByteArrayDataInput in, RegionEntryContext context) {
@@ -1700,7 +1700,7 @@ public interface DiskEntry extends RegionEntry {
     /**
      * Flush an entry that was previously scheduled to be written to disk.
      * @param tag 
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     public static void doAsyncFlush(DiskEntry entry, LocalRegion region, VersionTag tag) {
       if (region.isThisRegionBeingClosedOrDestroyed()) return;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskId.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskId.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskId.java
index dd916af..3da3879 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskId.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskId.java
@@ -30,7 +30,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
  * <li>Userbits of the value
  * </ul>
  * 
- * @since 5.1
+ * @since GemFire 5.1
  */
 
 public abstract class DiskId
@@ -184,13 +184,13 @@ public abstract class DiskId
   /**
    * Return true if entry is schedule to be async written to disk.
    * Return false if it has already been written or was never modified.
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public boolean isPendingAsync() {
     return EntryBits.isPendingAsync(getUserBits());
   }
   /**
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public synchronized void setPendingAsync(boolean v) {
     byte origBits = getUserBits();
@@ -460,12 +460,12 @@ public abstract class DiskId
   {
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry prev;
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry next;
 
@@ -528,12 +528,12 @@ public abstract class DiskId
   {
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry prev;
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry next;
 
@@ -611,12 +611,12 @@ public abstract class DiskId
   {
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry prev;
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry next;
 
@@ -695,12 +695,12 @@ public abstract class DiskId
   {
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry prev;
     /**
      * Used by DiskRegion for compaction
-     * @since prPersistSprint1
+     * @since GemFire prPersistSprint1
      */
     private DiskEntry next;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
index 7e2333e..018a065 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskInitFile.java
@@ -87,7 +87,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * Does all the IF file work for a DiskStoreImpl.
  *
  *
- * @since prPersistSprint1
+ * @since GemFire prPersistSprint1
  */
 public class DiskInitFile implements DiskInitFileInterpreter {
   private static final Logger logger = LogService.getLogger();
@@ -135,7 +135,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: blobLength
    *   blobLength: member bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_ONLINE_MEMBER_ID = 59;
   /**
@@ -146,7 +146,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: blobLength
    *   blobLength: member bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_OFFLINE_MEMBER_ID = 60;
   /**
@@ -157,7 +157,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: blobLength
    *   blobLength: member bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_RM_MEMBER_ID = 61;
   /**
@@ -168,7 +168,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: blobLength
    *   blobLength: member bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_MY_MEMBER_INITIALIZING_ID = 62;
   /**
@@ -177,7 +177,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    *   RegionId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_MY_MEMBER_INITIALIZED_ID = 63;
 
@@ -189,7 +189,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: nameLength
    *   nameLength: name bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_CREATE_REGION_ID = 64;
   /**
@@ -198,7 +198,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    *   RegionId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_BEGIN_DESTROY_REGION_ID = 65;
   /**
@@ -208,7 +208,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   RegionId
    *   8: oplogEntryId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_CLEAR_REGION_ID = 66;
   /**
@@ -217,7 +217,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    *   RegionId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_END_DESTROY_REGION_ID = 67;
   /**
@@ -226,7 +226,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    *   RegionId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_BEGIN_PARTIAL_DESTROY_REGION_ID = 68;
   /**
@@ -235,7 +235,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    *   RegionId
    *   1: EndOfRecordMarker
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public static final byte IFREC_END_PARTIAL_DESTROY_REGION_ID = 69;
 
@@ -291,7 +291,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   4: blobLength
    *   blobLength: member bytes
    *   1: EndOfRecordMarker
-   * @since prPersistSprint3
+   * @since GemFire prPersistSprint3
    */
   public static final byte IFREC_OFFLINE_AND_EQUAL_MEMBER_ID = 75;
   /**
@@ -363,7 +363,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Used to say that a disk store has been revoked
    * Byte Format:
    *   variable: a PersistentMemberPattern
-   * @since 7.0
+   * @since GemFire 7.0
    */
   public static final byte IFREC_REVOKE_DISK_STORE_ID = 81;
   
@@ -372,7 +372,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Byte Format:
    * 1: version byte from Version.GFE_CURRENT.ordinal
    * 1: EndOfRecord
-   * @since 7.0
+   * @since GemFire 7.0
    */
   public static final byte IFREC_GEMFIRE_VERSION = 82;
 
@@ -383,7 +383,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    *   RegionId
    *   variable: serialized RVV
    *   1: EndOfRecordMarker
-   * @since 7.0
+   * @since GemFire 7.0
    */
   public static final byte IFREC_CLEAR_REGION_WITH_RVV_ID = 83;
   
@@ -414,7 +414,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * number
    * Followed by EndOfRecord
    * Fix for bug 43824
-   * @since 8.0
+   * @since GemFire 8.0
    */
   public static final byte OPLOG_MAGIC_SEQ_ID = 89;
   
@@ -435,7 +435,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * 1: versioned (boolean)
    * 1: offHeap (boolean) added in 9.0
    * 1: EndOfRecordMarker
-   * @since 9.0
+   * @since Geode 1.0
    */
   public static final byte IFREC_REGION_CONFIG_ID_90 = 90;
 
@@ -2438,7 +2438,7 @@ public class DiskInitFile implements DiskInitFileInterpreter {
    * Currently only few for GemFireXD added here but all other boolean flags also
    * be better moved here.
    * 
-   * @since 7.0
+   * @since GemFire 7.0
    */
   public enum DiskRegionFlag {
     /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
index c1d2f03..a2092fd 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegion.java
@@ -42,7 +42,7 @@ import joptsimple.internal.Strings;
  * Used for both persistent recoverable regions and overflow-only regions.
  *
  *
- * @since 3.2
+ * @since GemFire 3.2
  */
 public class DiskRegion extends AbstractDiskRegion {
 
@@ -404,7 +404,7 @@ public class DiskRegion extends AbstractDiskRegion {
   }
 
   /**
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    */
   final BytesAndBits getBytesAndBits(DiskId id) {
     return getBytesAndBits(id, true);
@@ -415,7 +415,7 @@ public class DiskRegion extends AbstractDiskRegion {
   }
 
   /**
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    */
   final byte getBits(DiskId id) {
     return getDiskStore().getBits(this, id);
@@ -470,20 +470,20 @@ public class DiskRegion extends AbstractDiskRegion {
   /**
    * Get serialized form of data off the disk
    * @param id
-   * @since gemfire5.7_hotfix
+   * @since GemFire 5.7
    */
   public Object getSerializedData(DiskId id) {
     return getDiskStore().getSerializedData(this, id);
   }
 
   /**
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public void scheduleAsyncWrite(AsyncDiskEntry ade) {
     getDiskStore().scheduleAsyncWrite(ade);
   }
   /**
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public void unscheduleAsyncWrite(DiskId did) {
     getDiskStore().unscheduleAsyncWrite(did);
@@ -544,7 +544,7 @@ public class DiskRegion extends AbstractDiskRegion {
   /**
    * Returns true if the state of the specified entry was recovered from disk.
    * If so it will also set it to no longer be recovered.
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public boolean testIsRecoveredAndClear(RegionEntry re) {
     DiskEntry de = (DiskEntry)re;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegionStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegionStats.java
index 75cdf21..ae9b0a9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegionStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskRegionStats.java
@@ -27,7 +27,7 @@ import com.gemstone.gemfire.internal.StatisticsTypeFactoryImpl;
  * GemFire statistics about a {@link DiskRegion}.
  *
  *
- * @since 3.2
+ * @since GemFire 3.2
  */
 public class DiskRegionStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreAttributes.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreAttributes.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreAttributes.java
index a391a0c..451a907 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreAttributes.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreAttributes.java
@@ -29,7 +29,7 @@ import com.gemstone.gemfire.cache.DiskStoreFactory;
 /**
  * Creates an attribute object for DiskStore.
  * </p>
- * @since prPersistSprint2
+ * @since GemFire prPersistSprint2
  */
 public class DiskStoreAttributes implements Serializable, DiskStore {
   private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreFactoryImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreFactoryImpl.java
index 3e3add8..1c57db9 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreFactoryImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreFactoryImpl.java
@@ -37,7 +37,7 @@ import com.gemstone.gemfire.pdx.internal.TypeRegistry;
 /**
  * Implementation of DiskStoreFactory 
  * 
- * @since prPersistSprint2
+ * @since GemFire prPersistSprint2
  */
 public class DiskStoreFactoryImpl implements DiskStoreFactory
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreImpl.java
index e9cf6bf..3219bb4 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreImpl.java
@@ -122,7 +122,7 @@ import com.gemstone.gemfire.i18n.StringId;
  * persistent recoverable regions and overflow-only regions.
  * 
  * 
- * @since 3.2
+ * @since GemFire 3.2
  */
 @SuppressWarnings("synthetic-access")
 public class DiskStoreImpl implements DiskStore {
@@ -992,7 +992,7 @@ public class DiskStoreImpl implements DiskStore {
   }
 
   /**
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    */
   final byte getBits(DiskRegion dr, DiskId id) {
     acquireReadLock(dr);
@@ -1151,7 +1151,7 @@ public class DiskStoreImpl implements DiskStore {
    * Note that this is no longer implemented by getting a write lock but instead
    * locks the same lock that acquireReadLock does.
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   private void acquireWriteLock(DiskRegion dr) {
     // @todo darrel: this is no longer a write lock need to change method name
@@ -1163,7 +1163,7 @@ public class DiskStoreImpl implements DiskStore {
    * This function is having a default visiblity as it is used in the
    * OplogJUnitTest for a bug verification of Bug # 35012
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
 
   private void releaseWriteLock(DiskRegion dr) {
@@ -1176,7 +1176,7 @@ public class DiskStoreImpl implements DiskStore {
    * finally block. Note that this is no longer implemented by getting a read
    * lock but instead locks the same lock that acquireWriteLock does.
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   void acquireReadLock(DiskRegion dr) {
     dr.basicAcquireReadLock();
@@ -1191,7 +1191,7 @@ public class DiskStoreImpl implements DiskStore {
   }
 
   /**
-   * @since 5.1
+   * @since GemFire 5.1
    */
 
   void releaseReadLock(DiskRegion dr) {
@@ -1212,7 +1212,7 @@ public class DiskStoreImpl implements DiskStore {
   }
 
   /**
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public void forceRolling(DiskRegion dr) {
     if (!dr.isBackup())
@@ -1248,7 +1248,7 @@ public class DiskStoreImpl implements DiskStore {
    * Get serialized form of data off the disk
    * 
    * @param id
-   * @since gemfire5.7_hotfix
+   * @since GemFire 5.7
    */
   public Object getSerializedData(DiskRegion dr, DiskId id) {
     return convertBytesAndBitsToSerializedForm(getBytesAndBits(dr, id, true));
@@ -1367,7 +1367,7 @@ public class DiskStoreImpl implements DiskStore {
   }
 
   /**
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public void scheduleAsyncWrite(AsyncDiskEntry ade) {
     DiskRegion dr = ade.region.getDiskRegion();
@@ -1388,7 +1388,7 @@ public class DiskStoreImpl implements DiskStore {
   }
 
   /**
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   public void unscheduleAsyncWrite(DiskId did) {
     if (did != null) {
@@ -2869,7 +2869,7 @@ public class DiskStoreImpl implements DiskStore {
   /**
    * Compacts oplogs
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    * 
    */
   class OplogCompactor implements Runnable {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreStats.java
index 2f7ec72..db505b9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskStoreStats.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.distributed.internal.DistributionStats;
  * GemFire statistics about a {@link DiskStoreImpl}.
  *
  *
- * @since prPersistSprint2
+ * @since GemFire prPersistSprint2
  */
 public class DiskStoreStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
index 914c878..3ff0333 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DiskWriteAttributesImpl.java
@@ -37,7 +37,7 @@ import java.util.Properties;
  * @see Region#writeToDisk
  * 
  * 
- * @since 5.1
+ * @since GemFire 5.1
  */
 @SuppressWarnings({"deprecation", "unused"})
 public final class DiskWriteAttributesImpl implements DiskWriteAttributes
@@ -100,7 +100,7 @@ public final class DiskWriteAttributesImpl implements DiskWriteAttributes
   /**
    * Default disk directory size in megabytes
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public static final int DEFAULT_DISK_DIR_SIZE = DiskStoreFactory.DEFAULT_DISK_DIR_SIZE;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
index 6a7b4f2..6b1073b 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedCacheOperation.java
@@ -96,21 +96,21 @@ public abstract class DistributedCacheOperation {
    * Deserialization policy: do not deserialize (for byte array, null or cases
    * where the value should stay serialized)
    * 
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static final byte DESERIALIZATION_POLICY_NONE = (byte)0;
 
   /**
    * Deserialization policy: deserialize eagerly (for Deltas)
    * 
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static final byte DESERIALIZATION_POLICY_EAGER = (byte)1;
 
   /**
    * Deserialization policy: deserialize lazily (for all other objects)
    * 
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static final byte DESERIALIZATION_POLICY_LAZY = (byte)2;
   
@@ -199,7 +199,7 @@ public abstract class DistributedCacheOperation {
    * false if not. Currently the only case it doesn't need to be is a
    * DestroyRegionOperation doing a "local" destroy.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   boolean isOperationReliable() {
     Operation op = this.event.getOperation();
@@ -957,7 +957,7 @@ public abstract class DistributedCacheOperation {
      * Add the cache event's old value to this message.  We must propagate
      * the old value when the receiver is doing GII and has listeners (CQs)
      * that require the old value.
-     * @since 5.5
+     * @since GemFire 5.5
      * @param event the entry event that contains the old value
      */
     public void appendOldValueToMessage(EntryEventImpl event) {
@@ -979,7 +979,7 @@ public abstract class DistributedCacheOperation {
      * Insert this message's oldValue into the given event.  This fixes
      * bug 38382 by propagating old values with Entry level
      * CacheOperationMessages during initial image transfer
-     * @since 5.5
+     * @since GemFire 5.5
      */
     public void setOldValueInEvent(EntryEventImpl event) {
       CqService cqService = event.getRegion().getCache().getCqService();
@@ -1000,7 +1000,7 @@ public abstract class DistributedCacheOperation {
      * Sets a flag in the message indicating that this message contains delta
      * bytes.
      * 
-     * @since 6.1
+     * @since GemFire 6.1
      */
     protected void setHasDelta(boolean flag) {
       this.hasDelta = flag;
@@ -1015,7 +1015,7 @@ public abstract class DistributedCacheOperation {
     }
 
     /**
-     * @since 4.2.3
+     * @since GemFire 4.2.3
      */
     protected transient boolean regionAllowsConflation;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
index b6aa1b6..5d71ef2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedPutAllOperation.java
@@ -68,7 +68,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
 /**
  * Handles distribution of a Region.putall operation.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class DistributedPutAllOperation extends AbstractUpdateOperation
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
index cc86e2c..937216f 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRegion.java
@@ -162,7 +162,7 @@ public class DistributedRegion extends LocalRegion implements
   /**
    * Provides a queue for reliable message delivery
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected final ReliableMessageQueue rmq;
 
@@ -684,7 +684,7 @@ public class DistributedRegion extends LocalRegion implements
    * @throws RoleException
    *           if a required role is missing and the LossAction is either
    *           NO_ACCESS or LIMITED_ACCESS.
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected boolean isNoDistributionOk()
   {
@@ -703,7 +703,7 @@ public class DistributedRegion extends LocalRegion implements
   /**
    * returns true if this Region does not distribute its operations to other
    * members.
-   * @since 6.0
+   * @since GemFire 6.0
    * @see HARegion#localDestroyNoCallbacks(Object)
    */
   public boolean doesNotDistribute() {
@@ -727,7 +727,7 @@ public class DistributedRegion extends LocalRegion implements
    *          removed from this set.
    * @return the set, possibly null, of recipients that are currently having
    *         their data queued.
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected Set adjustForQueuing(Set recipients)
   {
@@ -767,7 +767,7 @@ public class DistributedRegion extends LocalRegion implements
    * @param b
    *          a non-null non-empty set
    * @return true if sets a and b intersect; false if not
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public static boolean intersects(Set a, Set b)
   {
@@ -1891,7 +1891,7 @@ public class DistributedRegion extends LocalRegion implements
   /**
    * Distribute the invalidate of a region given its event.
    * This implementation sends the invalidate to peers.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void distributeInvalidateRegion(RegionEventImpl event) {
     new InvalidateRegionOperation(event).distribute();
@@ -3584,7 +3584,7 @@ public class DistributedRegion extends LocalRegion implements
   /**
    * Distribute the PutAllOp.
    * This implementation distributes it to peers.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   @Override
   public void postPutAllSend(DistributedPutAllOperation putAllOp, VersionedObjectList successfulPuts) {
@@ -3764,7 +3764,7 @@ public class DistributedRegion extends LocalRegion implements
    * Used to get membership events from our advisor to implement
    * RegionMembershipListener invocations.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected class AdvisorListener implements MembershipListener
   {
@@ -3983,7 +3983,7 @@ public class DistributedRegion extends LocalRegion implements
    * 
    * @param function
    * @param args
-   * @since 5.8
+   * @since GemFire 5.8
    */  
   @Override
   public ResultCollector executeFunction(

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
index 1d216ce..eabefdf 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation.java
@@ -62,7 +62,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
 /**
  * Handles distribution of a Region.removeAll operation.
  * 
- * @since 8.1
+ * @since GemFire 8.1
  */
 public class DistributedRemoveAllOperation extends AbstractUpdateOperation // TODO extend DistributedCacheOperation instead
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DummyCachePerfStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DummyCachePerfStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DummyCachePerfStats.java
index 70ec158..8c0eabf 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DummyCachePerfStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DummyCachePerfStats.java
@@ -20,7 +20,7 @@ import com.gemstone.gemfire.Statistics;
 import com.gemstone.gemfire.distributed.internal.PoolStatHelper;
 
 /**
- * @since 5.7
+ * @since GemFire 5.7
  */
 public class DummyCachePerfStats extends CachePerfStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DynamicRegionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DynamicRegionFactoryImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DynamicRegionFactoryImpl.java
index 2064d24..09afc91 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DynamicRegionFactoryImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/DynamicRegionFactoryImpl.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.cache.DynamicRegionFactory;
 /** This class provides non-published methods that allow the cache
     to initialize and close the factory.
 
-    @since 4.3
+    @since GemFire 4.3
  */
 public class DynamicRegionFactoryImpl extends DynamicRegionFactory {
   /** create an instance of the factory.  This is normally only done

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntriesMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntriesMap.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntriesMap.java
index 257458f..3db1320 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntriesMap.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntriesMap.java
@@ -106,7 +106,7 @@ public interface EntriesMap extends ConcurrentMap {
    * @see InitialImageOperation.RequestImageMessage#chunkEntries
    *
    * @return false if map entry not found
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    */
   public boolean fillInValue(InitialImageOperation.Entry entry, DM mgr);       
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
index 68c8117..16b4016 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryEventImpl.java
@@ -134,21 +134,21 @@ public class EntryEventImpl
   /**
    * This field will be null unless this event is used for a putAll operation.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected transient DistributedPutAllOperation putAllOp;
 
   /**
    * This field will be null unless this event is used for a removeAll operation.
    *
-   * @since 8.1
+   * @since GemFire 8.1
    */
   protected transient DistributedRemoveAllOperation removeAllOp;
 
   /**
    * The member that originated this event
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected DistributedMember distributedMember;
 
@@ -164,7 +164,7 @@ public class EntryEventImpl
   /**
    * The originating membershipId of this event.
    *
-   * @since 5.1
+   * @since GemFire 5.1
    */
   protected ClientProxyMembershipID context = null;
   
@@ -443,7 +443,7 @@ public class EntryEventImpl
    * Creates a PutAllEvent given the distributed operation, the region, and the
    * entry data.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   @Retained
   static EntryEventImpl createPutAllEvent(
@@ -1192,7 +1192,7 @@ public class EntryEventImpl
    * Returns the value of the EntryEventImpl field.
    * This is for internal use only. Customers should always call
    * {@link #getCallbackArgument}
-   * @since 5.5 
+   * @since GemFire 5.5
    */
   public Object getRawCallbackArgument() {
     return this.keyInfo.getCallbackArg();
@@ -1518,7 +1518,7 @@ public class EntryEventImpl
 
   /**
    * Forces this entry's new value to be in serialized form.
-   * @since 5.0.2
+   * @since GemFire 5.0.2
    */
   public void makeSerializedNewValue() {
     makeSerializedNewValue(false);
@@ -1687,7 +1687,7 @@ public class EntryEventImpl
   /**
    * If we are currently a create op then turn us into an update
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   void makeUpdate()
   {
@@ -1697,7 +1697,7 @@ public class EntryEventImpl
   /**
    * If we are currently an update op then turn us into a create
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   void makeCreate()
   {
@@ -2580,7 +2580,7 @@ public class EntryEventImpl
   
   /**
    * Return true if this event came from a server by the client doing a get.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public boolean isFromServer() {
     return testEventFlag(EventFlags.FLAG_FROM_SERVER);
@@ -2590,7 +2590,7 @@ public class EntryEventImpl
    * comes from a server while the affected region entry is not locked.  Among
    * other things it causes version conflict checks to be performed to protect
    * against overwriting a newer version of the entry.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public void setFromServer(boolean v) {
     setEventFlag(EventFlags.FLAG_FROM_SERVER, v);

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
index d539366..16215ac 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntryOperationImpl.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.cache.Region;
  * Gemfire Context passed to <code>PartitionResolver</code> to compute the
  * data location
  * 
- * @since 5.8
+ * @since GemFire 5.8
  * 
  */
 public class EntryOperationImpl implements EntryOperation {
@@ -64,7 +64,7 @@ public class EntryOperationImpl implements EntryOperation {
    * Return a description of the operation that triggered this event.
    * 
    * @return the operation that triggered this event.
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public Operation getOperation() {
     return this.operation;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntrySnapshot.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntrySnapshot.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntrySnapshot.java
index 02d333e..b5c828f 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntrySnapshot.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EntrySnapshot.java
@@ -34,7 +34,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
 /**
    * A Region.Entry implementation for remote entries and all PR entries
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public class EntrySnapshot implements Region.Entry, DataSerializable {
 private static final long serialVersionUID = -2139749921655693280L;
@@ -78,7 +78,7 @@ private static final long serialVersionUID = -2139749921655693280L;
      * Used by unit tests. Only available on PR.
      * If, at the time this entry was created, it was initialized from a local data store
      * then this method returns true.
-     * @since 6.0
+     * @since GemFire 6.0
      */
     public boolean wasInitiallyLocal() {
       return this.startedLocal;
@@ -131,7 +131,7 @@ private static final long serialVersionUID = -2139749921655693280L;
     /**
      * Makes a copy, if copy-on-get is enabled, of the specified object.
      * 
-     * @since 4.0
+     * @since GemFire 4.0
      */
     private Object conditionalCopy(Object o) {
       return o;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EnumListenerEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EnumListenerEvent.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EnumListenerEvent.java
index 53595a7..1fa5709 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EnumListenerEvent.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EnumListenerEvent.java
@@ -38,7 +38,7 @@ public abstract class EnumListenerEvent
   /**
    * Invoke the correct listener method for this event.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public abstract void dispatchEvent(CacheEvent event, CacheListener listener);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventID.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventID.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventID.java
index d8a5b72..794d4d7 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventID.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventID.java
@@ -184,7 +184,7 @@ public final class EventID
 
   /**
    * Returns the thread id used by the calling thread for its event ids
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static long getThreadId() {
     ThreadAndSequenceIDWrapper wrapper = (ThreadAndSequenceIDWrapper)threadIDLocal.get();
@@ -193,7 +193,7 @@ public final class EventID
   /**
    * Returns the next reservable sequence id used by the calling thread for its event ids.
    * Note that the returned id is not yet reserved by the calling thread.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static long getSequenceId() {
     ThreadAndSequenceIDWrapper wrapper = (ThreadAndSequenceIDWrapper)threadIDLocal.get();
@@ -202,7 +202,7 @@ public final class EventID
   /**
    * Reserves and returns a sequence id for the calling thread to be used
    * for an event id.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public static long reserveSequenceId() {
     ThreadAndSequenceIDWrapper wrapper = (ThreadAndSequenceIDWrapper)threadIDLocal.get();
@@ -321,7 +321,7 @@ public final class EventID
   /**
    * Returns a byte[] whose contents are calculated by
    * calling {@link #getOptimizedByteArrayForEventID}
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public byte[] calcBytes() {
     return getOptimizedByteArrayForEventID(getThreadID(), getSequenceID());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
index 2f00872..b4d4620 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EventTracker.java
@@ -51,7 +51,7 @@ import com.gemstone.gemfire.internal.util.concurrent.StoppableCountDownLatch;
  * memberID:threadID.  It is used to avoid replaying events in
  * client/server and partitioned-region configurations.
  * 
- * @since 6.0
+ * @since GemFire 6.0
  */
 public class EventTracker
 {
@@ -522,7 +522,7 @@ public class EventTracker
    * @param r - a Runnable to wrap the processing of the bulk op
    * @param eventID - the base event ID of the bulk op
    *
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public void syncBulkOp(Runnable r, EventID eventID) {
     Assert.assertTrue(eventID != null);
@@ -597,7 +597,7 @@ public class EventTracker
   /**
    * A sequence number tracker to keep events from clients from being
    * re-applied to the cache if they've already been seen.
-   * @since 5.5
+   * @since GemFire 5.5
    */
   static class EventSeqnoHolder implements DataSerializable {
     private static final long serialVersionUID = 8137262960763308046L;
@@ -654,7 +654,7 @@ public class EventTracker
    * membershipID and threadID in the cache
    * processed is true means the bulk op is processed by one thread 
    * no need to redo it by other threads.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   static class BulkOpProcessed {
     /** whether the op is processed */
@@ -693,7 +693,7 @@ public class EventTracker
   /**
    * A holder for the version tags generated for a bulk operation (putAll or removeAll). These
    * version tags are retrieved when a bulk op is retried.
-   * @since 7.0
+   * @since GemFire 7.0
    * protected for test purposes only.
    */
   protected static class BulkOpHolder {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EvictionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EvictionAttributesImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EvictionAttributesImpl.java
index 1cb5115..50242aa 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EvictionAttributesImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/EvictionAttributesImpl.java
@@ -48,7 +48,7 @@ import com.gemstone.gemfire.internal.cache.lru.MemLRUCapacityController;
  * @see com.gemstone.gemfire.cache.RegionAttributes
  * @see com.gemstone.gemfire.cache.AttributesMutator
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public final class EvictionAttributesImpl extends EvictionAttributes 
   implements EvictionAttributesMutator
@@ -224,7 +224,7 @@ public final class EvictionAttributesImpl extends EvictionAttributes
   /**
    * Returns true if this object uses a LIFO algorithm
    * 
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public boolean isLIFO() {
     return this.algorithm.isLIFO();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ExpiryTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ExpiryTask.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ExpiryTask.java
index 7da95f8..54f0b23 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ExpiryTask.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ExpiryTask.java
@@ -186,7 +186,7 @@ public abstract class ExpiryTask extends SystemTimer.SystemTimerTask {
   /**
    * Test method that causes expiration to be suspended until
    * permitExpiration is called.
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public final static void suspendExpiration() {
     synchronized (suspendLock) {
@@ -202,7 +202,7 @@ public abstract class ExpiryTask extends SystemTimer.SystemTimerTask {
   /**
    * Wait until permission is given for expiration to be done.
    * Tests are allowed to suspend expiration.
-   * @since 5.0
+   * @since GemFire 5.0
    */
   private final void waitOnExpirationSuspension() {
       for (;;) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterProfile.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterProfile.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterProfile.java
index acd0fca..08a6484 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterProfile.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterProfile.java
@@ -86,7 +86,7 @@ import com.gemstone.gemfire.internal.util.concurrent.CopyOnWriteHashMap;
  * long integers.  This reduces the size of routing information when sent
  * over the network.
  * 
- * @since 6.5
+ * @since GemFire 6.5
  */
 public class FilterProfile implements DataSerializableFixedID {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterRoutingInfo.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterRoutingInfo.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterRoutingInfo.java
index 6576a18..7f5b587 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterRoutingInfo.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FilterRoutingInfo.java
@@ -44,7 +44,7 @@ import java.util.Set;
  * This class is used to hold the information about the servers and
  * their Filters (CQs and Interest List) that are satisfied by the 
  * cache update operation.
- * @since 6.5
+ * @since GemFire 6.5
  */
 public class FilterRoutingInfo implements VersionedDataSerializable {
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FindDurableQueueProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FindDurableQueueProcessor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FindDurableQueueProcessor.java
index a776487..7ec993a 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FindDurableQueueProcessor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FindDurableQueueProcessor.java
@@ -47,7 +47,7 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * A processor for helping a locator find the durable queues for a given durable client id.
  * Asks each bridge server if they have the durable id and builds a list of matching servers.
  *
- * @since 5.7
+ * @since GemFire 5.7
  */
 public class FindDurableQueueProcessor extends ReplyProcessor21 {
   private static final Logger logger = LogService.getLogger();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FixedPartitionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FixedPartitionAttributesImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FixedPartitionAttributesImpl.java
index 157586d..d631413 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FixedPartitionAttributesImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/FixedPartitionAttributesImpl.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.cache.FixedPartitionAttributes;
 /**
  * Internal implementation of {@link FixedPartitionAttributes}.
  * 
- * @since 6.6
+ * @since GemFire 6.6
  */
 
 public class FixedPartitionAttributesImpl extends FixedPartitionAttributes

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceReattemptException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceReattemptException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceReattemptException.java
index be58e2e..04b95bb 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceReattemptException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceReattemptException.java
@@ -27,7 +27,7 @@ import com.gemstone.gemfire.internal.Assert;
  * instigate a retry of some sort.
  * 
  * @see com.gemstone.gemfire.internal.cache.partitioned.PartitionMessage
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class ForceReattemptException extends
     DataLocationException

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceableLinkedBlockingQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceableLinkedBlockingQueue.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceableLinkedBlockingQueue.java
index 57eb16b..f58fc02 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceableLinkedBlockingQueue.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ForceableLinkedBlockingQueue.java
@@ -68,7 +68,7 @@ import java.util.NoSuchElementException;
  * <a href="{@docRoot}/../technotes/guides/collections/index.html">
  * Java Collections Framework</a>.
  *
- * @since 1.5
+ * @since GemFire 1.5
  * @author Doug Lea
  * @param <E> the type of elements held in this collection
  *

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
index 76a2729..64b4949 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GemFireCacheImpl.java
@@ -277,7 +277,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
    * If true then when a delta is applied the size of the entry value will be recalculated. If false (the default) then
    * the size of the entry value is unchanged by a delta application. Not a final so that tests can change this value.
    *
-   * @since hitachi 6.1.2.9
+   * @since GemFire hitachi 6.1.2.9
    */
   public static boolean DELTAS_RECALCULATE_SIZE = Boolean.getBoolean("gemfire.DELTAS_RECALCULATE_SIZE");
 
@@ -569,7 +569,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   
   /**
    * {@link ExtensionPoint} support.
-   * @since 8.1
+   * @since GemFire 8.1
    */
   private SimpleExtensionPoint<Cache> extensionPoint = new SimpleExtensionPoint<Cache>(this, this);
   
@@ -1389,7 +1389,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * create diskstore factory with default attributes
    *
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public DiskStoreFactory createDiskStoreFactory() {
     return new DiskStoreFactoryImpl(this);
@@ -1398,7 +1398,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * create diskstore factory with predefined attributes
    *
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public DiskStoreFactory createDiskStoreFactory(DiskStoreAttributes attrs) {
     return new DiskStoreFactoryImpl(this, attrs);
@@ -1499,14 +1499,14 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Set to true during a cache close if user requested durable subscriptions to be kept.
    *
-   * @since 5.7
+   * @since GemFire 5.7
    */
   private boolean keepAlive;
 
   /**
    * Returns true if durable subscriptions (registrations and queries) should be preserved.
    *
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public boolean keepDurableSubscriptionsAlive() {
     return this.keepAlive;
@@ -2483,7 +2483,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns the DiskStore by name
    *
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public DiskStore findDiskStore(String name) {
     if (name == null) {
@@ -2495,7 +2495,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns the DiskStore list
    *
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public Collection<DiskStoreImpl> listDiskStores() {
     return Collections.unmodifiableCollection(this.diskStores.values());
@@ -2701,7 +2701,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns the member id of my distributed system
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public InternalDistributedMember getMyId() {
     return this.system.getDistributedMember();
@@ -2839,7 +2839,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns the date and time that this cache was created.
    *
-   * @since 3.5
+   * @since GemFire 3.5
    */
   public Date getCreationDate() {
     return this.creationDate;
@@ -2848,7 +2848,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns the number of seconds that have elapsed since the Cache was created.
    *
-   * @since 3.5
+   * @since GemFire 3.5
    */
   public int getUpTime() {
     return (int) ((System.currentTimeMillis() - this.creationDate.getTime()) / 1000);
@@ -3215,7 +3215,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * returns a set of all current regions in the cache, including buckets
    *
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public Set<LocalRegion> getAllRegions() {
     Set<LocalRegion> result = new HashSet();
@@ -3468,7 +3468,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Called by ccn when a client goes away
    *
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public void cleanupForClient(CacheClientNotifier ccn, ClientProxyMembershipID client) {
     try {
@@ -3623,7 +3623,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns true if get should give a copy; false if a reference.
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   final boolean isCopyOnRead() {
     return this.copyOnRead;
@@ -3632,7 +3632,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Implementation of {@link com.gemstone.gemfire.cache.Cache#setCopyOnRead}
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   public void setCopyOnRead(boolean copyOnRead) {
     this.copyOnRead = copyOnRead;
@@ -3641,7 +3641,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Implementation of {@link com.gemstone.gemfire.cache.Cache#getCopyOnRead}
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   final public boolean getCopyOnRead() {
     return this.copyOnRead;
@@ -3728,7 +3728,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
    *
    * @return the CacheTransactionManager instance.
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   public CacheTransactionManager getCacheTransactionManager() {
     return this.txMgr;
@@ -3785,7 +3785,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
    * Returns the <code>Executor</code> (thread pool) that is used to execute cache event listeners.
    * Returns <code>null</code> if no pool exists.
    *
-   * @since 3.5
+   * @since GemFire 3.5
    */
   Executor getEventThreadPool() {
     return this.eventThreadPool;
@@ -4210,7 +4210,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
 
   /**
    * @return Context jndi context associated with the Cache.
-   * @since 4.0
+   * @since GemFire 4.0
    */
   public Context getJNDIContext() {
     // if (isClient()) {
@@ -4221,7 +4221,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
 
   /**
    * @return JTA TransactionManager associated with the Cache.
-   * @since 4.0
+   * @since GemFire 4.0
    */
   public javax.transaction.TransactionManager getJTATransactionManager() {
     // if (isClient()) {
@@ -4338,7 +4338,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Returns this cache's ReliableMessageQueueFactory.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public ReliableMessageQueueFactory getReliableMessageQueueFactory() {
     return this.rmqFactory;
@@ -4534,7 +4534,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   
   /**
    * Returns the QueryMonitor instance based on system property MAX_QUERY_EXECUTION_TIME.
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public QueryMonitor getQueryMonitor() {
     //Check to see if monitor is required if ResourceManager critical heap percentage is set
@@ -4579,7 +4579,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   /**
    * Simple class to allow waiters for register interest. Has at most one thread that ever calls wait.
    *
-   * @since 5.7
+   * @since GemFire 5.7
    */
   private class SimpleWaiter {
     private boolean notified = false;
@@ -4641,7 +4641,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public <K, V> RegionFactory<K, V> createRegionFactory(RegionShortcut atts) {
     if (isClient()) {
@@ -4652,7 +4652,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public <K, V> RegionFactory<K, V> createRegionFactory() {
     if (isClient()) {
@@ -4662,7 +4662,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public <K, V> RegionFactory<K, V> createRegionFactory(String regionAttributesId) {
     if (isClient()) {
@@ -4672,7 +4672,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public <K, V> RegionFactory<K, V> createRegionFactory(RegionAttributes<K, V> regionAttributes) {
     if (isClient()) {
@@ -4682,7 +4682,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public <K, V> ClientRegionFactory<K, V> createClientRegionFactory(ClientRegionShortcut atts) {
     return new ClientRegionFactoryImpl<K, V>(this, atts);
@@ -4693,7 +4693,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   }
 
   /**
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public QueryService getQueryService(String poolName) {
     Pool p = PoolManager.find(poolName);
@@ -5311,7 +5311,7 @@ public class GemFireCacheImpl implements InternalCache, ClientCache, HasCachePer
   
   /**
    * @see Extensible#getExtensionPoint()
-   * @since 8.1
+   * @since GemFire 8.1
    */
   @Override
   public ExtensionPoint<Cache> getExtensionPoint() {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
index fd350a0..ec5fc4e 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/GridAdvisor.java
@@ -297,7 +297,7 @@ public abstract class GridAdvisor extends DistributionAdvisor {
      * Tell local controllers about the received profile. Also if exchange
      * profiles then add each local controller to reply.
      * 
-     * @since 5.7
+     * @since GemFire 5.7
      */
     protected final void tellLocalControllers(boolean removeProfile,
         boolean exchangeProfiles, final List<Profile> replyProfiles) {
@@ -324,7 +324,7 @@ public abstract class GridAdvisor extends DistributionAdvisor {
      * Tell local bridge servers about the received profile. Also if exchange
      * profiles then add each local bridge server to reply.
      * 
-     * @since 5.7
+     * @since GemFire 5.7
      */
     protected final void tellLocalBridgeServers(boolean removeProfile,
         boolean exchangeProfiles, final List<Profile> replyProfiles) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/HARegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/HARegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/HARegion.java
index c924be5..cac3d0a 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/HARegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/HARegion.java
@@ -53,7 +53,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Released;
  * This region is being implemented to suppress distribution of puts and to
  * allow localDestroys on mirrored regions.
  * 
- * @since 4.3
+ * @since GemFire 4.3
  *  
  */
 public final class HARegion extends DistributedRegion
@@ -116,7 +116,7 @@ public final class HARegion extends DistributedRegion
 
   /**
    * Updates never distributed from buckets.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   @Override
   protected void distributeUpdate(EntryEventImpl event, long lastModifiedTime, boolean ifNew, boolean ifOld, Object expectedOldValue, boolean requireOldValue) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/IncomingGatewayStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/IncomingGatewayStatus.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/IncomingGatewayStatus.java
index 11c8a35..abcbcf1 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/IncomingGatewayStatus.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/IncomingGatewayStatus.java
@@ -26,7 +26,7 @@ import java.net.InetAddress;
  * used by the monitoring tool.
  *
  *
- * @since 4.3
+ * @since GemFire 4.3
  */
 public class IncomingGatewayStatus implements Serializable {
   private static final long serialVersionUID = -4579815367602658353L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java
index bda5a27..20f5f49 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCache.java
@@ -29,7 +29,7 @@ import com.gemstone.gemfire.internal.cache.extension.Extensible;
  * not be part of the "public" API of the implementing class.
  * </p>
  * @see com.gemstone.gemfire.cache.Cache
- * @since 7.0
+ * @since GemFire 7.0
  */
 public interface InternalCache extends Cache, Extensible<Cache> {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCacheEvent.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCacheEvent.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCacheEvent.java
index 4497bbb..da2d385 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCacheEvent.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalCacheEvent.java
@@ -41,7 +41,7 @@ public interface InternalCacheEvent extends CacheEvent
   public boolean isBridgeEvent();
   /**
    * Answers true if this event is from a client
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public boolean hasClientOrigin();
   

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalDataView.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalDataView.java
index 0885477..2452804 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalDataView.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalDataView.java
@@ -31,7 +31,7 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.VersionedObjectList;
 import com.gemstone.gemfire.internal.offheap.annotations.Retained;
 
 /**
- * @since 6.0tx
+ * @since GemFire 6.0tx
  */
 public interface InternalDataView {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
index f7d46fe..7974418 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/InternalRegionArguments.java
@@ -30,7 +30,7 @@ import com.gemstone.gemfire.internal.cache.wan.AbstractGatewaySender;
  * An internal version of Region Attributes that allows for additional information
  * to be passed to the Region constructors, typically for internal purposes, for example
  * internally GemFire may need use a Region and flag it for internal use only.
- * @since 4.2.3
+ * @since GemFire 4.2.3
  */
 public final class InternalRegionArguments
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperFactory.java
index 75925ba..707ee2d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperFactory.java
@@ -18,7 +18,7 @@
  * The LoaderHelperFactory inspiration came 
  * from a need to allow Partitioned Regions to generate a LoaderHelper that was
  * outside the context of the Region the loader invoked from.
- * @since 5.0
+ * @since GemFire 5.0
  */
 package com.gemstone.gemfire.internal.cache;
 
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.cache.LoaderHelper;
  * The LoaderHelperFactory creates a LoaderHelper class which is used by a 
  * {@link com.gemstone.gemfire.cache.CacheLoader}.
  *  
- * @since 5.0
+ * @since GemFire 5.0
  */
 public interface LoaderHelperFactory
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperImpl.java
index 3c3c8ff..55a10b5 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LoaderHelperImpl.java
@@ -31,7 +31,7 @@ import com.gemstone.gemfire.i18n.StringId;
  *
  *
  * @see CacheLoader#load(LoaderHelper) load
- * @since 2.0
+ * @since GemFire 2.0
  */
 public class LoaderHelperImpl implements LoaderHelper
 {