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:01 UTC

[16/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/LocalRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
index cc5ac59..8295487 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegion.java
@@ -227,7 +227,7 @@ public class LocalRegion extends AbstractRegion
   
   /**
    * Internal interface used to simulate failures when performing entry operations
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public interface TestCallable {
     public void call(LocalRegion r, Operation op, RegionEntry re);
@@ -331,7 +331,7 @@ public class LocalRegion extends AbstractRegion
    * Used by unit tests to set expiry to milliseconds instead of the default
    * seconds. Used in ExpiryTask.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   final boolean EXPIRY_UNITS_MS;
 
@@ -366,7 +366,7 @@ public class LocalRegion extends AbstractRegion
    * Used to hold off cache listener events until the afterRegionCreate is
    * called
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   private final StoppableCountDownLatch afterRegionCreateEventLatch;
 
@@ -822,7 +822,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected final ServerRegionProxy srp;
 
@@ -897,7 +897,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Returns the member id of my distributed system
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   @Override
   protected InternalDistributedMember getMyId()
@@ -1600,7 +1600,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Returns true if get should give a copy; false if a reference.
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   protected boolean isCopyOnRead()
   {
@@ -1615,7 +1615,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Makes a copy, if copy-on-get is enabled, of the specified object.
    *
-   * @since 4.0
+   * @since GemFire 4.0
    */
   protected Object conditionalCopy(Object o)
   {
@@ -2006,7 +2006,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Flavor of keys that will not do repeatable read
-   * @since 5.5
+   * @since GemFire 5.5
    */
   public Set testHookKeys()
   {
@@ -2209,7 +2209,7 @@ public class LocalRegion extends AbstractRegion
    *
    * @return <code>null</code> if disk regions are not being used
    *
-   * @since 3.2
+   * @since GemFire 3.2
    */
   public DiskRegion getDiskRegion()
   {
@@ -2233,7 +2233,7 @@ public class LocalRegion extends AbstractRegion
    *
    * Initially called by EvictorThread.run
    *
-   * @since 3.5.1
+   * @since GemFire 3.5.1
    */
   public void checkLRU()
   {
@@ -2686,7 +2686,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Called after we have delivered our REGION_CREATE event.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   private void releaseAfterRegionCreateEventLatch()
   {
@@ -2697,7 +2697,7 @@ public class LocalRegion extends AbstractRegion
    * Used to cause cache listener events to wait until the after region create
    * event is delivered.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   private void waitForRegionCreateEvent()
   {
@@ -3146,7 +3146,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void serverRegionDestroy(RegionEventImpl regionEvent) {
     if (regionEvent.getOperation().isDistributed()) {
@@ -3160,7 +3160,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void serverRegionClear(RegionEventImpl regionEvent) {
     if (regionEvent.getOperation().isDistributed()) {
@@ -3173,7 +3173,7 @@ public class LocalRegion extends AbstractRegion
     }
   }
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void serverRegionInvalidate(RegionEventImpl regionEvent) {
     if (regionEvent.getOperation().isDistributed()) {
@@ -3185,7 +3185,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   void serverInvalidate(EntryEventImpl event) {
     if (event.getOperation().isDistributed() && !event.isOriginRemote()) {
@@ -3197,7 +3197,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void serverPut(EntryEventImpl event,
       boolean requireOldValue, Object expectedOldValue) {
@@ -3246,7 +3246,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Destroy an entry on the server given its event.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected void serverDestroy(EntryEventImpl event, Object expectedOldValue) {
     if (event.getOperation().isDistributed()) {
@@ -3383,7 +3383,7 @@ public class LocalRegion extends AbstractRegion
   }
 
   /**
-   * @since 5.0.2
+   * @since GemFire 5.0.2
    */
   private final boolean DO_EXPENSIVE_VALIDATIONS = Boolean.getBoolean("gemfire.DO_EXPENSIVE_VALIDATIONS");
 
@@ -3614,7 +3614,7 @@ public class LocalRegion extends AbstractRegion
    *
    * @see RegionMap#getEntry
    *
-   * @since 3.2
+   * @since GemFire 3.2
    */
   public Object getValueInVM(Object key) throws EntryNotFoundException
   {
@@ -3628,7 +3628,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * @param rememberRead true if read should be remembered in a transaction
-   * @since 5.5
+   * @since GemFire 5.5
    */
   private Object basicGetValueInVM(Object key, boolean rememberRead)
     throws EntryNotFoundException
@@ -3662,7 +3662,7 @@ public class LocalRegion extends AbstractRegion
      * @return an unmodifiable set of keys that have been read or written
      * by the transaction on this thread.
      * @throws IllegalStateException if not tx in progress
-     * @since 5.5
+     * @since GemFire 5.5
      */
     public Set testHookTXKeys() {
       if (!isTX()) throw new IllegalStateException(LocalizedStrings.LocalRegion_TX_NOT_IN_PROGRESS.toLocalizedString());
@@ -3692,7 +3692,7 @@ public class LocalRegion extends AbstractRegion
    *
    * @see RegionEntry#getValueOnDisk
    *
-   * @since 3.2
+   * @since GemFire 3.2
    */
   public Object getValueOnDisk(Object key) throws EntryNotFoundException
   {
@@ -3730,7 +3730,7 @@ public class LocalRegion extends AbstractRegion
    * or null if the entry exists but no value data exists.
    * @throws IllegalStateException when the region is not persistent
    * @throws EntryNotFoundException if there is no entry for the given key
-   * @since gemfire5.7_hotfix
+   * @since GemFire 5.7
    */
   public Object getSerializedValueOnDisk(Object key) throws EntryNotFoundException
   {
@@ -3763,7 +3763,7 @@ public class LocalRegion extends AbstractRegion
    *
    * @see RegionEntry#getValueOnDisk
    *
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public Object getValueOnDiskOrBuffer(Object key)
   throws EntryNotFoundException {
@@ -4720,7 +4720,7 @@ public class LocalRegion extends AbstractRegion
    * <p>
    * Acquires and releases the DestroyLock.
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   void reinitialize(InputStream inputStream, RegionEventImpl event)
       throws TimeoutException, IOException, ClassNotFoundException
@@ -6536,7 +6536,7 @@ public class LocalRegion extends AbstractRegion
    * @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) {
     if (this.eventTracker != null && !isTX()) {
@@ -6873,7 +6873,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Called after this region has been completely created
    *
-   * @since 5.0
+   * @since GemFire 5.0
    *
    * @see DistributedRegion#postDestroyRegion(boolean, RegionEventImpl)
    */
@@ -7030,7 +7030,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Do the expensive work of discovering an existing JTA transaction
    * Only needs to be called at Region.Entry entry points e.g. Region.put, Region.invalidate, etc.
-   * @since tx
+   * @since GemFire tx
    */
   final public void discoverJTA() {
     if (!isSecret() && !isUsedForPartitionedRegionAdmin()
@@ -7041,7 +7041,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * @return true if a transaction is in process
-   * @since tx 
+   * @since GemFire tx
    */
   public final boolean isTX() {
     return getTXState() != null;
@@ -7234,7 +7234,7 @@ public class LocalRegion extends AbstractRegion
    * @param entry the Region entry being destroyed
    * @param event
    *          the event describing the destroy operation
-   * @since 5.1
+   * @since GemFire 5.1
    */
   protected void basicDestroyBeforeRemoval(RegionEntry entry, EntryEventImpl event)
   {
@@ -7867,7 +7867,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Release the client connection pool if we have one
-   * @since 5.7
+   * @since GemFire 5.7
    */
   private void detachPool() {
     ServerRegionProxy mySRP = getServerProxy();
@@ -8020,7 +8020,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * For each region entry in this region call the callback
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public void foreachRegionEntry(RegionEntryCallback callback) {
     Iterator it = this.entries.regionEntriesInVM().iterator();
@@ -8031,7 +8031,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Used by {@link #foreachRegionEntry}.
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public interface RegionEntryCallback {
     public void handleRegionEntry(RegionEntry re);
@@ -8203,7 +8203,7 @@ public class LocalRegion extends AbstractRegion
    *
    * @return <code>null</code> is a disk region is not desired
    *
-   * @since 3.2
+   * @since GemFire 3.2
    */
   protected DiskRegion createDiskRegion(InternalRegionArguments internalRegionArgs)
       throws DiskAccessException {
@@ -8239,7 +8239,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Returns the object sizer on this region or null if it has no sizer.
-   * @since 6.1.2.9
+   * @since GemFire 6.1.2.9
    */
   public ObjectSizer getObjectSizer() {
     ObjectSizer result = null;
@@ -9497,7 +9497,7 @@ public class LocalRegion extends AbstractRegion
     // /////////////////////////////////////////
 
     /**
-     * @since 5.0
+     * @since GemFire 5.0
      */
     public Object setValue(Object arg0)
     {
@@ -9529,7 +9529,7 @@ public class LocalRegion extends AbstractRegion
   /**
    * Methods for java.util.Map compliance
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
 
   /**
@@ -10865,7 +10865,7 @@ public class LocalRegion extends AbstractRegion
    * @param topSerial the remote serialNumber for the top region (maybe root)
    * @param subregionSerialNumbers map of remote subregions to serialNumbers
    * @param regionDestroyed true if the region was destroyed on the remote host (as opposed to closed)
-   * @since 5.0
+   * @since GemFire 5.0
    */
   final void handleRemoteLocalRegionDestroyOrClose(
       InternalDistributedMember sender,
@@ -10893,7 +10893,7 @@ public class LocalRegion extends AbstractRegion
    * @param topSerial the remote serialNumber for the top region (maybe root)
    * @param subregionSerialNumbers remote map of subregions to serialNumbers
    * @param regionDestroyed 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   private final void basicHandleRemoteLocalRegionDestroyOrClose(
       InternalDistributedMember sender,
@@ -10935,7 +10935,7 @@ public class LocalRegion extends AbstractRegion
    * Remove the specified sender from this regions advisor.
    * @param regionDestroyed 
    *
-   * @since 5.0
+   * @since GemFire 5.0
    */
   protected void removeSenderFromAdvisor(InternalDistributedMember sender, int serial, boolean regionDestroyed)
   {
@@ -10966,7 +10966,7 @@ public class LocalRegion extends AbstractRegion
 
  /**
    * forces the diskRegion to switch the oplog
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public void forceRolling() throws DiskAccessException {
     if(this.diskRegion!=null){
@@ -10994,7 +10994,7 @@ public class LocalRegion extends AbstractRegion
    * get rolled else null if no oplogs were available at the time of signal or region
    * is not having disk persistence. Pls note that the actual number of oplogs 
    * rolled may be more than what is indicated
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   @Override
   public boolean forceCompaction()
@@ -11214,7 +11214,7 @@ public class LocalRegion extends AbstractRegion
 
   /**
    * Called by ccn when a client goes away
-   * @since 5.7
+   * @since GemFire 5.7
    */
   void cleanupForClient(CacheClientNotifier ccn,
                         ClientProxyMembershipID client) {
@@ -11366,7 +11366,7 @@ public class LocalRegion extends AbstractRegion
    * @param function
    * @param args
    * @param filter
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   public ResultCollector executeFunction(final DistributedRegionFunctionExecutor execution, final Function function, final Object args,
       final ResultCollector rc,final Set filter, final ServerToClientFunctionResultSender sender) {   
@@ -11481,7 +11481,7 @@ public class LocalRegion extends AbstractRegion
    * @param localMemoryIsCritical true if the local memory is in a critical state
    * @param critialMembers set of members whose memory is in a critical state
    * @see ResourceManager#setCriticalHeapPercentage(float) and ResourceManager#setCriticalOffHeapPercentage(float)
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public void initialCriticalMembers(boolean localMemoryIsCritical,
       Set<InternalDistributedMember> critialMembers) {
@@ -11586,7 +11586,7 @@ public class LocalRegion extends AbstractRegion
   }
   
   /**
-   * @since SqlFabric
+   * @since GemFire SqlFabric
    *
    */
   void distributeUpdatedProfileOnHubCreation()
@@ -11755,7 +11755,7 @@ public class LocalRegion extends AbstractRegion
     
     /**
      * @return the timestamp that marks the start of the operation
-     * @since 3.5
+     * @since GemFire 3.5
      */
     @Override
     public long startCacheListenerCall() {
@@ -11765,7 +11765,7 @@ public class LocalRegion extends AbstractRegion
     }
     /**
      * @param start the timestamp taken when the operation started 
-     * @since 3.5
+     * @since GemFire 3.5
      */
     @Override
     public void endCacheListenerCall(long start) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegionDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegionDataView.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegionDataView.java
index c26ff10..ae4789d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegionDataView.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/LocalRegionDataView.java
@@ -29,7 +29,7 @@ import com.gemstone.gemfire.internal.cache.versions.ConcurrentCacheModificationE
 
 /**
  * 
- * @since 6.0tx
+ * @since GemFire 6.0tx
  */
 public class LocalRegionDataView implements InternalDataView {
   /* (non-Javadoc)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/MinimumSystemRequirements.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/MinimumSystemRequirements.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/MinimumSystemRequirements.java
index 4772f8c..775b4ba 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/MinimumSystemRequirements.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/MinimumSystemRequirements.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
  * Checks that minimum system requirements are met.
  * 
  *
- * @since 8.1
+ * @since GemFire 8.1
  */
 public final class MinimumSystemRequirements {
 
@@ -45,7 +45,7 @@ public final class MinimumSystemRequirements {
    * 
    * @see #checkAndLog()
    * 
-   * @since 8.1
+   * @since GemFire 8.1
    */
   public static void assertLogAndExit() {
     if (!checkAndLog()) {
@@ -58,7 +58,7 @@ public final class MinimumSystemRequirements {
    * 
    * @return true if minimum system requirements met, otherwise false.
    * 
-   * @since 8.1
+   * @since GemFire 8.1
    */
   public static boolean checkAndLog() {
     boolean minimumSystemRequirementsMet = true;
@@ -77,7 +77,7 @@ public final class MinimumSystemRequirements {
    * 
    * @return true if minimum system requirements met, otherwise false.
    * 
-   * @since 8.1
+   * @since GemFire 8.1
    */
   private static boolean checkJavaVersion() {
     if (SystemUtils.isJavaVersionAtLeast(JAVA_VERSION)) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OpType.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OpType.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OpType.java
index 8200fa6..f4a49d6 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OpType.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OpType.java
@@ -23,7 +23,7 @@ package com.gemstone.gemfire.internal.cache;
  * 
  * @see com.gemstone.gemfire.cache.Operation
  * 
- * @since 6.6
+ * @since GemFire 6.6
  */
 public final class OpType {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
index 96f616b..42d1dbc 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/Oplog.java
@@ -124,7 +124,7 @@ import com.gemstone.gemfire.pdx.internal.PdxWriterImpl;
  * {@link OverflowOplog}.
  * 
  * 
- * @since 5.1
+ * @since GemFire 5.1
  */
 
 public final class Oplog implements CompactableOplog, Flushable {
@@ -205,7 +205,7 @@ public final class Oplog implements CompactableOplog, Flushable {
   /**
    * Set to true once compact is called on this oplog.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private volatile boolean compacting = false;
 
@@ -240,7 +240,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * NEW_ENTRY records. 1: EndOfRecord Only needs to be written once per oplog
    * and must preceed any OPLOG_NEW_ENTRY_0ID records.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_NEW_ENTRY_BASE_ID = 63;
   static final int OPLOG_NEW_ENTRY_BASE_REC_SIZE = 1 + 8 + 1;
@@ -250,7 +250,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_NEW_ENTRY_0ID = 64;
 
@@ -260,7 +260,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 1: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_1ID = 65;
   /**
@@ -269,7 +269,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 2: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_2ID = 66;
 
@@ -279,7 +279,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 3: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_3ID = 67;
 
@@ -289,7 +289,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 4: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_4ID = 68;
 
@@ -299,7 +299,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 5: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_5ID = 69;
   /**
@@ -308,7 +308,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 6: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_6ID = 70;
   /**
@@ -317,7 +317,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 7: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_7ID = 71;
   /**
@@ -326,7 +326,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * userBits 8: OplogEntryId RegionId 4: valueLength (optional depending on
    * bits) valueLength: value bytes (optional depending on bits) 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_8ID = 72;
 
@@ -337,7 +337,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_1ID = 73;
   /**
@@ -347,7 +347,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_2ID = 74;
 
@@ -358,7 +358,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_3ID = 75;
 
@@ -369,7 +369,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_4ID = 76;
 
@@ -380,7 +380,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_5ID = 77;
   /**
@@ -390,7 +390,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_6ID = 78;
   /**
@@ -400,7 +400,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_7ID = 79;
   /**
@@ -410,7 +410,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * bits) valueLength: value bytes (optional depending on bits) 4: keyLength
    * keyLength: key bytes 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_MOD_ENTRY_WITH_KEY_8ID = 80;
 
@@ -419,7 +419,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 1 byte. Byte Format: 1:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_1ID = 81;
   /**
@@ -427,7 +427,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 2 bytes. Byte Format: 2:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_2ID = 82;
 
@@ -436,7 +436,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 3 bytes. Byte Format: 3:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_3ID = 83;
 
@@ -445,7 +445,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 4 bytes. Byte Format: 4:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_4ID = 84;
 
@@ -454,7 +454,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 5 bytes. Byte Format: 5:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_5ID = 85;
   /**
@@ -462,7 +462,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 6 bytes. Byte Format: 6:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_6ID = 86;
   /**
@@ -470,7 +470,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 7 bytes. Byte Format: 7:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_7ID = 87;
   /**
@@ -478,7 +478,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * OplogEntryId. The signed difference is encoded in 8 bytes. Byte Format: 8:
    * OplogEntryId 1: EndOfRecord
    *
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private static final byte OPLOG_DEL_ENTRY_8ID = 88;
 
@@ -519,7 +519,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * Each oplog type has a different magic number Followed by EndOfRecord Fix
    * for bug 43824
    * 
-   * @since 8.0
+   * @since GemFire 8.0
    */
   static final byte OPLOG_MAGIC_SEQ_ID = 92;
 
@@ -1277,7 +1277,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * the value This method should never get invoked for an entry which has been
    * destroyed
    * 
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    * @param id
    *          The DiskId for the entry @param offset The offset in this OpLog
    *          where the entry is present. @param faultingIn @param bitOnly
@@ -1436,21 +1436,21 @@ public final class Oplog implements CompactableOplog, Flushable {
    * Used during recovery to calculate the OplogEntryId of the next NEW_ENTRY
    * record.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private long recoverNewEntryId = DiskStoreImpl.INVALID_ID;
   /**
    * Used during writing to remember the last MOD_ENTRY OplogEntryId written to
    * this oplog.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private long writeModEntryId = DiskStoreImpl.INVALID_ID;
   /**
    * Used during recovery to calculate the OplogEntryId of the next MOD_ENTRY
    * record.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private long recoverModEntryId = DiskStoreImpl.INVALID_ID;
   /**
@@ -1465,14 +1465,14 @@ public final class Oplog implements CompactableOplog, Flushable {
    * Used during writing to remember the last DEL_ENTRY OplogEntryId written to
    * this oplog.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private long writeDelEntryId = DiskStoreImpl.INVALID_ID;
   /**
    * Used during recovery to calculate the OplogEntryId of the next DEL_ENTRY
    * record.
    * 
-   * @since prPersistSprint1
+   * @since GemFire prPersistSprint1
    */
   private long recoverDelEntryId = DiskStoreImpl.INVALID_ID;
 
@@ -7885,7 +7885,7 @@ public final class Oplog implements CompactableOplog, Flushable {
    * Used in offline mode to prevent pdx deserialization of keys. The raw bytes
    * are a serialized pdx.
    * 
-   * @since 6.6
+   * @since GemFire 6.6
    */
   private static class RawByteKey implements Sendable {
     final byte[] bytes;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OverflowOplog.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OverflowOplog.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OverflowOplog.java
index 600f790..bb792a8 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OverflowOplog.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/OverflowOplog.java
@@ -51,7 +51,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * For regions that are persistent (i.e. they can be recovered) see {@link Oplog}.
  * 
  * 
- * @since prPersistSprint2
+ * @since GemFire prPersistSprint2
  */
 class OverflowOplog implements CompactableOplog, Flushable {
   private static final Logger logger = LogService.getLogger();
@@ -309,7 +309,7 @@ class OverflowOplog implements CompactableOplog, Flushable {
    * obatin the value This method should never get invoked for an entry which
    * has been destroyed
    * 
-   * @since 3.2.1 
+   * @since GemFire 3.2.1
    * @param id The DiskId for the entry @param offset The offset in
    *        this OpLog where the entry is present. @param faultingIn @param
    *        bitOnly boolean indicating whether to extract just the UserBit or

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PRHARedundancyProvider.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PRHARedundancyProvider.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PRHARedundancyProvider.java
index 6fe39b1..2ec1e3f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PRHARedundancyProvider.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PRHARedundancyProvider.java
@@ -938,7 +938,7 @@ public class PRHARedundancyProvider
   /** 
    * Get buddy data stores on the same Host as the accepted member
    * @return set of members on the same host, not including accepted member
-   * @since gemfire59poc
+   * @since GemFire 5.9
    * 
    */
   private Set <InternalDistributedMember> getBuddyMembersInZone(
@@ -957,7 +957,7 @@ public class PRHARedundancyProvider
   /**
    * Early check for resources. This code may be executed for every put operation if
    * there are no datastores present, limit excessive logging.
-   * @since gemfire5.8
+   * @since GemFire 5.8
    */
   private void earlySufficientStoresCheck(String partitionName) {
     assert Assert.assertHoldsLock(this,false);
@@ -975,7 +975,7 @@ public class PRHARedundancyProvider
    * to once per PR after which once every {@link #INSUFFICIENT_LOGGING_THROTTLE_TIME}
    * second
    * @return true if it's time to log
-   * @since gemfire5.8
+   * @since GemFire 5.8
    */
   private boolean shouldLogInsufficientStores() {
     long now = NanoTimer.getTime();
@@ -1285,7 +1285,7 @@ public class PRHARedundancyProvider
    * @param bucketId
    * @param prName
    * @return InternalDistributedMember colocated data store
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   private InternalDistributedMember getColocatedDataStore(
       Collection<InternalDistributedMember> candidates,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionAttributesImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionAttributesImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionAttributesImpl.java
index d1e2bd0..47548f3 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionAttributesImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionAttributesImpl.java
@@ -53,7 +53,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
  * only in this class and not in {@link PartitionAttributes} are for internal
  * use only.
  *  
- * @since 5.5
+ * @since GemFire 5.5
  */
 public class PartitionAttributesImpl implements PartitionAttributes,
       Cloneable, DataSerializable
@@ -679,7 +679,7 @@ public class PartitionAttributesImpl implements PartitionAttributes,
    * 4. totalNumBuckets should be same for colocated regions<br>
    * 5. redundancy of colocated regions should be same<br>
    * 
-   * @since 5.8Beta
+   * @since GemFire 5.8Beta
    */
   void validateColocation() {
     if (this.colocatedRegionName == null) {
@@ -722,7 +722,7 @@ public class PartitionAttributesImpl implements PartitionAttributes,
    * Only attributes explicitly set in pa will be merged into this.
    * Any attribute set in pa will take precedence over an attribute in this.
    * @param pa the attributes to merge into this.
-   * @since 7.0
+   * @since GemFire 7.0
    */
   public void merge(PartitionAttributesImpl pa) {
     if (pa.hasRedundancy) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
index ea207ae..4165fd7 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegion.java
@@ -1730,7 +1730,7 @@ public class PartitionedRegion extends LocalRegion implements
   // /////////////////////////////////////////////////////////////////
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1740,7 +1740,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1752,7 +1752,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1762,7 +1762,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1772,7 +1772,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1781,7 +1781,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1792,7 +1792,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1814,7 +1814,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1826,7 +1826,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1843,7 +1843,7 @@ public class PartitionedRegion extends LocalRegion implements
    * 
    * @see DefaultQuery#execute()
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public Object executeQuery(DefaultQuery query, Object[] parameters,
       Set buckets) throws FunctionDomainException, TypeMismatchException,
@@ -1988,7 +1988,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -1998,7 +1998,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -2008,7 +2008,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
   /**
-   * @since 5.0
+   * @since GemFire 5.0
    * @throws UnsupportedOperationException
    * OVERRIDES
    */
@@ -3333,7 +3333,7 @@ public class PartitionedRegion extends LocalRegion implements
   /**
    * Gets the Node for reading or performing a load from a specific bucketId.
    * @return the member from which to read or load
-   * @since 5.7
+   * @since GemFire 5.7
    */
   private InternalDistributedMember getNodeForBucketReadOrLoad(int bucketId) {
     InternalDistributedMember targetNode;
@@ -3531,7 +3531,7 @@ public class PartitionedRegion extends LocalRegion implements
    * @param function
    * @param execution
    * @param rc
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public ResultCollector executeFunction(final Function function,
       final PartitionedRegionFunctionExecutor execution, ResultCollector rc,
@@ -3739,7 +3739,7 @@ public class PartitionedRegion extends LocalRegion implements
    * 
    * @param function
    * @param execution
-   * @since 6.0
+   * @since GemFire 6.0
    */
   private ResultCollector executeOnSingleNode(final Function function,
       final PartitionedRegionFunctionExecutor execution, ResultCollector rc, 
@@ -4006,7 +4006,7 @@ public class PartitionedRegion extends LocalRegion implements
    * @param function
    * @param execution
    * @return ResultCollector
-   * @since 6.0
+   * @since GemFire 6.0
    */
   private ResultCollector executeOnAllBuckets(final Function function,
       final PartitionedRegionFunctionExecutor execution, ResultCollector rc, boolean isPRSingleHop) {
@@ -5985,7 +5985,7 @@ public class PartitionedRegion extends LocalRegion implements
    * Called after the cache close has closed all regions. This clean up static
    * pr resources.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   static void afterRegionsClosedByCacheClose(GemFireCacheImpl cache) {
     PRQueryProcessor.shutdown();
@@ -6392,7 +6392,7 @@ public class PartitionedRegion extends LocalRegion implements
    * Set view of entries. This currently extends the keySet iterator and
    * performs individual getEntry() operations using the keys
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   protected class PREntriesSet extends KeysSet {
 
@@ -6633,7 +6633,7 @@ public class PartitionedRegion extends LocalRegion implements
    * Set view of values. This currently extends the keySet iterator and performs
    * individual get() operations using the keys
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   protected class ValuesSet extends KeysSet  {
 
@@ -6700,7 +6700,7 @@ public class PartitionedRegion extends LocalRegion implements
   }
 
     /**
-   * @since 6.6
+   * @since GemFire 6.6
    */
   @Override
   public boolean containsValue(final Object value) {
@@ -7140,7 +7140,7 @@ public class PartitionedRegion extends LocalRegion implements
    * created the lock, typically used for locking buckets, but not restricted to
    * that usage.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   static class BucketLock {
 
@@ -8858,7 +8858,7 @@ public class PartitionedRegion extends LocalRegion implements
    * from queries like getKeysWithRegEx. The implementor creates a method,
    * receiveSet, that consumes the chunks.
    * 
-   * @since 5.1
+   * @since GemFire 5.1
    */
   public static interface SetCollector {
     public void receiveSet(Set theSet) throws IOException;
@@ -9707,7 +9707,7 @@ public class PartitionedRegion extends LocalRegion implements
    * should *only* be invoked when region is just newly created and has no data
    * or existing buckets else will have undefined behaviour.
    * 
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public void setColocatedWith(String colocatedRegionFullPath) {
     ((PartitionAttributesImpl)this.partitionAttributes)
@@ -9720,7 +9720,7 @@ public class PartitionedRegion extends LocalRegion implements
    * RegionMembershipListener invocations. This is copied almost in whole from
    * DistributedRegion
    * 
-   * @since 5.7
+   * @since GemFire 5.7
    */
   protected class AdvisorListener implements MembershipListener
   {
@@ -10637,7 +10637,7 @@ public class PartitionedRegion extends LocalRegion implements
   /**
    * Returns the local BucketRegion given the key.
    * Returns null if no BucketRegion exists.
-   * @since 6.1.2.9
+   * @since GemFire 6.1.2.9
    */
   public BucketRegion getBucketRegion(Object key) {
     if (this.dataStore == null)
@@ -10665,7 +10665,7 @@ public class PartitionedRegion extends LocalRegion implements
   /**
    * Test hook to return the per entry overhead for a bucket region.
    * Returns -1 if no buckets exist in this vm. 
-   * @since 6.1.2.9
+   * @since GemFire 6.1.2.9
    */
   public int getPerEntryLRUOverhead() {
     if (this.dataStore == null) { // this is an accessor

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketMgmtHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketMgmtHelper.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketMgmtHelper.java
index 8ace8b3..2d1ae19 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketMgmtHelper.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionBucketMgmtHelper.java
@@ -36,7 +36,7 @@ public class PartitionedRegionBucketMgmtHelper
    * @param b Bucket to evaluate
    * @param moveSource 
    * @return true if it is allowed to be recovered
-   * @since gemfire59poc
+   * @since GemFire 5.9
    */
   public static boolean bucketIsAllowedOnThisHost(Bucket b, InternalDistributedMember moveSource) {
     if (b.getDistributionManager().enforceUniqueZone()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
index bda68e3..40821c2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataStore.java
@@ -1871,7 +1871,7 @@ public class PartitionedRegionDataStore implements HasCachePerfStats
   /**
    * Returns the local BucketRegion given an bucketId.
    * Returns null if no BucketRegion exists.
-   * @since 6.1.2.9
+   * @since GemFire 6.1.2.9
    */
   public BucketRegion getLocalBucketById(Integer bucketId) {
     final BucketRegion bucketRegion = this.localBucket2RegionMap.get(bucketId);
@@ -1894,7 +1894,7 @@ public class PartitionedRegionDataStore implements HasCachePerfStats
   /**
    * Test hook to return the per entry overhead for a bucket region.
    * PRECONDITION: a bucket must exist and be using LRU.
-   * @since 6.1.2.9
+   * @since GemFire 6.1.2.9
    */
   public int getPerEntryLRUOverhead() {
     BucketRegion br = (localBucket2RegionMap.values().iterator().next());

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataView.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataView.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataView.java
index de1f7d8..02a84ee 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataView.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionDataView.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.internal.cache.tier.sockets.ClientProxyMembershipID;
 
 
 /**
- * @since 6.0tx
+ * @since GemFire 6.0tx
  */
 public class PartitionedRegionDataView extends LocalRegionDataView {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryEvaluator.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryEvaluator.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryEvaluator.java
index 85f058f..5ca17a8 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryEvaluator.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionQueryEvaluator.java
@@ -92,7 +92,7 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
 
   /**
    * An ArrayList which might be unconsumable.
-   * @since 6.6.2
+   * @since GemFire 6.6.2
    */
   public static class MemberResultsList extends ArrayList {
     private boolean isLastChunkReceived = false;
@@ -108,7 +108,7 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
 
   /**
    * Simple testing interface
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public interface TestHook {
     public void hook(final int spot) throws RuntimeException;
@@ -1024,7 +1024,7 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
    * in multipleThreads and results gained from buckets.
    * In future this can be used for adding for more information to final
    * query running info from pool threads.
-   * @since 6.6
+   * @since GemFire 6.6
    */
   public static class PRQueryResultCollector {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStats.java
index 43645c6..04d432f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStats.java
@@ -44,7 +44,7 @@ import com.gemstone.gemfire.internal.StatisticsTypeFactoryImpl;
  * To manipulate the statistic values, use (inc|dec|set|get)&lt;fieldName&gt;
  * methods.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class PartitionedRegionStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatus.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatus.java
index e3dbabd..193d7ba 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatus.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PartitionedRegionStatus.java
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.internal.cache;
  * <code>PartitionedRegion</code>s. This class is used by the monitoring tool.
  *
  *
- * @since 5.1
+ * @since GemFire 5.1
  */
 public class PartitionedRegionStatus extends RegionStatus {
   private static final long serialVersionUID = -6755318987122602065L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PlaceHolderDiskRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PlaceHolderDiskRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PlaceHolderDiskRegion.java
index 50f1ac7..df858f6 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PlaceHolderDiskRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PlaceHolderDiskRegion.java
@@ -32,7 +32,7 @@ import com.gemstone.gemfire.internal.i18n.LocalizedStrings;
    * from the DiskInitFile.
    *
    *
-   * @since prPersistSprint2
+   * @since GemFire prPersistSprint2
    */
   public class PlaceHolderDiskRegion extends AbstractDiskRegion
       implements DiskRecoveryStore {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolFactoryImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolFactoryImpl.java
index 216f3e2..102d0ef 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolFactoryImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolFactoryImpl.java
@@ -49,7 +49,7 @@ import com.gemstone.gemfire.pdx.internal.TypeRegistry;
 
 /**
  * Implementation of PoolFactory.
- * @since 5.7
+ * @since GemFire 5.7
  */
 public class PoolFactoryImpl implements PoolFactory {
   private static final Logger logger = LogService.getLogger();
@@ -310,7 +310,7 @@ public class PoolFactoryImpl implements PoolFactory {
    * @throws IllegalStateException if the connection pool name already exists
    * @throws IllegalStateException if this factory does not have any locators or servers
    * @return the newly created connection pool.
-   * @since 5.7
+   * @since GemFire 5.7
    */
   public Pool create(String name) throws CacheException {
     GemFireCacheImpl cache = GemFireCacheImpl.getInstance();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolManagerImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolManagerImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolManagerImpl.java
index 761f973..bc5441b 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolManagerImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolManagerImpl.java
@@ -48,7 +48,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
 /**
  * Implementation used by PoolManager.
  *
- * @since 5.7
+ * @since GemFire 5.7
  *
  */
 public class PoolManagerImpl {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolStats.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolStats.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolStats.java
index 99876ac..6a6ae3b 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolStats.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PoolStats.java
@@ -28,7 +28,7 @@ import com.gemstone.gemfire.internal.StatisticsTypeFactoryImpl;
  * GemFire statistics about a Pool 
  *
  *
- * @since 5.7
+ * @since GemFire 5.7
  */
 public class PoolStats {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable.java
index e9796ea..3a582ab 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PreferBytesCachedDeserializable.java
@@ -33,7 +33,7 @@ import com.gemstone.gemfire.internal.lang.StringUtils;
  * You can ask it for its Object in which case it always has to deserialize.
  * So it "prefers serialization (aka bytes)".
  *
- * @since 5.0.2
+ * @since GemFire 5.0.2
  *
  */
 public final class PreferBytesCachedDeserializable implements CachedDeserializable, DataSerializableFixedID {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PrimaryBucketException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PrimaryBucketException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PrimaryBucketException.java
index 35502c4..4a5696b 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PrimaryBucketException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PrimaryBucketException.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.GemFireException;
  * An exception thrown if a bucket instance is not primary yet was requested
  * to perform a modification operation. 
  *
- * @since 5.1
+ * @since GemFire 5.1
  *
  */
 public class PrimaryBucketException extends GemFireException

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyBucketRegion.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyBucketRegion.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyBucketRegion.java
index 245f5b2..7078fe2 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyBucketRegion.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyBucketRegion.java
@@ -57,7 +57,7 @@ import com.gemstone.gemfire.internal.logging.LogService;
  * Empty shell for {@link BucketRegion} which exists only to maintain metadata
  * in the form of a {@link BucketAdvisor}
  * 
- * @since 5.1
+ * @since GemFire 5.1
  */
 public final class ProxyBucketRegion implements Bucket {
   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/ProxyRegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyRegionMap.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyRegionMap.java
index 74c134b..ee8e0c8 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyRegionMap.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ProxyRegionMap.java
@@ -50,7 +50,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Released;
  * Internal implementation of {@link RegionMap}for regions whose DataPolicy is
  * proxy. Proxy maps are always empty.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  * 
  *  
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PutAllPartialResultException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PutAllPartialResultException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PutAllPartialResultException.java
index ee1ea1a..39e1a02 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PutAllPartialResultException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/PutAllPartialResultException.java
@@ -30,7 +30,7 @@ import java.util.*;
  *
  *
  *
- * @since 6.5
+ * @since GemFire 6.5
  */
 public class PutAllPartialResultException extends GemFireException {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/QueuedOperation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/QueuedOperation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/QueuedOperation.java
index 2d5a698..22f9903 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/QueuedOperation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/QueuedOperation.java
@@ -28,7 +28,7 @@ import java.io.*;
  * Represents a single operation that can be queued for reliable delivery.
  * Instances are owned in the context of a region.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class QueuedOperation
   {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionClearedException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionClearedException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionClearedException.java
index 5007882..03d6759 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionClearedException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionClearedException.java
@@ -19,7 +19,7 @@ package com.gemstone.gemfire.internal.cache;
 /**
  * Indicates that a Clear Operation happened while an entry operation
  * was in progress, which would result in the ongoing entry operation to abort
- * @since 5.1
+ * @since GemFire 5.1
  */
 public class RegionClearedException extends Exception  {
 private static final long serialVersionUID = 1266503771775907997L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntry.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntry.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntry.java
index 09aef2a..b35eaa3 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntry.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntry.java
@@ -42,7 +42,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Unretained;
  * has its own entry class. The "value" field of each of these entries
  * will implement this interface.
  *
- * @since 3.5.1
+ * @since GemFire 3.5.1
  *
 
 Implementations:
@@ -88,7 +88,7 @@ public interface RegionEntry {
    * Returns true if getLastAccessed, getHitCount, and getMissCount can be called
    * without throwing InternalStatisticsDisabledException.
    * Otherwise returns false.
-   * @since 6.0
+   * @since GemFire 6.0
    */
   public boolean hasStats();
     
@@ -200,7 +200,7 @@ public interface RegionEntry {
    * @see InitialImageOperation.RequestImageMessage#chunkEntries
    *
    * @return false if map entry not found
-   * @since 3.2.1
+   * @since GemFire 3.2.1
    */
   public boolean fillInValue(LocalRegion r,
       @Retained(ABSTRACT_REGION_ENTRY_FILL_IN_VALUE) InitialImageOperation.Entry entry,
@@ -271,7 +271,7 @@ public interface RegionEntry {
    * Returns the value as stored by the RegionEntry implementation.  For instance, if compressed this
    * value would be the compressed form.
    *  
-   * @since 8.0
+   * @since GemFire 8.0
    */
   @Retained
   public Object getTransformedValue();
@@ -357,13 +357,13 @@ public interface RegionEntry {
 
   /**
    * @return true if entry's value came from a netsearch
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public boolean getValueWasResultOfSearch();
   /**
    * @param v true if entry's value should be marked as having been
    * the result of a netsearch.
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public void setValueResultOfSearch(boolean v);
 
@@ -372,7 +372,7 @@ public interface RegionEntry {
    * on the disk, ignoring heap data.
    * @param localRegion the persistent region 
    * @return the serialized value from disk
-   * @since gemfire5.7_hotfix
+   * @since GemFire 5.7
    */
   public Object getSerializedValueOnDisk(LocalRegion localRegion);
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryContext.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryContext.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryContext.java
index abdefaa..064c8f2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryContext.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryContext.java
@@ -21,7 +21,7 @@ import com.gemstone.gemfire.compression.Compressor;
 
 /**
  * Provides important contextual information that allows a {@link RegionEntry} to manage its state.
- * @since 8.0
+ * @since GemFire 8.0
  */
 public interface RegionEntryContext extends HasCachePerfStats {
   public static final String DEFAULT_COMPRESSION_PROVIDER="com.gemstone.gemfire.compression.SnappyCompressor";

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryFactory.java
index efb071c..a5d9d79 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEntryFactory.java
@@ -21,7 +21,7 @@ package com.gemstone.gemfire.internal.cache;
 /**
  * A factory that produces RegionEntry instances.
  *
- * @since 3.5.1
+ * @since GemFire 3.5.1
  *
  *
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEventImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEventImpl.java
index 2304dea..333dfd2 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEventImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEventImpl.java
@@ -174,7 +174,7 @@ public class RegionEventImpl
    * Returns the value of the RegionEventImpl field.
    * This is for internal use only. Customers should always call
    * {@link #getCallbackArgument}
-   * @since 5.7 
+   * @since GemFire 5.7
    */
   public Object getRawCallbackArgument() {
     return this.callbackArgument;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEvictorTask.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEvictorTask.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEvictorTask.java
index ee49b64..2c0115e 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEvictorTask.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionEvictorTask.java
@@ -33,7 +33,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LocalizedMessage;
  * Takes delta to be evicted and tries to evict the least no of LRU entry which
  * would make evictedBytes more than or equal to the delta
  * 
- * @since 6.0
+ * @since GemFire 6.0
  * 
  */
 public class RegionEvictorTask implements Callable<Object> {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionFactoryImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionFactoryImpl.java
index fd3e42d..254d37d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionFactoryImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionFactoryImpl.java
@@ -26,7 +26,7 @@ import com.gemstone.gemfire.cache.client.ClientNotReadyException;
 /**
  * <code>RegionFactoryImpl</code> extends RegionFactory
  * adding {@link RegionShortcut} support.
- * @since 6.5
+ * @since GemFire 6.5
  */
 
 public class RegionFactoryImpl<K,V> extends RegionFactory<K,V>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMap.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMap.java
index a7c2607..a16f1ec 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMap.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMap.java
@@ -41,7 +41,7 @@ import com.gemstone.gemfire.internal.cache.versions.VersionTag;
  * its entries. Note that the value of every entry in this map will
  * implement {@link RegionEntry}.
  *
- * @since 3.5.1
+ * @since GemFire 3.5.1
  *
  *
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMapFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMapFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMapFactory.java
index 7a97408..cfbe4e6 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMapFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionMapFactory.java
@@ -22,7 +22,7 @@ package com.gemstone.gemfire.internal.cache;
 /**
  * Used to produce instances of RegionMap
  *
- * @since 3.5.1
+ * @since GemFire 3.5.1
  *
  *
  */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueue.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueue.java
index 0d6a841..5108861 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueue.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueue.java
@@ -26,7 +26,7 @@ import java.util.List;
  * implementations backed by regions.
  * 
  * 
- * @since 4.2
+ * @since GemFire 4.2
  */
 public interface RegionQueue
 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueueException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueueException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueueException.java
index 1aca59a..ed6c7e5 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueueException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionQueueException.java
@@ -22,7 +22,7 @@ import com.gemstone.gemfire.cache.CacheException;
  * An exception thrown by a <code>RegionQueue</code>.
  *
  *
- * @since 4.2
+ * @since GemFire 4.2
  */
 // Since this exception is in an internal package, we make it
 // a checked exception.

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionStatus.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionStatus.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionStatus.java
index 4f5003a..80a16ac 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionStatus.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RegionStatus.java
@@ -29,7 +29,7 @@ import java.io.Serializable;
  * <code>Region</code>s. This class is used by the monitoring tool.
  *
  *
- * @since 5.1
+ * @since GemFire 5.1
  */
 public class RegionStatus implements Serializable {
   private static final long serialVersionUID = 3442040750396350302L;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableDistributionData.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableDistributionData.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableDistributionData.java
index 30a5c24..a60b7f9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableDistributionData.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableDistributionData.java
@@ -22,7 +22,7 @@ import java.util.*;
  * Represents one or more distributed operations that can be reliably distributed.
  * This interface allows the data to be queued and checked for reliable distribution.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public interface ReliableDistributionData  {
 //  /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueue.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueue.java
index 5e0ec90..f26470d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueue.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueue.java
@@ -26,7 +26,7 @@ import java.util.Set;
  * is done.
  * Instances of this interface can be obtained from {@link ReliableMessageQueueFactory} which can be obtained from {@link GemFireCacheImpl#getReliableMessageQueueFactory}.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public interface ReliableMessageQueue {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactory.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactory.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactory.java
index 4a4dcf7..5a86a8f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactory.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactory.java
@@ -21,7 +21,7 @@ package com.gemstone.gemfire.internal.cache;
  * The Cache will have an instance of the factory that can be obtained
  * from {@link GemFireCacheImpl#getReliableMessageQueueFactory}.
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public interface ReliableMessageQueueFactory {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactoryImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactoryImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactoryImpl.java
index 170cbb1..57ed7d0 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactoryImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/ReliableMessageQueueFactoryImpl.java
@@ -24,7 +24,7 @@ import java.util.*;
 /**
  * Implementation of {@link ReliableMessageQueueFactory}
  * 
- * @since 5.0
+ * @since GemFire 5.0
  */
 public class ReliableMessageQueueFactoryImpl implements ReliableMessageQueueFactory {
   private boolean closed;
@@ -128,7 +128,7 @@ public class ReliableMessageQueueFactoryImpl implements ReliableMessageQueueFact
 
   /**
    * Implements ReliableMessageQueue.
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public class Queue implements ReliableMessageQueue {
     private final DistributedRegion r;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage.java
index acf8723..a1b5d0c 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteContainsKeyValueMessage.java
@@ -45,7 +45,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
 /**
  * This message is used be a replicate region to send a contains key/value request
  * to another peer.
- * @since 6.5
+ * @since GemFire 6.5
  */
 public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageWithDirectReply
   {
@@ -275,7 +275,7 @@ public final class RemoteContainsKeyValueMessage extends RemoteOperationMessageW
    * A processor to capture the value returned by {@link 
    * com.gemstone.gemfire.internal.cache.RemoteContainsKeyValueMessage.RemoteContainsKeyValueReplyMessage}
    * 
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public static class RemoteContainsKeyValueResponse extends RemoteOperationResponse
    {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteDestroyMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteDestroyMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteDestroyMessage.java
index f7109bb..822b317 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteDestroyMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteDestroyMessage.java
@@ -73,7 +73,7 @@ import static com.gemstone.gemfire.internal.cache.DistributedCacheOperation.VALU
  * frequently, if they are not then it makes sense to fold the destroy and the
  * invalidate into the same message and use an extra bit to differentiate
  * 
- * @since 6.5
+ * @since GemFire 6.5
  *  
  */
 public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply implements OldValueImporter {
@@ -204,7 +204,7 @@ public class RemoteDestroyMessage extends RemoteOperationMessageWithDirectReply
    * on one of the bridge servers.
    * 
    * @param event underlying event.
-   * @since 5.5
+   * @since GemFire 5.5
    */
   public void setOldValue(EntryEventImpl event){
     if (event.hasOldValue()) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchEntryMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchEntryMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchEntryMessage.java
index 685f0a5..b7cc393 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchEntryMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchEntryMessage.java
@@ -54,7 +54,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * reply is sent in a {@link 
  * com.gemstone.gemfire.internal.cache.RemoteFetchEntryMessage.FetchEntryReplyMessage}.
  * 
- * @since 5.1
+ * @since GemFire 5.1
  */
 public final class RemoteFetchEntryMessage extends RemoteOperationMessage
   {
@@ -194,7 +194,7 @@ public final class RemoteFetchEntryMessage extends RemoteOperationMessage
   /**
    * This message is used for the reply to a {@link RemoteFetchEntryMessage}.
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public static final class FetchEntryReplyMessage extends ReplyMessage
    {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchVersionMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchVersionMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchVersionMessage.java
index 12e4de6..21590f6 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchVersionMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteFetchVersionMessage.java
@@ -47,7 +47,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * DistributedRegions with DataPolicy EMPTY, NORMAL, PRELOADED, can use
  * this message to fetch VersionTag for a key.
  * 
- * @since 7.0
+ * @since GemFire 7.0
  */
 public final class RemoteFetchVersionMessage extends RemoteOperationMessage {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteGetMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteGetMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteGetMessage.java
index b565a2c..7e2be1f 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteGetMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteGetMessage.java
@@ -57,7 +57,7 @@ import com.gemstone.gemfire.internal.util.BlobHelper;
  * 
  * Replicate regions can use this message to send a Get request to another peer.
  * 
- * @since 6.5
+ * @since GemFire 6.5
  */
 public final class RemoteGetMessage extends RemoteOperationMessageWithDirectReply
   {
@@ -228,7 +228,7 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
    * is used <bold>very </bold> frequently the performance of this class is
    * critical.
    * 
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public static final class GetReplyMessage extends ReplyMessage
    {
@@ -363,7 +363,7 @@ public final class RemoteGetMessage extends RemoteOperationMessageWithDirectRepl
    * A processor to capture the value returned by {@link 
    * com.gemstone.gemfire.internal.cache.RemoteGetMessage.GetReplyMessage}
    * 
-   * @since 5.0
+   * @since GemFire 5.0
    */
   public static class RemoteGetResponse extends RemoteOperationResponse {
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
index c4ed1cc..f975f6f 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteInvalidateMessage.java
@@ -396,7 +396,7 @@ public final class RemoteInvalidateMessage extends RemoteDestroyMessage {
   }
   /**
    * A processor to capture the value returned by {@link RemoteInvalidateMessage}
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public static class InvalidateResponse extends RemoteOperationResponse  {
     private volatile boolean returnValueReceived;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationException.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationException.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationException.java
index 33d838e..dfaa6c0 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationException.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationException.java
@@ -25,7 +25,7 @@ import com.gemstone.gemfire.internal.Assert;
  * Indicates that the current non-partitioned region operation failed fatally.
  * 
  * @see com.gemstone.gemfire.internal.cache.RemoteOperationMessage
- * @since 6.5
+ * @since GemFire 6.5
  */
 public class RemoteOperationException extends
     DataLocationException

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
index 42ce811..8ffab72 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemoteOperationMessage.java
@@ -57,7 +57,7 @@ import com.gemstone.gemfire.internal.logging.log4j.LogMarker;
  * The base PartitionedRegion message type upon which other messages should be
  * based.
  * 
- * @since 6.5
+ * @since GemFire 6.5
  */
 public abstract class RemoteOperationMessage extends DistributionMessage implements 
     MessageWithReply, TransactionMessage
@@ -470,7 +470,7 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
   /**
    * added to support old value to be written on wire.
    * @param value true or false
-   * @since 6.5
+   * @since GemFire 6.5
    */
   public void setHasOldValue(boolean value) {
     // override in subclasses which need old value to be serialized.
@@ -506,7 +506,7 @@ public abstract class RemoteOperationMessage extends DistributionMessage impleme
    * recipient, capturing any CacheException thrown by the recipient and handle
    * it as an expected exception.
    * 
-   * @since 6.5
+   * @since GemFire 6.5
    * @see #waitForCacheException()
    */
   public static class RemoteOperationResponse extends DirectReplyProcessor {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/8eac0fa8/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutAllMessage.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutAllMessage.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutAllMessage.java
index ff09af9..045e51c 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutAllMessage.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/RemotePutAllMessage.java
@@ -65,7 +65,7 @@ import com.gemstone.gemfire.internal.offheap.annotations.Released;
  * A Replicate Region putAll message.  Meant to be sent only to
  * the peer who hosts transactional data.
  *
- * @since 6.5
+ * @since GemFire 6.5
  */
 public final class RemotePutAllMessage extends RemoteOperationMessageWithDirectReply
   {