You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/06/08 00:05:59 UTC

[82/90] [abbrv] incubator-geode git commit: GEODE-1464: remove sqlf code

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
index 0704bb8..7e2a0af 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySender.java
@@ -908,7 +908,7 @@ public abstract class AbstractGatewaySender implements GatewaySender,
       }
     } else {
       GatewaySenderEventCallbackArgument geCallbackArg = new GatewaySenderEventCallbackArgument(
-          callbackArg, this.getMyDSId(), allRemoteDSIds, true);
+          callbackArg, this.getMyDSId(), allRemoteDSIds);
       clonedEvent.setCallbackArgument(geCallbackArg);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySenderEventProcessor.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
index c57aebc..ce08e8d 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
@@ -810,7 +810,7 @@ public abstract class AbstractGatewaySenderEventProcessor extends Thread {
           }
           GatewaySenderEventCallbackArgument geCallbackArg = new GatewaySenderEventCallbackArgument(
               event.getRawCallbackArgument(), this.sender.getMyDSId(),
-              allRemoteDSIds, true);
+              allRemoteDSIds);
           event.setCallbackArgument(geCallbackArg);
           GatewaySenderEventImpl pdxSenderEvent = new GatewaySenderEventImpl(
               EnumListenerEvent.AFTER_UPDATE, event, null); // OFFHEAP: event for pdx type meta data so it should never be off-heap

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventCallbackArgument.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventCallbackArgument.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventCallbackArgument.java
index f84dbbb..82476c8 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventCallbackArgument.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventCallbackArgument.java
@@ -96,14 +96,10 @@ WrappedCallbackArgument implements DataSerializableFixedID {
    * @param originalReceivers
    *          The list of <code>Gateway</code> s to which the event has been
    *          originally sent
-   * @param serializeCBArg
-   *          boolean indicating whether to serialize callback argument
-   * 
    */
   public GatewaySenderEventCallbackArgument(Object originalCallbackArg,
-      int originatingDSId, List<Integer> originalReceivers,
-      boolean serializeCBArg) {
-    super(originalCallbackArg, serializeCBArg);
+      int originatingDSId, List<Integer> originalReceivers) {
+    super(originalCallbackArg);
     this.originatingDSId = originatingDSId;
     initializeReceipientDSIds(originalReceivers);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventImpl.java
index 8a811e2..83811ec 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/GatewaySenderEventImpl.java
@@ -515,10 +515,6 @@ public class GatewaySenderEventImpl implements
    *  //OFFHEAP TODO: Optimize callers by returning a reference to the off heap value
    */
   public Object getValue() {
-    if (CachedDeserializableFactory.preferObject()) {
-      // sqlf does not use CacheDeserializable wrappers
-      return getDeserializedValue();
-    }
     Object rawValue = this.value;
     if (rawValue == null) {
       rawValue = this.substituteValue;
@@ -535,9 +531,6 @@ public class GatewaySenderEventImpl implements
     if (valueIsObject == 0x00) {
       //if the value is a byte array, just return it
       return rawValue;
-    } else if (CachedDeserializableFactory.preferObject()) {
-      // sqlf does not use CacheDeserializable wrappers
-      return rawValue;
     } else if (rawValue instanceof byte[]) {
       return CachedDeserializableFactory.create((byte[]) rawValue);
     } else {
@@ -947,9 +940,7 @@ public class GatewaySenderEventImpl implements
      */
     @Retained(OffHeapIdentifier.GATEWAY_SENDER_EVENT_IMPL_VALUE)
     StoredObject so = null;
-    if (event.hasDelta()) {
-      this.valueIsObject = 0x02;
-    } else {
+    {
       ReferenceCountHelper.setReferenceCountOwner(this);
       so = event.getOffHeapNewValue();
       ReferenceCountHelper.setReferenceCountOwner(null);      
@@ -969,7 +960,7 @@ public class GatewaySenderEventImpl implements
       // can share a reference to the off-heap value.
       this.value = event.getCachedSerializedNewValue();
     } else {
-      final Object newValue = event.getRawNewValue(shouldApplyDelta());
+      final Object newValue = event.getRawNewValue();
       assert !(newValue instanceof StoredObject); // since we already called getOffHeapNewValue() and it returned null
       if (newValue instanceof CachedDeserializable) {
         this.value = ((CachedDeserializable) newValue).getSerializedValue();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueue.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueue.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueue.java
index 46ff263..e0f8b6f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueue.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/wan/parallel/ParallelGatewaySenderQueue.java
@@ -567,13 +567,8 @@ public class ParallelGatewaySenderQueue implements RegionQueue {
           if (isAccessor)
             return; // return from here if accessor node
 
-          // if the current node is marked uninitialized (SQLF DDL replay in
-          // progress) then we cannot wait for buckets to recover, because
-          // bucket creation has been disabled until DDL replay is complete.
-          if(!prQ.getCache().isUnInitializedMember(prQ.getDistributionManager().getId())) {
-            //Wait for buckets to be recovered.
-            prQ.shadowPRWaitForBucketRecovery();
-          }
+          //Wait for buckets to be recovered.
+          prQ.shadowPRWaitForBucketRecovery();
 
         } catch (IOException veryUnLikely) {
           logger.fatal(LocalizedMessage.create(LocalizedStrings.SingleWriteSingleReadRegionQueue_UNEXPECTED_EXCEPTION_DURING_INIT_OF_0,

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/RegionAttributesCreation.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/RegionAttributesCreation.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/RegionAttributesCreation.java
index 243d8c5..f79f7f9 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/RegionAttributesCreation.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/cache/xmlcache/RegionAttributesCreation.java
@@ -203,12 +203,10 @@ public class RegionAttributesCreation extends UserSpecifiedRegionAttributes impl
     this(cc, getDefaultAttributes(cc), true);
   }
 
-  // used by sqlfabric
   public RegionAttributesCreation() {
     this(defaultAttributes, true);
   }
 
-  // used by sqlfabric
   public RegionAttributesCreation(RegionAttributes attrs, boolean defaults) {
     this(null, attrs, defaults);
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/i18n/LocalizedStrings.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/i18n/LocalizedStrings.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/i18n/LocalizedStrings.java
index 13eca56..a09952e 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/i18n/LocalizedStrings.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/i18n/LocalizedStrings.java
@@ -734,7 +734,6 @@ public class LocalizedStrings {
   public static final StringId PartitionedRegion_FAILED_REGISTRATION_PRID_0_NAMED_1 = new StringId(1872, "FAILED_REGISTRATION prId={0} named {1}");
   public static final StringId PartitionedRegion_FORCEREATTEMPT_EXCEPTION___0 = new StringId(1873, "ForceReattempt exception :  {0}");
   public static final StringId PartitionedRegion_NEWLY_ADDED_MEMBER_TO_THE_PR_IS_AN_ACCESSOR_AND_WILL_NOT_RECEIVE_INDEX_INFORMATION_0 = new StringId(1874, "Newly added member to the PR is an accessor and will not receive index information : {0}");
-  public static final StringId FunctionService_ROUTING_OBJECTS_SET_IS_NULL = new StringId(1875, "Set for routing objects passed is null");
 
   public static final StringId PartitionedRegion_NO_VM_AVAILABLE_FOR_CONTAINS_KEY_IN_1_ATTEMPTS = new StringId(1877, "No VM available for contains key in {1} attempts");
   public static final StringId PartitionedRegion_NO_VM_AVAILABLE_FOR_CONTAINS_VALUE_FOR_KEY_IN_1_ATTEMPTS = new StringId(1878, "No VM available for contains value for key in {1} attempts");
@@ -836,8 +835,6 @@ public class LocalizedStrings {
 
   public static final StringId LocalRegion_THE_FOLLOWING_EXCEPTION_OCCURRED_ATTEMPTING_TO_GET_KEY_0 = new StringId(1995, "The following exception occurred attempting to get key={0}");
 
-  public static final StringId RegionAdvisor_CANNOT_RESET_EXISTING_BUCKET = new StringId(
-                                                                                                1997, "For region {0}: RegionAdvisor cannot reset existing bucket with ID {1}");
   public static final StringId SystemAdmin_LRU_OPTION_HELP = new StringId(1998, "-lru=<type> Sets region''s lru algorithm. Valid types are: none, lru-entry-count, lru-heap-percentage, or lru-memory-size");
   public static final StringId SystemAdmin_LRUACTION_OPTION_HELP = new StringId(1999, "-lruAction=<action> Sets the region''s lru action. Valid actions are: none, overflow-to-disk, local-destroy");
   public static final StringId SystemAdmin_LRULIMIT_OPTION_HELP = new StringId(2000, "-lruLimit=<int> Sets the region''s lru limit. Valid values are >= 0");
@@ -2973,9 +2970,6 @@ public class LocalizedStrings {
   public static final StringId GemFireCache_INITIALIZATION_FAILED_FOR_REGION_0 = new StringId(4609, "Initialization failed for Region {0}");
   public static final StringId LocalRegion_INITIALIZATION_FAILED_FOR_REGION_0 = new StringId(4610, "Initialization failed for Region {0}");
   public static final StringId PartitionedRegion_0_EVICTIONATTRIBUTES_1_DO_NOT_MATCH_WITH_OTHER_2 = new StringId(4611, "For Partitioned Region {0} the locally configured EvictionAttributes {1} do not match with other EvictionAttributes {2} and may cause misses during reads from VMs with smaller maximums.");
-  public static final StringId DSFIDFactory_COULD_NOT_INSTANTIATE_SQLFABRIC_MESSAGE_CLASSID_0_1 = new StringId(4616, "Could not instantiate SQLFabric message [classId:{0}]:{1}");
-  public static final StringId DSFIDFactory_ILLEGAL_ACCESS_FOR_SQLFABRIC_MESSAGE_CLASSID_0_1 = new StringId(4617, "Illegal access for SQLFabric message [classId:{0}]:{1}");
-  public static final StringId DSFIDFactory_UNKNOWN_CLASSID_0_FOR_SQLFABRIC_MESSAGE = new StringId(4618, "Unknown ClassId [{0}] for SQLFabric message");
   public static final StringId AbstractRegionMap_THE_CURRENT_VALUE_WAS_NOT_EQUAL_TO_EXPECTED_VALUE = new StringId(4619, "The current value was not equal to expected value.");
   public static final StringId AbstractRegionEntry_THE_CURRENT_VALUE_WAS_NOT_EQUAL_TO_EXPECTED_VALUE = new StringId(4620, "The current value was not equal to expected value.");
   public static final StringId AbstractRegionMap_ENTRY_NOT_FOUND_WITH_EXPECTED_VALUE = new StringId(4621, "entry not found with expected value");
@@ -3112,11 +3106,6 @@ public class LocalizedStrings {
   public static final StringId AttributesFactory_INVALIDATE_REGION_NOT_SUPPORTED_FOR_PR = new StringId(4784,"ExpirationAction INVALIDATE or LOCAL_INVALIDATE for region is not supported for Partitioned Region.");
   public static final StringId AttributesFactory_LOCAL_DESTROY_IS_NOT_SUPPORTED_FOR_PR = new StringId(4785,"ExpirationAction LOCAL_DESTROY is not supported for Partitioned Region.");
   public static final StringId AttributesFactory_LOCAL_INVALIDATE_IS_NOT_SUPPORTED_FOR_PR = new StringId(4786,"ExpirationAction LOCAL_INVALIDATE is not supported for Partitioned Region.");
-  public static final StringId GemFireUtilLauncher_ARGUMENTS = new StringId(4789, "Usage:\n{0} [{1}] <arguments for the utility specified>\n\nThe command to display a particular utility''s usage is:\n{0} <utility name> --help");
-  public static final StringId GemFireUtilLauncher_INVALID_UTILITY_0 = new StringId(4790, "Invalid utility name: {0} was specified.");
-  public static final StringId GemFireUtilLauncher_PROBLEM_STARTING_0 = new StringId(4791, "Problem starting {0}.");
-  public static final StringId GemFireUtilLauncher_MISSING_COMMAND = new StringId(4792, "** Missing command");
-  public static final StringId GemFireUtilLauncher_HELP = new StringId(4793, "** Displaying help information");
   public static final StringId AttributesFactory_DESTROY_REGION_NOT_SUPPORTED_FOR_PR = new StringId(4794,"ExpirationAction DESTROY or LOCAL_DESTROY for region is not supported for Partitioned Region.");
   public static final StringId ExecuteFunction_DS_NOT_CREATED_OR_NOT_READY = new StringId(4795, "DistributedSystem is either not created or not ready");
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/LoggingThreadGroup.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/LoggingThreadGroup.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/LoggingThreadGroup.java
index 82f487f..420b258 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/LoggingThreadGroup.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/LoggingThreadGroup.java
@@ -106,7 +106,6 @@ public class LoggingThreadGroup extends ThreadGroup {
       if (group == null) {
         group = new LoggingThreadGroup(name, logWriter);
         // force autoclean to false and not inherit from parent group
-        // (happens to be true for SQLFabric started threads as seen in #41438)
         group.setDaemon(false);
         loggingThreadGroups.add(group);
       }
@@ -161,7 +160,6 @@ public class LoggingThreadGroup extends ThreadGroup {
       if (group == null) {
         group = new LoggingThreadGroup(name, logger);
         // force autoclean to false and not inherit from parent group
-        // (happens to be true for SQLFabric started threads as seen in #41438)
         group.setDaemon(false);
         loggingThreadGroups.add(group);
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/ManagerLogWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/ManagerLogWriter.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/ManagerLogWriter.java
index 353813c..adc1a9e 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/ManagerLogWriter.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/ManagerLogWriter.java
@@ -324,40 +324,6 @@ public class ManagerLogWriter extends LocalLogWriter  {
       }
     }
 
-    /* This method is only used by sqlfabric, use getLogNameForOldMainLog instead - xzhou
-     *  
-     */
-//    public static File getMainLogName(File log) {
-//      /*
-//       * this is just searching for the existing logfile name
-//       * we need to search for meta log file name
-//       *
-//       */
-//      File dir = log.getAbsoluteFile().getParentFile();
-//      int previousMainId = calcNextMainId(dir, true);
-//      // comment out the following to fix bug 31789
-////       if (previousMainId > 1) {
-////         previousMainId--;
-////       }
-//      previousMainId--;
-//      File result = null;
-//      do {
-//        previousMainId++;
-//        StringBuffer buf = new StringBuffer(log.getPath());
-//        int insertIdx = buf.lastIndexOf(".");
-//        if (insertIdx == -1) {
-//          buf
-//            .append(formatId(previousMainId))
-//            .append(formatId(1));
-//        } else {
-//          buf.insert(insertIdx, formatId(1));
-//          buf.insert(insertIdx, formatId(previousMainId));
-//        }
-//        result = new File(buf.toString());
-//      } while (result.exists());
-//      return result;
-//    }
-    
     /**
      * as a fix for bug #41474 we use "." if getParentFile returns null
      */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/PureLogWriter.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/PureLogWriter.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/PureLogWriter.java
index 3279bf6..53bac4f 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/PureLogWriter.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/logging/PureLogWriter.java
@@ -186,7 +186,6 @@ public class PureLogWriter extends LogWriterImpl {
         return sw.toString();
     }
 
-    // split out header writing portion for SQLFabric logging
     protected void printHeader(PrintWriter pw, int msgLevel, Date msgDate,
         String connectionName, String threadName, long tid) {
       pw.println();
@@ -208,7 +207,6 @@ public class PureLogWriter extends LogWriterImpl {
       pw.print("] ");
     }
 
-    // made public for use by SQLFabric logging
     public String put(int msgLevel, Date msgDate, String connectionName,
         String threadName, long tid, String msg, String exceptionText) {
         String result = formatLogLine(msgLevel, msgDate, connectionName

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
index f3f064a..cd5f7dd 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/OffHeapHelper.java
@@ -33,7 +33,6 @@ public class OffHeapHelper {
   
   /**
    * If o is off-heap then return its heap form; otherwise return o since it is already on the heap.
-   * Note even if o is sqlf off-heap byte[] or byte[][] the heap form will be created.
    */
   public static Object getHeapForm(Object o) {
     if (o instanceof StoredObject) {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/ReferenceCountHelperImpl.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/ReferenceCountHelperImpl.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/ReferenceCountHelperImpl.java
index 571c2d1..6745414 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/ReferenceCountHelperImpl.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/ReferenceCountHelperImpl.java
@@ -208,7 +208,6 @@ class ReferenceCountHelperImpl {
           for (int i=0; i < list.size(); i++) {
             RefCountChangeInfo info = list.get(i);
             if (owner instanceof RegionEntry) {
-              // use identity comparison on region entries since sqlf does some wierd stuff in the equals method
               if (owner == info.getOwner()) {
                 if (info.getUseCount() > 0) {
                   info.decUseCount();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/annotations/OffHeapIdentifier.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/annotations/OffHeapIdentifier.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/annotations/OffHeapIdentifier.java
index e275467..23e8dcf 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/annotations/OffHeapIdentifier.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/offheap/annotations/OffHeapIdentifier.java
@@ -32,13 +32,9 @@ public enum OffHeapIdentifier {
   TX_ENTRY_STATE("com.gemstone.gemfire.internal.cache.originalVersionId"),
   GATEWAY_SENDER_EVENT_IMPL_VALUE("com.gemstone.gemfire.internal.cache.wan.GatewaySenderEventImpl.valueObj"),
   TEST_OFF_HEAP_REGION_BASE_LISTENER("com.gemstone.gemfire.internal.offheap.OffHeapRegionBase.MyCacheListener.ohOldValue and ohNewValue"),
-  COMPACT_COMPOSITE_KEY_VALUE_BYTES("com.vmware.sqlfire.internal.engine.store.CompactCompositeKey.valueBytes"),
-  // TODO: HOOTS: Deal with this
   REGION_ENTRY_VALUE(""),
   ABSTRACT_REGION_ENTRY_PREPARE_VALUE_FOR_CACHE("com.gemstone.gemfire.internal.cache.AbstractRegionEntry.prepareValueForCache(...)"),
   ABSTRACT_REGION_ENTRY_FILL_IN_VALUE("com.gemstone.gemfire.internal.cache.AbstractRegionEntry.fillInValue(...)"),
-  COMPACT_EXEC_ROW_SOURCE("com.vmware.sqlfire.internal.engine.store.CompactExecRow.source"),
-  COMPACT_EXEC_ROW_WITH_LOBS_SOURCE("com.vmware.sqlfire.internal.engine.store.CompactExecRowWithLobs.source"),
   GEMFIRE_TRANSACTION_BYTE_SOURCE(""),
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
index ead57ce..c8e7361 100755
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/shared/NativeCalls.java
@@ -17,7 +17,6 @@
 
 package com.gemstone.gemfire.internal.shared;
 
-import java.io.File;
 import java.io.FileDescriptor;
 import java.io.FileInputStream;
 import java.io.IOException;
@@ -38,21 +37,17 @@ import com.gemstone.gemfire.SystemFailure;
  * Encapsulates native C/C++ calls via JNA. To obtain an instance of
  * implementation for a platform, use {@link NativeCalls#getInstance()}.
  * 
- * This class is also referenced by ODBC/.NET drivers so it should not refer to
- * any classes other than standard JDK or those within the same package.
- * 
  * @since GemFire 8.0
  */
 public abstract class NativeCalls {
 
   /**
    * Static instance of NativeCalls implementation. This can be one of JNA
-   * implementations in <code>NativeCallsJNAImpl</code> or can fallback to a
+   * implementations in <code>NativeCallsJNAImpl</code> or can fall back to a
    * generic implementation in case JNA is not available for the platform.
    * 
-   * Note: this variable is deliberately not final since other drivers like
-   * those for ADO.NET or ODBC will plugin their own native implementations of
-   * NativeCalls.
+   * Note: this variable is deliberately not final so that other clients 
+   * can plug in their own native implementations of NativeCalls.
    */
   protected static NativeCalls instance;
 
@@ -60,7 +55,7 @@ public abstract class NativeCalls {
     NativeCalls inst;
     try {
       // try to load JNA implementation first
-      // we do it via reflection since some clients like ADO.NET/ODBC
+      // we do it via reflection since some clients
       // may not have it
       final Class<?> c = Class
           .forName("com.gemstone.gemfire.internal.shared.NativeCallsJNAImpl");
@@ -73,24 +68,8 @@ public abstract class NativeCalls {
       inst = null;
     }
     if (inst == null) {
-      // In case JNA implementations cannot be loaded, fallback to generic
-      // implementations.
-      // Other clients like ADO.NET/ODBC will plugin their own implementations.
-      try {
-        // using reflection to get the implementation based on OSProcess
-        // since this is also used by GemFireXD client; at some point all the
-        // functionality of OSProcess should be folded into the JNA impl
-        final Class<?> c = Class
-            .forName("com.gemstone.gemfire.internal.OSProcess$NativeOSCalls");
-        inst = (NativeCalls)c.newInstance();
-      } catch (VirtualMachineError e) {
-        SystemFailure.initiateFailure(e);
-        throw e;
-      } catch (Throwable t) {
-        SystemFailure.checkFailure();
-        // fallback to generic impl in case of a problem
-        inst = new NativeCallsGeneric();
-      }
+      // fall back to generic implementation in case of a problem
+      inst = new NativeCallsGeneric();
     }
     instance = inst;
   }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/util/ArrayUtils.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/util/ArrayUtils.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/util/ArrayUtils.java
index 4f15b17..04b1a15 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/util/ArrayUtils.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/util/ArrayUtils.java
@@ -255,7 +255,7 @@ public abstract class ArrayUtils {
         }
         else {
           first = false;
-          // for SQLFire show the first byte[] for byte[][] storage
+          // show the first byte[] for byte[][] storage
           objectStringWithBytes(o, sb);
         }
       }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
----------------------------------------------------------------------
diff --git a/geode-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java b/geode-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
index 0000fb9..0842d71 100644
--- a/geode-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
+++ b/geode-core/src/main/java/com/gemstone/gemfire/internal/util/concurrent/CustomEntryConcurrentHashMap.java
@@ -24,7 +24,7 @@
  * implementations can be plugged in. These HashEntry objects are now assumed to
  * be immutable in the sense that they cannot and should not be cloned in a
  * rehash, and the rehash mechanism has been recoded using locking for that. For
- * GemFire/SQLFire, this is now used to plugin the RegionEntry implementation
+ * Geode, this is now used to plugin the RegionEntry implementation
  * directly as a HashEntry instead of having it as a value and then HashEntry as
  * a separate object having references to key/value which reduces the entry
  * overhead substantially. Other change is to add a "create" method that creates

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java b/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
index b5f4149..4ecf3e3 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/cache30/MultiVMRegionTestCase.java
@@ -107,7 +107,6 @@ import com.gemstone.gemfire.internal.cache.TXManagerImpl;
 import com.gemstone.gemfire.internal.cache.TXStateProxy;
 import com.gemstone.gemfire.internal.cache.Token;
 import com.gemstone.gemfire.internal.cache.TombstoneService;
-import com.gemstone.gemfire.internal.cache.delta.Delta;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionHolder;
 import com.gemstone.gemfire.internal.cache.versions.RegionVersionVector;
 import com.gemstone.gemfire.internal.cache.versions.VMRegionVersionVector;
@@ -2964,145 +2963,6 @@ public abstract class MultiVMRegionTestCase extends RegionTestCase {
   }
   
   /**
-   * Delta implementation for the delta tests, appends " 10" if it's a string,
-   * or adds 10 if it's an Integer
-   */
-  static class AddTen implements Delta, Serializable {
-
-    public Object apply(EntryEvent<?, ?> putEvent) {
-      Object oldValue = putEvent.getOldValue();
-      if (oldValue instanceof String) {
-        return (String)oldValue + " 10";
-      }
-      else if (oldValue instanceof Integer) {
-        return new Integer(((Integer)oldValue).intValue() + 10);
-      }
-      else throw new IllegalStateException("unexpected old value");
-    }
-
-    public Object merge(Object toMerge, boolean isCreate) {
-      return null;
-    }
-
-    public Object merge(Object toMerge) {
-      return null;
-    }
-
-    public Object getResultantValue() {
-      return null;
-    }
-  }
-
-  /**
-   * Tests that a Delta is applied correctly both locally and on a replicate
-   * region.
-   */
-  public void testDeltaWithReplicate() throws InterruptedException {
-    if (!supportsReplication()) {
-      return;
-    }
-    //pauseIfNecessary(100); // wait for previous tearDown to complete
-    
-    final String name = this.getUniqueName();
-    final Object key1 = "KEY1";
-    final Object value1 = "VALUE1";
-    final Object key2 = "KEY2";
-    final Object value2 = new Integer (0xCAFE);
-    final Object key3 = "KEY3";
-    final Object value3 = "VALUE3";
-    
-    final Delta delta = new AddTen();
-
-    Host host = Host.getHost(0);
-    VM vm0 = host.getVM(0);
-    VM vm2 = host.getVM(2); // use VM on separate shared memory in case shared regions
-    
-    SerializableRunnable create = new
-    CacheSerializableRunnable("Create Replicate Region") {
-      public void run2() throws CacheException {
-        RegionAttributes ra = getRegionAttributes();
-        AttributesFactory factory =
-          new AttributesFactory(ra);
-        if (ra.getEvictionAttributes() == null
-            || !ra.getEvictionAttributes().getAction().isOverflowToDisk()) {
-          factory.setDiskStoreName(null);
-        }
-        factory.setDataPolicy(DataPolicy.REPLICATE);
-        createRegion(name, factory.create());
-      }
-    };
-    
-    vm0.invoke(create);
-    Thread.sleep(250);
-    vm2.invoke(create);
-    Thread.sleep(250);
-    
-    vm0.invoke(new CacheSerializableRunnable("Put data") {
-      public void run2() throws CacheException {
-        Region region = getRootRegion().getSubregion(name);
-        region.put(key1, value1);
-        region.put(key2, value2);
-        region.put(key3, value3);
-      }
-    });
-    
-    Invoke.invokeRepeatingIfNecessary(vm2, new CacheSerializableRunnable("Wait for update") {
-      public void run2() throws CacheException {
-        Region region = getRootRegion().getSubregion(name);
-        assertNotNull(region.getEntry(key1));
-        assertNotNull(region.getEntry(key2));
-        assertNotNull(region.getEntry(key3));
-      }
-    }, getRepeatTimeoutMs());
-    
-    // apply delta
-    vm0.invoke(new CacheSerializableRunnable("Apply delta") {
-      public void run2() throws CacheException {
-        Region region = getRootRegion().getSubregion(name);
-        region.put(key1, delta);
-        region.put(key2, delta);
-        region.put(key3, delta);
-      }
-    });
-    
-    CacheSerializableRunnable verify = 
-      new CacheSerializableRunnable("Verify values") {
-        public void run2() throws CacheException {
-          Region region = getRootRegion().getSubregion(name);
-          
-          Region.Entry entry1 = region.getEntry(key1);
-          assertNotNull(entry1);
-          assertEquals("VALUE1 10", entry1.getValue());
-          
-          Region.Entry entry2 = region.getEntry(key2);
-          assertNotNull(entry2);
-          assertEquals(new Integer(0xCAFE + 10), entry2.getValue());
-          
-          Region.Entry entry3 = region.getEntry(key3);
-          assertNotNull(entry3);
-          assertEquals("VALUE3 10", entry3.getValue());
-        }
-      };
-    
-    Invoke.invokeRepeatingIfNecessary(vm0, verify, getRepeatTimeoutMs());
-    
-    
-    // Destroy the local entries so we know that they are not found by
-    // a netSearch
-    vm0.invoke(new CacheSerializableRunnable("Remove local entries") {
-      public void run2() throws CacheException {
-        Region region = getRootRegion().getSubregion(name);
-        region.localDestroyRegion();
-      }
-    });
-    
-    Invoke.invokeRepeatingIfNecessary(vm2, verify, getRepeatTimeoutMs());
-    
-  }
-  
-  
-  
-  /**
    * Tests that a newly-created mirrored region contains all of the
    * entries of another region.
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
index 3e153e0..3e133f6 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/distributed/LocatorDUnitTest.java
@@ -115,7 +115,7 @@ public class LocatorDUnitTest extends DistributedTestCase {
   ////////  Test Methods
 
   /**
-   * SQLFire uses a colocated locator in a dm-type=normal VM.  This tests that
+   * This tests that
    * the locator can resume control as coordinator after all locators have been
    * shut down and one is restarted.  It's necessary to have a lock service
    * start so elder failover is forced to happen.  Prior to fixing how this worked

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
index 3538e41..06d0e08 100644
--- a/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/disttx/DistributedTransactionDUnitTest.java
@@ -36,11 +36,6 @@ import java.util.Properties;
 import java.util.Set;
 import java.util.concurrent.CountDownLatch;
 
-/**
- * Port of GemFireXD's corresponding test for distributed transactions
- * 
- *
- */
 @SuppressWarnings("deprecation")
 public class DistributedTransactionDUnitTest extends CacheTestCase {
   final protected String CUSTOMER_PR = "customerPRRegion";
@@ -345,11 +340,6 @@ public class DistributedTransactionDUnitTest extends CacheTestCase {
   
 
   
-  /**
-   * From GemFireXD: testTransactionalInsertOnReplicatedTable
-   * 
-   * @throws Exception
-   */
   public void testTransactionalPutOnReplicatedRegion() throws Exception {
     Host host = Host.getHost(0);
     VM server1 = host.getVM(0);
@@ -623,8 +613,6 @@ public class DistributedTransactionDUnitTest extends CacheTestCase {
   }
   
   /*
-   * [sjigyasu] This adapation of test from GemFireXD allows the difference in 
-   * the way GemFire and GemFireXD handle server groups.
    * We create 2 partitioned regions one on each server and have a third node
    * as accessor and fire transactional operations on it.
    */

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java
index 07f87a3..ca870cc 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/BackwardCompatibilitySerializationDUnitTest.java
@@ -167,15 +167,6 @@ public class BackwardCompatibilitySerializationDUnitTest extends CacheTestCase {
     constdsfids.add(new Byte(DataSerializableFixedID.RESULTS_BAG).intValue());
     constdsfids.add(new Byte(DataSerializableFixedID.GATEWAY_EVENT_IMPL_66)
         .intValue());
-    constdsfids.add(new Byte(DataSerializableFixedID.SQLF_TYPE).intValue());
-    constdsfids.add(new Byte(DataSerializableFixedID.SQLF_DVD_OBJECT)
-        .intValue());
-    constdsfids.add(new Byte(DataSerializableFixedID.SQLF_GLOBAL_ROWLOC)
-        .intValue());
-    constdsfids.add(new Byte(DataSerializableFixedID.SQLF_GEMFIRE_KEY)
-        .intValue());
-    constdsfids.add(new Byte(DataSerializableFixedID.SQLF_FORMATIBLEBITSET)
-        .intValue());
     constdsfids
         .add(new Short(DataSerializableFixedID.TOKEN_INVALID).intValue());
     constdsfids.add(new Short(DataSerializableFixedID.TOKEN_LOCAL_INVALID)

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
index 9462fab..3e83159 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/execute/PRCustomPartitioningDUnitTest.java
@@ -465,8 +465,7 @@ public class PRCustomPartitioningDUnitTest extends
 
 /**
  * Example implementation of a Partition Resolver which uses part of the value
- * for custom partitioning.  This example is a simplification of what SQLFabric
- * may do when the DDL specifies "partition by"    
+ * for custom partitioning.
 
  */
 class MonthBasedPartitionResolver implements PartitionResolver, Declarable2 {

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessageJUnitTest.java
----------------------------------------------------------------------
diff --git a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessageJUnitTest.java b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessageJUnitTest.java
index e08a268..bc974f7 100755
--- a/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessageJUnitTest.java
+++ b/geode-core/src/test/java/com/gemstone/gemfire/internal/cache/partitioned/FetchEntriesMessageJUnitTest.java
@@ -73,7 +73,6 @@ public class FetchEntriesMessageJUnitTest {
     cache = Fakes.cache();
     PartitionedRegion pr = mock(PartitionedRegion.class);
     InternalDistributedSystem system = cache.getDistributedSystem();
-    when(pr.keyRequiresRegionContext()).thenReturn(false);
 
     FetchEntriesResponse response = new FetchEntriesResponse(system, pr, null, 0);
     HeapDataOutputStream chunkStream = createDummyChunk();

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedDataSerializables.txt
----------------------------------------------------------------------
diff --git a/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedDataSerializables.txt b/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedDataSerializables.txt
index cd659e6..37eee1b 100644
--- a/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedDataSerializables.txt
+++ b/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedDataSerializables.txt
@@ -963,7 +963,7 @@ fromData,284,2bb9002301003d1c077e07a0000704a70004033e1c10207e1020a0000704a700040
 toData,299,033d033e2ab600089e003d1c07803d043e2ab6000b3a041904b9000c01009900271904b9000d0100c0000a3a051905c600131905c1001199000e1c1020803da70006a7ffd5b80012b20013b90014020099001fb80012b20013121505bd001659032a5359041cb8001753b9001804002b1cb9001902001d9900b32ab60008852bb8001abb001b592ab60008b7001c3a040336052ab6000b3a061906b9000c010099008a1906b9000d0100c0000a3a071907c7000d2b03b900190200a7006c1907b6001d3a081908c700132b04b90019020019072bb8001ea7005019041908b6001f360915099a00242b05b90019020084050115053609190419081509b600205719072bb8001ea700212b06b90019020019072b03b6002119071908b6002215090464852bb8001aa7ff72b1
 
 com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllEntryData,1
-toData,236,2ab4000a4e2ab4000c3a042d2bb8003d1904c1003e9a00081904c700192b03b9003f02001904c0003ec0003e2bb80040a700341904c1004199001f1904c000413a052b04b9003f02001905b9004201002bb80040a700102b04b9003f020019042bb800432b2ab40012b40044b9003f02002ab4000636052ab40026c6000a150507809136052ab40017c6001d15051008809136052ab40017c1004599000b150510208091360515051080809136052b1505b9003f02002ab40026c6000b2ab400262bb8003d2ab40017c6000b2ab400172bb800462ab6002899000b2ab400142bb800462ab400082bb80047b1
+toData,229,2ab4000a4d2ab4000c4e2c2bb8003d2dc1003e9a00072dc700182b03b9003f02002dc0003ec0003e2bb80040a700312dc1004199001e2dc000413a042b04b9003f02001904b9004201002bb80040a7000f2b04b9003f02002d2bb800432b2ab40012b40044b9003f02002ab4000636042ab40026c6000a150407809136042ab40017c6001d15041008809136042ab40017c1004599000b150410208091360415041080809136042b1504b9003f02002ab40026c6000b2ab400262bb8003d2ab40017c6000b2ab400172bb800462ab6002899000b2ab400142bb800462ab400082bb80047b1
 
 com/gemstone/gemfire/internal/cache/DistributedPutAllOperation$PutAllMessage,2
 fromData,197,2a2bb7003c2a2bb8003dc0003eb500052a2bb8003f88b500152a2ab40015bd0040b500062ab400159e00722bb800414dbb004259b700434e03360415042ab40015a200202ab400061504bb0040592b2ab4000515042c2db7004453840401a7ffdd2bb9004501003604150499002f2bb800463a0503360615062ab40015a2001d2ab4000615063219051506b60047c00048b5002e840601a7ffe02ab400491140007e99000e2a2bb8003dc0004bb5000b2a2ab400491180007e99000704a7000403b5001ab1
@@ -973,8 +973,9 @@ com/gemstone/gemfire/internal/cache/DistributedRegionFunctionStreamingMessage,2
 fromData,171,2a2bb700612bb9006201003d1c047e9900142a2bb900640100b500082ab40008b800651c077e99000d2a2bb900640100b500051c057e99000e2a2bb80066c00067b500062bb800664e2dc100689900252a03b5000d2a2dc00068b80069b500072ab40007c7001b2a2dc00068b5004ca700102a2dc0006ab500072a04b5000d2a2bb80066c0006bb500092a2bb8006cb5000b2a2bb8006db5000a2a1c10407e99000704a7000403b5000cb1
 toData,173,2a2bb7006f033d2ab400089900081c0480933d2ab40005029f00081c0780933d2ab40006c600081c0580933d2ab4000c9900091c104080933d2b1cb9007002002ab4000899000d2b2ab40008b9007102002ab40005029f000d2b2ab40005b9007102002ab40006c6000b2ab400062bb800722ab4000d99000e2ab400072bb80072a700102ab40007b9005701002bb800722ab400092bb800722ab4000bc000732bb800742ab4000a2bb80075b1
 
+
 com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllEntryData,1
-toData,146,2ab4000a4e2d2bb8003f2b2ab40010b40040b9004102002ab4000636042ab40022c6000a150407809136042ab40015c6001d15041008809136042ab40015c1004299000b150410208091360415041080809136042b1504b9004102002ab40022c6000b2ab400222bb8003f2ab40015c6000b2ab400152bb800432ab6002499000b2ab400122bb800432ab400082bb80044b1
+toData,136,2ab4000a4d2c2bb8003f2b2ab40010b40040b9004102002ab400063e2ab40022c600081d0780913e2ab40015c600191d100880913e2ab40015c100429900091d102080913e1d108080913e2b1db9004102002ab40022c6000b2ab400222bb8003f2ab40015c6000b2ab400152bb800432ab6002499000b2ab400122bb800432ab400082bb80044b1
 
 com/gemstone/gemfire/internal/cache/DistributedRemoveAllOperation$RemoveAllMessage,2
 fromData,197,2a2bb700382a2bb80039c0003ab500032a2bb8003b88b500132a2ab40013bd003cb500042ab400139e00722bb8003d4dbb003e59b7003f4e03360415042ab40013a200202ab400041504bb003c592b2ab4000315042c2db7004053840401a7ffdd2bb9004101003604150499002f2bb800423a0503360615062ab40013a2001d2ab4000415063219051506b60043c00044b5002b840601a7ffe02ab400451140007e99000e2a2bb80039c00047b500092a2ab400451180007e99000704a7000403b50018b1
@@ -1075,8 +1076,8 @@ fromData,16,2a2bb7000d2a2bb9000e0100b50002b1
 toData,16,2a2bb7000f2b2ab40002b900100200b1
 
 com/gemstone/gemfire/internal/cache/InitialImageOperation$Entry,2
-fromData,107,2a2bb9001b0100b500032bb9001b01003d2a2bb8001cb500122ab40003b8001499000d2ab2001db50002a7001d2ab600159a000e2a2bb8001eb50002a7000b2a2bb8001fb500022a2bb900200100b500041c047e9900162a1c057e99000704a70004032bb80021b5000db1
-toData,125,2b2ab40003b9000f02002ab4000dc6000704a70004033d1c2ab4000dc1001199000705a700040380913d2b1cb9000f02002ab400122bb800132ab40003b800149a00232ab600159a000e2ab400022bb80016a700112ab40002c00017c000172bb800182b2ab40004b9001903002ab4000dc6000b2ab4000d2bb8001ab1
+fromData,89,2a2bb900150100b500032bb9001501003d2a2bb80016b5000f2ab40003b8001199000d2ab20017b50002a7000b2a2bb80018b500022a2bb900190100b500041c047e9900162a1c057e99000704a70004032bb8001ab5000ab1
+toData,101,2b2ab40003b9000c02002ab4000ac6000704a70004033d1c2ab4000ac1000e99000705a700040380913d2b1cb9000c02002ab4000f2bb800102ab40003b800119a000b2ab400022bb800122b2ab40004b9001303002ab4000ac6000b2ab4000a2bb80014b1
 
 com/gemstone/gemfire/internal/cache/InitialImageOperation$FilterInfoMessage,2
 fromData,230,2a2bb7008c2a2bb8008db500202ab4000403322bb8008db5003d2ab4000403322bb8008db500402ab4000403322bb8008db500422ab4000403322bb8008db500442ab4000403322bb8008db500462ab4000403322bb8008db500482ab4000403322bb8008db5004a2ab4000403322bb8008db5004c2ab4000404322bb8008db5003d2ab4000404322bb8008db500402ab4000404322bb8008db500422ab4000404322bb8008db500442ab4000404322bb8008db500462ab4000404322bb8008db500482ab4000404322bb8008db5004a2ab4000404322bb8008db5004c2a2bb8008db50033b1
@@ -1175,7 +1176,7 @@ fromData,9,2a2bb8000eb50002b1
 toData,9,2ab400022bb8000fb1
 
 com/gemstone/gemfire/internal/cache/QueuedOperation,1
-toData,97,2b2ab40002b40035b9003602002ab400072bb800372ab40002b600319900442ab400032bb800372ab40002b600169a000d2ab40002b600159900282b2ab40006b9003602002ab40006049f000e2ab400042bb80038a7000b2ab400052bb80037b1
+toData,78,2b2ab40002b40035b9003602002ab400072bb800372ab40002b600319900312ab400032bb800372ab40002b600169a000d2ab40002b600159900152b2ab40006b9003602002ab400042bb80038b1
 
 com/gemstone/gemfire/internal/cache/RegionEventImpl,2
 fromData,48,2a2bb80025b500092a2bb80026b500022a2bb900270100b80028b5000a2a2bb900290100b500032a2bb8002ab5000bb1
@@ -1370,8 +1371,8 @@ fromData,37,2a2bb7004f2a2bb900500100b500052a2bb900500100b500032a2bb80051c00052b5
 toData,34,2a2bb7004c2b2ab40005b9004d02002b2ab40003b9004d02002ab400022bb8004eb1
 
 com/gemstone/gemfire/internal/cache/TXRegionLockRequestImpl,2
-fromData,102,2a2bb8000cb500032a03b7000d4d2bb8000e3e0336042cc600311d9e002d2a2c2ab40003b6000fc00010b500022ab40002c600172a2a2ab40002b600111d2bb70012b5000404360415049a00121d9e000e2a2a031d2bb70012b50004a700094e2a01b50004b1
-toData,17,2ab600212bb800222ab400042bb80023b1
+fromData,62,2a2bb8000cb500032a03b7000d4d2bb8000e3e2cc600161d9e00122a2c2ab40003b6000fc00010b500022a2a1d2bb70011b50004a700094e2a01b50004b1
+toData,17,2ab6001e2bb8001f2ab400042bb80020b1
 
 com/gemstone/gemfire/internal/cache/TXRemoteCommitMessage$TXRemoteCommitReplyMessage,2
 fromData,17,2a2bb7001a2a2bb8001bc0001cb50004b1
@@ -1410,16 +1411,16 @@ fromData,62,2a2bb700152bb9001601003d1c02a0000b2a01b50007a700271cbd00174e03360415
 toData,59,2a2bb700192ab40007c7000d2b02b9001a0200a700272ab40007be3d2b1cb9001a0200033e1d1ca200132ab400071d322bb8001b840301a7ffeeb1
 
 com/gemstone/gemfire/internal/cache/UpdateAttributesProcessor$UpdateAttributesMessage,2
-fromData,71,2a2bb7002a2a2bb8002bb500082a2bb9002c0100b500022ab40002b8002d2a2bb8002ec0000eb50005a700094d2a01b500052a2bb900300100b500032a2bb900300100b50004b1
-toData,52,2a2bb700312ab400082bb800322b2ab40002b9003302002ab400052bb800342b2ab40003b9003502002b2ab40004b900350200b1
+fromData,62,2a2bb7002a2a2bb8002bb500082a2bb9002c0100b500022ab40002b8002d2a2bb8002ec0000eb500052a2bb9002f0100b500032a2bb9002f0100b50004b1
+toData,52,2a2bb700302ab400082bb800312b2ab40002b9003202002ab400052bb800332b2ab40003b9003402002b2ab40004b900340200b1
 
 com/gemstone/gemfire/internal/cache/UpdateEntryVersionOperation$UpdateEntryVersionMessage,2
 fromData,45,2a2bb700322a2bb80033c00034b500022a2bb80033b500092bb800354d2cb6003699000b2a2bb80037b50005b1
 toData,118,2a2bb700382ab400022bb800392ab400092bb800392ab40003b6003ac0001e4d2cc1003b99002e2cb6003c4e2db6003d990018b2003e2bb8003f2ab40003b600402bb80041a7000ab200422bb8003fa700262cb60043990018b2003e2bb8003f2ab40003b600402bb80041a7000ab200422bb8003fb1
 
 com/gemstone/gemfire/internal/cache/UpdateOperation$UpdateMessage,2
-fromData,163,2a2bb7006c2bb9006d01003d1cb2006e7e99000704a70004033e1d9900332abb006f59b70070b500042ab400042bb800712bb900720100360415049900102a2bb900730100b80006b50007a700082a01b500042a2bb80074b5000d2a1cb200757e91b5000a2ab6002899000e2a2bb80076b50026a7002e2ab4000a04a0000e2a2bb80074b50010a7000b2a2bb80076b5000f1cb200777e99000b2a2bb80076b50026b1
-toData,235,2ab40003b60039c000784d2a2cb700792a2bb7007a2ab4000a3e2ab40004c6000a1db2006e80913e2ab4000a99001b2ab400059900142ab40003b6005bc6000a1db2007780913e2b1db9007b02002ab40004c6004b2ab400042bb8007c2cc1007d9900352cb6007e3a041904b6007f9a000d2b03b900800200a7001a2b04b9008002002b2ab40003b60081b60082b900830300a7000a2b03b9008002002ab4000d2bb800842ab6002899001e2ab40003b6005b2bb800852ab40003b60039b60086b60087a700262ab4000a2ab400102ab4000f2bb800881db200777e99000e2ab40003b6005b2bb80085b1
+fromData,144,2a2bb700692bb9006a01003d1cb2006b7e99000704a70004033e1d9900332abb006c59b7006db500042ab400042bb8006e2bb9006f0100360415049900102a2bb900700100b80006b50007a700082a01b500042a2bb80071b5000d2a1cb200727e91b5000a2ab6002899000e2a2bb80073b50026a7001b2a2bb80073b5000f1cb200747e99000b2a2bb80073b50026b1
+toData,235,2ab40003b60039c000754d2a2cb700762a2bb700772ab4000a3e2ab40004c6000a1db2006b80913e2ab4000a99001b2ab400059900142ab40003b60058c6000a1db2007480913e2b1db9007802002ab40004c6004b2ab400042bb800792cc1007a9900352cb6007b3a041904b6007c9a000d2b03b9007d0200a7001a2b04b9007d02002b2ab40003b6007eb6007fb900800300a7000a2b03b9007d02002ab4000d2bb800812ab6002899001e2ab40003b600582bb800822ab40003b60039b60083b60084a700262ab4000a2ab400102ab4000f2bb800851db200747e99000e2ab40003b600582bb80082b1
 
 com/gemstone/gemfire/internal/cache/UpdateOperation$UpdateWithContextMessage,2
 fromData,14,2a2bb700132a2bb80014b50009b1
@@ -1430,8 +1431,8 @@ fromData,17,2bb800204d2a2cbeb500082a2cb50006b1
 toData,9,2ab600212bb80022b1
 
 com/gemstone/gemfire/internal/cache/WrappedCallbackArgument,2
-fromData,9,2a2bb80005b50003b1
-toData,24,2ab4000299000e2ab400032bb80004a70008012bb80004b1
+fromData,9,2a2bb80004b50002b1
+toData,9,2ab400022bb80003b1
 
 com/gemstone/gemfire/internal/cache/compression/CompressedCachedDeserializable,2
 fromData,18,2a2ab600072bb8000eb900080200b50002b1

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/880f8648/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
----------------------------------------------------------------------
diff --git a/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt b/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
index 4e951af..8ea91f5 100755
--- a/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
+++ b/geode-core/src/test/resources/com/gemstone/gemfire/codeAnalysis/sanctionedSerializables.txt
@@ -245,7 +245,6 @@ com/gemstone/gemfire/internal/AbstractConfig$SortedProperties,true,7156507110684
 com/gemstone/gemfire/internal/ConfigSource,true,-4097017272431018553,description:java/lang/String,type:com/gemstone/gemfire/internal/ConfigSource$Type
 com/gemstone/gemfire/internal/ConfigSource$Type,false
 com/gemstone/gemfire/internal/CopyOnWriteHashSet,true,8591978652141659932
-com/gemstone/gemfire/internal/DSFIDFactory$SqlfSerializationException,true,5076687296705595933
 com/gemstone/gemfire/internal/DSFIDNotFoundException,true,130596009484324655,dsfid:int,versionOrdinal:short
 com/gemstone/gemfire/internal/InternalDataSerializer$SERIALIZATION_VERSION,false
 com/gemstone/gemfire/internal/InternalStatisticsDisabledException,true,4146181546364258311